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

abort() - Method in class alluxio.security.login.AlluxioLoginModule
Aborts the authentication (second phase).
abort() - Method in class alluxio.security.login.AppLoginModule
Aborts the authentication (second phase).
abortBlock(long, long) - Method in interface alluxio.worker.block.BlockStore
Aborts a temporary block.
abortBlock(long, long) - Method in interface alluxio.worker.block.BlockWorker
Aborts the temporary block created by the session.
abortBlock(long, long) - Method in class alluxio.worker.block.DefaultBlockWorker
 
abortBlock(long, long) - Method in class alluxio.worker.block.TieredBlockStore
 
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
 
abortTempBlockMeta(TempBlockMeta) - Method in class alluxio.worker.block.BlockMetadataManager
Aborts a temp block.
AbstractBackupRole - Class in alluxio.master.backup
Abstract backup role implementation.
AbstractBackupRole(CoreMasterContext) - Constructor for class alluxio.master.backup.AbstractBackupRole
Creates a BackupMaster.
AbstractBlockMeta - Class in alluxio.worker.block.meta
A base class of the metadata of blocks in Alluxio managed storage.
AbstractBlockMeta(long, StorageDir) - Constructor for class alluxio.worker.block.meta.AbstractBlockMeta
Creates a new instance of AbstractBlockMeta.
AbstractBlockStoreEventListener - Class in alluxio.worker.block
A block store event listener base class implementing the BlockStoreEventListener interface with empty methods bodies.
AbstractBlockStoreEventListener() - Constructor for class alluxio.worker.block.AbstractBlockStoreEventListener
 
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
 
AbstractClient - Class in alluxio
The base class for clients.
AbstractClient(ClientContext, InetSocketAddress) - Constructor for class alluxio.AbstractClient
Creates a new client base.
AbstractClient(ClientContext, InetSocketAddress, Supplier<RetryPolicy>) - Constructor for class alluxio.AbstractClient
Creates a new client base.
AbstractClient.RpcCallable<V> - Interface in alluxio
The RPC to be executed in AbstractClient.retryRPC(RpcCallable).
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.
AbstractEvictor - Class in alluxio.worker.block.evictor
Provides the basic implementation for every evictor.
AbstractEvictor(BlockMetadataEvictorView, Allocator) - Constructor for class alluxio.worker.block.evictor.AbstractEvictor
Creates a new instance of AbstractEvictor.
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
 
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
 
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.
AbstractMasterClient(MasterClientContext, InetSocketAddress, Supplier<RetryPolicy>) - Constructor for class alluxio.AbstractMasterClient
Creates a new master client base.
AbstractPrimarySelector - Class in alluxio.master
Base class for implementing primary selectors.
AbstractPrimarySelector() - Constructor for class alluxio.master.AbstractPrimarySelector
 
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>, InstancedConfiguration) - Constructor for class alluxio.cli.AbstractShell
Creates a new instance of AbstractShell.
AbstractTableCommand - Class in alluxio.cli.table.command
A class which should be extended when implementing commands for the TableShell.
AbstractTableCommand(AlluxioConfiguration, TableMasterClient) - Constructor for class alluxio.cli.table.command.AbstractTableCommand
Creates a new instance of AbstractTableCommand.
AbstractUfsManager - Class in alluxio.underfs
Basic implementation of UfsManager.
AbstractUfsManager.Key - Class in alluxio.underfs
The key of the UFS cache.
AbstractValidationTask - Class in alluxio.cli.validation
Abstract class for validation environment.
AbstractValidationTask() - Constructor for class alluxio.cli.validation.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
 
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.
ACCESS_ACL_FIELD_NUMBER - Static variable in class alluxio.proto.meta.InodeMeta.Inode
 
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.
accessBlock(long, long) - Method in class alluxio.worker.block.DefaultBlockWorker
 
accessBlock(long, long) - Method in class alluxio.worker.block.TieredBlockStore
 
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() - 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, long, OpenOptions) - Method in class alluxio.worker.block.UfsInputStreamManager
Acquires an input stream.
acquire(UnderFileSystem, String, long, OpenOptions, boolean) - Method in class alluxio.worker.block.UfsInputStreamManager
Acquires an input stream.
acquireAccess(long, long, Protocol.OpenUfsBlockOptions) - Method in class alluxio.worker.block.UnderFileSystemBlockStore
Acquires access for a UFS block given a UnderFileSystemBlockMeta and the limit on the maximum concurrency on the block.
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.
acquireClientResource() - Method in class alluxio.table.under.hive.util.HiveClientPool
 
acquireConnection(GrpcChannelKey, AlluxioConfiguration) - Method in class alluxio.grpc.GrpcConnectionPool
Acquires and increases the ref-count for the ManagedChannel.
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.
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
 
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
 
ACTIVE_SYNC_TX_ID_FIELD_NUMBER - Static variable in class alluxio.proto.journal.Journal.JournalEntry
 
ActiveSyncer - Class in alluxio.master.file.activesync
Periodically sync the files for a particular mount point.
ActiveSyncer(FileSystemMaster, ActiveSyncManager, MountTable, long) - Constructor for class alluxio.master.file.activesync.ActiveSyncer
Constructs a new ActiveSyncer.
ActiveSyncManager - Class in alluxio.master.file.activesync
Manager for the Active UFS sync process.
ActiveSyncManager(MountTable, FileSystemMaster) - Constructor for class alluxio.master.file.activesync.ActiveSyncManager
Constructs a Active Sync Manager.
activeSyncMetadata(AlluxioURI, Collection<AlluxioURI>, ExecutorService) - Method in class alluxio.master.file.DefaultFileSystemMaster
Actively sync metadata, based on a list of changed files.
activeSyncMetadata(AlluxioURI, Collection<AlluxioURI>, ExecutorService) - Method in interface alluxio.master.file.FileSystemMaster
Starts a batch sync with a list of changed files passed in.
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(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(TimeSeries) - Method in class alluxio.job.util.TimeSeries
Add one histogram to the current one.
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(Supplier<JournalContext>, String, Map<PropertyKey, String>) - Method in class alluxio.master.meta.PathProperties
Adds properties for path.
add(Class<W>, T) - Method in class alluxio.Registry
 
add(AclAction) - Method in class alluxio.security.authorization.AclActions
Adds a permitted action.
add(T) - Method in class alluxio.underfs.ObjectUnderFileSystem.OperationBuffer
Add 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_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
 
ADD_TABLE_FIELD_NUMBER - Static variable in class alluxio.proto.journal.Journal.JournalEntry
 
ADD_TRANSFORM_JOB_INFO_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
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
addAggregator(MultiValueMetricsAggregator) - Method in class alluxio.master.metrics.DefaultMetricsMaster
 
addAll(Collection<? extends T>) - Method in class alluxio.collections.DelegatingSet
 
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
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 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;
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;
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.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;
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;
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;
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
addAllPartitionCols(Iterable<? extends FieldSchema>) - Method in class alluxio.proto.journal.Table.AddTableEntry.Builder
partitioning scheme
addAllPartitions(Iterable<? extends Partition>) - Method in class alluxio.grpc.table.ReadTablePResponse.Builder
repeated .alluxio.grpc.table.Partition partitions = 1;
addAllPartitions(Iterable<? extends Partition>) - Method in class alluxio.proto.journal.Table.AddTableEntry.Builder
repeated .alluxio.grpc.table.Partition partitions = 9;
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;
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;
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
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;
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;
addAllSyncPaths(Iterable<? extends SyncPointInfo>) - Method in class alluxio.grpc.GetSyncPathListPResponse.Builder
repeated .alluxio.grpc.file.SyncPointInfo syncPaths = 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;
addAllTableStats(Iterable<? extends ColumnStatisticsInfo>) - Method in class alluxio.proto.journal.Table.AddTableEntry.Builder
repeated .alluxio.grpc.table.ColumnStatisticsInfo table_stats = 6;
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;
addAllTiers(Iterable<? extends LocalityTier>) - Method in class alluxio.grpc.TieredIdentity.Builder
repeated .alluxio.grpc.LocalityTier tiers = 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)
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.
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 class alluxio.worker.block.meta.StorageDir
Adds the metadata of a new block into this storage dir.
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;
addBlocksToDelete(List<Long>) - Method in class alluxio.worker.block.AsyncBlockRemover
Put blocks into async block remover.
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;
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;
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, String, Source) - Method in class alluxio.wire.Configuration.Builder
Adds a cluster level property.
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;
AddCommand - Class in alluxio.cli.fsadmin.pathconf
Adds path level configurations.
AddCommand(Context, AlluxioConfiguration) - Constructor for class alluxio.cli.fsadmin.pathconf.AddCommand
 
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;
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;
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;
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;
addExternalMasterAddress(MasterNetAddress) - Method in class alluxio.multi.process.MultiProcessCluster
Updates internal master list with an external address.
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;
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.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;
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.
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;
addInnerValue(K1, K2, V) - Method in class alluxio.collections.TwoKeyConcurrentMap
 
addInode(Inode) - Method in class alluxio.master.file.meta.TtlBucket
Adds a inode to the bucket.
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;
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;
addLocation(long, Block.BlockLocation) - Method in interface alluxio.master.metastore.BlockStore
Adds a new block location.
addLocation(long, Block.BlockLocation) - Method in class alluxio.master.metastore.heap.HeapBlockStore
 
addLocation(long, Block.BlockLocation) - Method in class alluxio.master.metastore.rocks.RocksBlockStore
 
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(String, String) - Method in class alluxio.master.block.meta.MasterWorkerInfo
Adds a new worker lost storage path.
addLostStorage(Map<String, StorageList>) - Method in class alluxio.master.block.meta.MasterWorkerInfo
Adds new worker lost storage paths.
addMapping(String, String) - Method in class alluxio.table.under.hive.util.PathTranslator
Add a mapping to the path translator.
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;
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.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.
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.DefaultMetaStore
 
addPage(PageId, PageInfo) - Method in interface alluxio.client.file.cache.MetaStore
Adds a new page to the cache.
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
addPartitionCols(FieldSchema) - Method in class alluxio.proto.journal.Table.AddTableEntry.Builder
partitioning scheme
addPartitionCols(int, FieldSchema) - Method in class alluxio.proto.journal.Table.AddTableEntry.Builder
partitioning scheme
addPartitionCols(FieldSchema.Builder) - Method in class alluxio.proto.journal.Table.AddTableEntry.Builder
partitioning scheme
addPartitionCols(int, FieldSchema.Builder) - Method in class alluxio.proto.journal.Table.AddTableEntry.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
addPartitionColsBuilder() - Method in class alluxio.proto.journal.Table.AddTableEntry.Builder
partitioning scheme
addPartitionColsBuilder(int) - Method in class alluxio.proto.journal.Table.AddTableEntry.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;
addPartitions(Partition) - Method in class alluxio.proto.journal.Table.AddTableEntry.Builder
repeated .alluxio.grpc.table.Partition partitions = 9;
addPartitions(int, Partition) - Method in class alluxio.proto.journal.Table.AddTableEntry.Builder
repeated .alluxio.grpc.table.Partition partitions = 9;
addPartitions(Partition.Builder) - Method in class alluxio.proto.journal.Table.AddTableEntry.Builder
repeated .alluxio.grpc.table.Partition partitions = 9;
addPartitions(int, Partition.Builder) - Method in class alluxio.proto.journal.Table.AddTableEntry.Builder
repeated .alluxio.grpc.table.Partition partitions = 9;
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;
addPartitionsBuilder() - Method in class alluxio.proto.journal.Table.AddTableEntry.Builder
repeated .alluxio.grpc.table.Partition partitions = 9;
addPartitionsBuilder(int) - Method in class alluxio.proto.journal.Table.AddTableEntry.Builder
repeated .alluxio.grpc.table.Partition partitions = 9;
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;
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;
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, String>) - 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, String) - Method in class alluxio.multi.process.MultiProcessCluster.Builder
 
addProxy(Address, Address) - Method in class alluxio.master.transport.GrpcMessagingProxy
Adds a new proxy mapping.
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.worker.block.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.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.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.BlockStoreLocationProto.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.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.Command.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.CommitBlockInUfsPOptions.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.CommitBlockInUfsPRequest.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.CommitBlockInUfsPResponse.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.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.CreateLocalBlockRequest.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.CreateLocalBlockResponse.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.ExistsPOptions.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.FileBlockInfo.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.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.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.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.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.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.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.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.GetServiceVersionPRequest.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.GetServiceVersionPResponse.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.GetSyncPathListPRequest.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.GetSyncPathListPResponse.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.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.JobServiceSummary.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.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.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.LoadMetadataPOptions.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.LocalityTier.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.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.NetAddress.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.OpenFilePOptions.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.OpenLocalBlockRequest.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.OpenLocalBlockResponse.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.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.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.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.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.ReverseResolvePRequest.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.ReverseResolvePResponse.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.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.StartSyncPOptions.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.StartSyncPRequest.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.StartSyncPResponse.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.StatusSummary.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.StopSyncPOptions.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.StopSyncPRequest.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.StopSyncPResponse.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.StorageList.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.SyncPointInfo.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.TieredIdentity.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.TierList.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.TransportMessage.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.UfsInfo.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.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.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.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.CreateUfsBlockOptions.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.OpenUfsBlockOptions.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.proto.dataserver.Protocol.Response.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.Journal.JournalEntry.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.Table.AddTableEntry.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.proto.journal.Table.AddTransformJobInfoEntry.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.proto.journal.Table.AttachDbEntry.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.proto.journal.Table.CompleteTransformTableEntry.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.proto.journal.Table.DetachDbEntry.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.proto.journal.Table.RemoveTableEntry.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.proto.journal.Table.RemoveTransformJobInfoEntry.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.proto.journal.Table.UpdateDatabaseInfoEntry.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.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.WorkerInfo
 
ADDRESS_FIELD_NUMBER - Static variable in class alluxio.grpc.WorkerLostStorageInfo
 
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
 
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
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;
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;
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;
addSwiftCredentials(Configuration) - Static method in class alluxio.hadoop.HadoopUtils
Adds Swift keys to the given Hadoop Configuration object if the user has specified them using System properties, and they're not already set.
addSyncPaths(SyncPointInfo) - Method in class alluxio.grpc.GetSyncPathListPResponse.Builder
repeated .alluxio.grpc.file.SyncPointInfo syncPaths = 1;
addSyncPaths(int, SyncPointInfo) - Method in class alluxio.grpc.GetSyncPathListPResponse.Builder
repeated .alluxio.grpc.file.SyncPointInfo syncPaths = 1;
addSyncPaths(SyncPointInfo.Builder) - Method in class alluxio.grpc.GetSyncPathListPResponse.Builder
repeated .alluxio.grpc.file.SyncPointInfo syncPaths = 1;
addSyncPaths(int, SyncPointInfo.Builder) - Method in class alluxio.grpc.GetSyncPathListPResponse.Builder
repeated .alluxio.grpc.file.SyncPointInfo syncPaths = 1;
addSyncPathsBuilder() - Method in class alluxio.grpc.GetSyncPathListPResponse.Builder
repeated .alluxio.grpc.file.SyncPointInfo syncPaths = 1;
addSyncPathsBuilder(int) - Method in class alluxio.grpc.GetSyncPathListPResponse.Builder
repeated .alluxio.grpc.file.SyncPointInfo syncPaths = 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;
addTableStats(ColumnStatisticsInfo) - Method in class alluxio.proto.journal.Table.AddTableEntry.Builder
repeated .alluxio.grpc.table.ColumnStatisticsInfo table_stats = 6;
addTableStats(int, ColumnStatisticsInfo) - Method in class alluxio.proto.journal.Table.AddTableEntry.Builder
repeated .alluxio.grpc.table.ColumnStatisticsInfo table_stats = 6;
addTableStats(ColumnStatisticsInfo.Builder) - Method in class alluxio.proto.journal.Table.AddTableEntry.Builder
repeated .alluxio.grpc.table.ColumnStatisticsInfo table_stats = 6;
addTableStats(int, ColumnStatisticsInfo.Builder) - Method in class alluxio.proto.journal.Table.AddTableEntry.Builder
repeated .alluxio.grpc.table.ColumnStatisticsInfo table_stats = 6;
addTableStatsBuilder() - Method in class alluxio.proto.journal.Table.AddTableEntry.Builder
repeated .alluxio.grpc.table.ColumnStatisticsInfo table_stats = 6;
addTableStatsBuilder(int) - Method in class alluxio.proto.journal.Table.AddTableEntry.Builder
repeated .alluxio.grpc.table.ColumnStatisticsInfo table_stats = 6;
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.
addTask(long, WorkerInfo) - 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 class alluxio.worker.block.BlockMetadataManager
Adds a temp block.
addTempBlockMeta(TempBlockMeta) - Method in class alluxio.worker.block.meta.StorageDir
Adds the metadata of a new block into this storage dir.
addTiers(LocalityTier) - Method in class alluxio.grpc.TieredIdentity.Builder
repeated .alluxio.grpc.LocalityTier tiers = 1;
addTiers(int, LocalityTier) - Method in class alluxio.grpc.TieredIdentity.Builder
repeated .alluxio.grpc.LocalityTier tiers = 1;
addTiers(LocalityTier.Builder) - Method in class alluxio.grpc.TieredIdentity.Builder
repeated .alluxio.grpc.LocalityTier tiers = 1;
addTiers(int, LocalityTier.Builder) - Method in class alluxio.grpc.TieredIdentity.Builder
repeated .alluxio.grpc.LocalityTier tiers = 1;
addTiers(long) - Method in class alluxio.grpc.TierList.Builder
repeated int64 tiers = 1;
addTiersBuilder() - Method in class alluxio.grpc.TieredIdentity.Builder
repeated .alluxio.grpc.LocalityTier tiers = 1;
addTiersBuilder(int) - Method in class alluxio.grpc.TieredIdentity.Builder
repeated .alluxio.grpc.LocalityTier 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.
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)
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;
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
addWorker(long, String) - Method in class alluxio.master.block.meta.MasterBlockInfo
Adds a location of the block.
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
advance() - Method in interface alluxio.master.journal.JournalReader
Advances the reader to the next element.
advance() - Method in class alluxio.master.journal.ufs.UfsJournalReader
 
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.meta.RetryHandlingMetaMasterMasterClient
 
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.
AggregateException - Exception in alluxio.exception
Represents a collection of exceptions.
AggregateException(Collection<Exception>) - Constructor for exception alluxio.exception.AggregateException
Creates a new instance of AggregateException.
ALL_FIELD_NUMBER - Static variable in class alluxio.grpc.table.AllOrNoneSet
 
ALL_OPTION_NAME - Static variable in class alluxio.cli.fsadmin.pathconf.ShowCommand
 
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
 
allMetricKeys() - Static method in class alluxio.metrics.MetricKey
 
allMetrics() - Static method in class alluxio.metrics.MetricsSystem
 
allocateBlockWithView(long, long, BlockStoreLocation, BlockMetadataView) - Method in interface alluxio.worker.block.allocator.Allocator
Allocates a block from the given block store location under a given view.
allocateBlockWithView(long, long, BlockStoreLocation, BlockMetadataView) - Method in class alluxio.worker.block.allocator.GreedyAllocator
 
allocateBlockWithView(long, long, BlockStoreLocation, BlockMetadataView) - Method in class alluxio.worker.block.allocator.MaxFreeAllocator
 
allocateBlockWithView(long, long, BlockStoreLocation, BlockMetadataView) - Method in class alluxio.worker.block.allocator.RoundRobinAllocator
 
Allocator - Interface in alluxio.worker.block.allocator
Interface for the allocation policy of Alluxio managed data.
Allocator.Factory - Class in alluxio.worker.block.allocator
Factory for 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.
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.checker - package alluxio.checker
 
alluxio.cli - package alluxio.cli
 
alluxio.cli.bundler - package alluxio.cli.bundler
 
alluxio.cli.bundler.command - package alluxio.cli.bundler.command
 
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.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.pathconf - package alluxio.cli.fsadmin.pathconf
 
alluxio.cli.fsadmin.report - package alluxio.cli.fsadmin.report
 
alluxio.cli.job - package alluxio.cli.job
 
alluxio.cli.job.command - package alluxio.cli.job.command
 
alluxio.cli.table - package alluxio.cli.table
 
alluxio.cli.table.command - package alluxio.cli.table.command
 
alluxio.cli.validation - package alluxio.cli.validation
 
alluxio.client - package alluxio.client
 
alluxio.client.block - package alluxio.client.block
 
alluxio.client.block.options - package alluxio.client.block.options
 
alluxio.client.block.policy - package alluxio.client.block.policy
 
alluxio.client.block.policy.options - package alluxio.client.block.policy.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.evictor - package alluxio.client.file.cache.evictor
 
alluxio.client.file.cache.store - package alluxio.client.file.cache.store
 
alluxio.client.file.options - package alluxio.client.file.options
 
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.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.path - package alluxio.conf.path
 
alluxio.examples - package alluxio.examples
 
alluxio.exception - package alluxio.exception
 
alluxio.exception.status - package alluxio.exception.status
 
alluxio.extensions - package alluxio.extensions
 
alluxio.file.options - package alluxio.file.options
 
alluxio.fuse - package alluxio.fuse
 
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.job - package alluxio.job
 
alluxio.job.meta - package alluxio.job.meta
 
alluxio.job.plan - package alluxio.job.plan
 
alluxio.job.plan.load - package alluxio.job.plan.load
 
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.transform - package alluxio.job.plan.transform
 
alluxio.job.plan.transform.compact - package alluxio.job.plan.transform.compact
 
alluxio.job.plan.transform.format - package alluxio.job.plan.transform.format
 
alluxio.job.plan.transform.format.csv - package alluxio.job.plan.transform.format.csv
 
alluxio.job.plan.transform.format.parquet - package alluxio.job.plan.transform.format.parquet
 
alluxio.job.plan.transform.format.tables - package alluxio.job.plan.transform.format.tables
 
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.logserver - package alluxio.logserver
 
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.activesync - package alluxio.master.file.activesync
 
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.replication - package alluxio.master.file.replication
 
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.plan - package alluxio.master.job.plan
 
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.table - package alluxio.master.table
 
alluxio.master.table.transform - package alluxio.master.table.transform
 
alluxio.master.transport - package alluxio.master.transport
 
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.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.refresh - package alluxio.refresh
 
alluxio.resource - package alluxio.resource
 
alluxio.retry - package alluxio.retry
Set of utilities for working with retryable operations.
alluxio.security - package alluxio.security
 
alluxio.security.authentication - package alluxio.security.authentication
 
alluxio.security.authentication.plain - package alluxio.security.authentication.plain
 
alluxio.security.authorization - package alluxio.security.authorization
 
alluxio.security.group - package alluxio.security.group
 
alluxio.security.group.provider - package alluxio.security.group.provider
 
alluxio.security.login - package alluxio.security.login
 
alluxio.security.user - package alluxio.security.user
 
alluxio.shell - package alluxio.shell
 
alluxio.table - package alluxio.table
 
alluxio.table.common - package alluxio.table.common
 
alluxio.table.common.layout - package alluxio.table.common.layout
 
alluxio.table.common.transform - package alluxio.table.common.transform
 
alluxio.table.common.transform.action - package alluxio.table.common.transform.action
 
alluxio.table.common.udb - package alluxio.table.common.udb
 
alluxio.table.under.hive - package alluxio.table.under.hive
 
alluxio.table.under.hive.util - package alluxio.table.under.hive.util
 
alluxio.time - package alluxio.time
 
alluxio.underfs - package alluxio.underfs
 
alluxio.underfs.cos - package alluxio.underfs.cos
 
alluxio.underfs.gcs - package alluxio.underfs.gcs
 
alluxio.underfs.hdfs - package alluxio.underfs.hdfs
 
alluxio.underfs.hdfs.acl - package alluxio.underfs.hdfs.acl
 
alluxio.underfs.hdfs.activesync - package alluxio.underfs.hdfs.activesync
 
alluxio.underfs.kodo - package alluxio.underfs.kodo
 
alluxio.underfs.local - package alluxio.underfs.local
 
alluxio.underfs.options - package alluxio.underfs.options
 
alluxio.underfs.oss - package alluxio.underfs.oss
 
alluxio.underfs.s3a - package alluxio.underfs.s3a
 
alluxio.underfs.swift - package alluxio.underfs.swift
 
alluxio.underfs.swift.http - package alluxio.underfs.swift.http
 
alluxio.underfs.wasb - package alluxio.underfs.wasb
 
alluxio.underfs.web - package alluxio.underfs.web
 
alluxio.uri - package alluxio.uri
 
alluxio.util - package alluxio.util
 
alluxio.util.executor - package alluxio.util.executor
 
alluxio.util.interfaces - package alluxio.util.interfaces
 
alluxio.util.io - package alluxio.util.io
 
alluxio.util.logging - package alluxio.util.logging
 
alluxio.util.network - package alluxio.util.network
 
alluxio.util.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.allocator - package alluxio.worker.block.allocator
 
alluxio.worker.block.evictor - package alluxio.worker.block.evictor
Set of evictors for evicting or moving blocks to other locations.
alluxio.worker.block.io - package alluxio.worker.block.io
 
alluxio.worker.block.meta - package alluxio.worker.block.meta
 
alluxio.worker.file - package alluxio.worker.file
 
alluxio.worker.grpc - package alluxio.worker.grpc
 
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_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_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_LOCALITY_SCRIPT - Static variable in class alluxio.Constants
 
ALLUXIO_MASTER_SERVLET_RESOURCE_KEY - Static variable in class alluxio.web.MasterWebServer
 
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_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_USE_FIXED_TEST_PORTS - Static variable in class alluxio.multi.process.MultiProcessCluster
 
ALLUXIO_WORKER_SERVLET_RESOURCE_KEY - Static variable in class alluxio.web.WorkerWebServer
 
AlluxioBlockStore - Class in alluxio.client.block
Alluxio Block Store client.
AlluxioCatalog - Class in alluxio.master.table
Class representing the Alluxio catalog.
AlluxioCatalog() - Constructor for class alluxio.master.table.AlluxioCatalog
Creates an instance.
AlluxioCommand(String, String) - Constructor for class alluxio.cli.bundler.command.CollectAlluxioInfoCommand.AlluxioCommand
AlluxioConfiguration - Interface in alluxio.conf
Alluxio configuration.
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.
AlluxioFileInStream - Class in alluxio.client.file
An implementation of FileInStream for data stored in Alluxio.
AlluxioFileInStream(URIStatus, InStreamOptions, FileSystemContext) - Constructor for class alluxio.client.file.AlluxioFileInStream
 
AlluxioFileOutStream - Class in alluxio.client.file
Provides a streaming API to write a file.
AlluxioFileOutStream(AlluxioURI, OutStreamOptions, FileSystemContext) - Constructor for class alluxio.client.file.AlluxioFileOutStream
Creates a new file output stream.
AlluxioFileSystem - Class in alluxio.hadoop
The Alluxio implementation of Hadoop AbstractFileSystem.
AlluxioFrameworkIntegrationTest - Class in alluxio.cli
Integration tests for AlluxioFramework.
AlluxioFuse - Class in alluxio.fuse
Main entry point to Alluxio-FUSE.
AlluxioFuseFileSystem - Class in alluxio.fuse
Main FUSE implementation class.
AlluxioFuseFileSystem(FileSystem, AlluxioFuseOptions, AlluxioConfiguration) - Constructor for class alluxio.fuse.AlluxioFuseFileSystem
Creates a new instance of AlluxioFuseFileSystem.
AlluxioFuseOptions - Class in alluxio.fuse
Convenience class to pass around Alluxio-FUSE options.
AlluxioFuseOptions(String, String, boolean, List<String>) - Constructor for class alluxio.fuse.AlluxioFuseOptions
 
AlluxioFuseUtils - Class in alluxio.fuse
Utility methods for Alluxio-FUSE.
AlluxioHdfsFileSystem - Class in alluxio.hadoop
A wrapper class to translate Hadoop FileSystem to Alluxio FileSystem.
AlluxioHdfsFileSystem(FileSystem, Configuration) - Constructor for class alluxio.hadoop.AlluxioHdfsFileSystem
 
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
 
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
 
AlluxioLog4jSocketNode - Class in alluxio.logserver
Reads LoggingEvent objects from remote logging clients and writes the objects to designated log files.
AlluxioLog4jSocketNode(String, Socket) - Constructor for class alluxio.logserver.AlluxioLog4jSocketNode
Constructor of AlluxioLog4jSocketNode.
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.
AlluxioLogServer - Class in alluxio.logserver
Alluxio log server receiving logs pushed from Alluxio servers.
AlluxioLogServerProcess - Class in alluxio.logserver
A centralized log server for Alluxio.
AlluxioLogServerProcess(String) - Constructor for class alluxio.logserver.AlluxioLogServerProcess
Constructs an AlluxioLogServerProcess instance.
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.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
 
AlluxioRemoteLogFilter - Class in alluxio
Thin filter to add MDC information to LoggingEvent.
AlluxioRemoteLogFilter() - Constructor for class alluxio.AlluxioRemoteLogFilter
 
AlluxioSecondaryMaster - Class in alluxio.master
The secondary Alluxio master that replays journal logs and writes checkpoints.
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.
AlluxioWorkerRestServiceHandler - Class in alluxio.worker
This class is a REST handler for requesting general worker information.
AlluxioWorkerRestServiceHandler(ServletContext) - Constructor for class alluxio.worker.AlluxioWorkerRestServiceHandler
 
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
 
ALWAYS_VALUE - Static variable in enum alluxio.grpc.LoadMetadataPType
Always load metadata.
AlwaysHealthyJobWorkerHealthReporter - Class in alluxio.worker.job.command
JobWorkerHealthReporter that always reports that the worker is healthy.
AlwaysHealthyJobWorkerHealthReporter() - Constructor for class alluxio.worker.job.command.AlwaysHealthyJobWorkerHealthReporter
 
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.Constants
 
ANSI_PURPLE - Static variable in class alluxio.Constants
 
ANSI_RED - Static variable in class alluxio.Constants
 
ANSI_RESET - Static variable in class alluxio.Constants
 
ANSI_WHITE - Static variable in class alluxio.Constants
 
ANSI_YELLOW - Static variable in class alluxio.Constants
 
ANY_DIR - Static variable in class alluxio.worker.block.BlockStoreLocation
Special value to indicate any dir.
ANY_MEDIUM - Static variable in class alluxio.worker.block.BlockStoreLocation
Special value to indicate any medium type.
ANY_TIER - Static variable in class alluxio.worker.block.BlockStoreLocation
Special value to indicate any tier.
anyDirInTier(String) - Static method in class alluxio.worker.block.BlockStoreLocation
Convenience method to return the block store location representing any dir in the tier.
anyDirInTierWithMedium(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.
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.
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(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 interface alluxio.master.journal.JournalContext
 
append(Journal.JournalEntry) - Method in class alluxio.master.journal.MasterJournalContext
 
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 interface alluxio.worker.block.io.BlockWriter
Appends data to the end of a block from an input ByteBuffer.
append(ByteBuf) - Method in interface alluxio.worker.block.io.BlockWriter
Appends buf.readableBytes() bytes to the end of this block writer from the given buf.
append(DataBuffer) - Method in interface 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.block.io.LocalFileBlockWriter
 
append(ByteBuf) - Method in class alluxio.worker.block.io.LocalFileBlockWriter
 
append(DataBuffer) - Method in class alluxio.worker.block.io.LocalFileBlockWriter
 
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.
appendPath(URI, String) - Static method in class alluxio.util.URIUtils
Appends the given path to the given base URI.
appendPathOrDie(URI, String) - Static method in class alluxio.util.URIUtils
Appends the given path to the given base URI.
AppLoginModule - Class in alluxio.security.login
An app login module that creates a user based on the user name provided through application configuration.
AppLoginModule() - Constructor for class alluxio.security.login.AppLoginModule
Constructs a new AppLoginModule.
AppLoginModule.AppCallbackHandler - Class in alluxio.security.login
A callback handler for AppLoginModule.
apply(A, B, C) - Method in interface alluxio.collections.TwoKeyConcurrentMap.TriFunction
 
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() - Method in interface alluxio.master.table.transform.TransformManager.ThrowingSupplier
 
applyAndJournal(Supplier<JournalContext>, File.AddSyncPointEntry) - Method in class alluxio.master.file.activesync.ActiveSyncManager
Apply File.AddSyncPointEntry and journal the entry.
applyAndJournal(Supplier<JournalContext>, File.RemoveSyncPointEntry) - Method in class alluxio.master.file.activesync.ActiveSyncManager
Apply File.RemoveSyncPointEntry and journal the entry.
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
 
applyAndJournal(Supplier<JournalContext>, Journal.JournalEntry) - Method in class alluxio.master.table.Database
 
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(Commit<JournalEntryCommand>) - 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.
approximateContentHash(long, long) - Static method in class alluxio.util.UnderFileSystemUtils
Returns an approximate content hash, using the length and modification time.
argsToString(String, T...) - Static method in class alluxio.util.CommonUtils
Converts varargs of objects to a string.
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
 
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.
assertValidPort(InetSocketAddress) - Static method in class alluxio.util.network.NetworkAddressUtils
Checks if the given port in the address is valid.
ASYNC_CACHE_UFS_SESSION_ID - Static variable in class alluxio.Sessions
 
ASYNC_CACHE_WORKER_SESSION_ID - Static variable in class alluxio.Sessions
 
ASYNC_PERSIST_REQUEST_FIELD_NUMBER - Static variable in class alluxio.proto.journal.Journal.JournalEntry
 
ASYNC_THROUGH_VALUE - Static variable in enum alluxio.grpc.WritePType
ASYNC_THROUGH = 5;
AsyncBlockRemover - Class in alluxio.worker.block
Asynchronous block removal service.
AsyncBlockRemover(BlockWorker) - Constructor for class alluxio.worker.block.AsyncBlockRemover
Constructor of AsyncBlockRemover.
asyncCache(AsyncCacheRequest) - Method in interface alluxio.client.block.stream.BlockWorkerClient
Caches a block asynchronously.
asyncCache(AsyncCacheRequest) - Method in class alluxio.client.block.stream.DefaultBlockWorkerClient
 
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.BlockWorkerImplBase
 
asyncCache(AsyncCacheRequest, StreamObserver<AsyncCacheResponse>) - Method in class alluxio.grpc.BlockWorkerGrpc.BlockWorkerStub
 
asyncCache(AsyncCacheRequest, StreamObserver<AsyncCacheResponse>) - Method in class alluxio.worker.grpc.BlockWorkerImpl
 
AsyncCacheRequest - Class in alluxio.grpc
Request for caching a block asynchronously next available id: 6
AsyncCacheRequest.Builder - Class in alluxio.grpc
Request for caching a block asynchronously next available id: 6
AsyncCacheRequestManager - Class in alluxio.worker.block
Handles client requests to asynchronously cache blocks.
AsyncCacheRequestManager(ExecutorService, BlockWorker, FileSystemContext) - Constructor for class alluxio.worker.block.AsyncCacheRequestManager
 
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
 
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 - 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) - Constructor for class alluxio.master.file.meta.AsyncUfsAbsentPathCache
Creates a new instance of AsyncUfsAbsentPathCache.
asyncUpdateFileAccessTime(AlluxioURI) - Method in class alluxio.client.file.MetadataCachingBaseFileSystem
Asynchronously update file's last access time.
AsyncUserAccessAuditLogWriter - Class in alluxio.master.audit
AsyncUserAccessAuditLogWriter writes user access audit log entries asynchronously.
AsyncUserAccessAuditLogWriter() - 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.
ATTACH_DB_FIELD_NUMBER - Static variable in class alluxio.proto.journal.Journal.JournalEntry
 
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) - 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.TableMasterClientServiceImplBase
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
attachDatabase(JournalContext, String, String, String, String, Map<String, String>, boolean) - Method in class alluxio.master.table.AlluxioCatalog
Attaches an udb database to Alluxio catalog.
attachDatabase(String, String, String, String, Map<String, String>, boolean) - Method in class alluxio.master.table.DefaultTableMaster
 
attachDatabase(String, String, String, String, Map<String, String>, boolean) - Method in interface alluxio.master.table.TableMaster
Attach an existing database to the catalog.
attachDatabase(AttachDatabasePRequest, StreamObserver<AttachDatabasePResponse>) - Method in class alluxio.master.table.TableMasterClientServiceHandler
 
AttachDatabaseCommand - Class in alluxio.cli.table.command
A command which can be used to attach a UDB to the Alluxio master's table service.
AttachDatabaseCommand(AlluxioConfiguration, TableMasterClient) - Constructor for class alluxio.cli.table.command.AttachDatabaseCommand
Creates a new instance of AttachDatabaseCommand.
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(StreamObserver<SaslMessage>) - Method in class alluxio.grpc.SaslAuthenticationServiceGrpc.SaslAuthenticationServiceImplBase
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() - Method in class alluxio.security.authentication.ChannelAuthenticator
It builds an authenticated channel.
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
 
authenticate() - Method in class alluxio.underfs.swift.KeystoneV3AccessProvider
 
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
 
AuthenticationUserUtils - Class in alluxio.security.authentication
This class provides util methods for AuthenticationUserUtilss.
authority() - Method in class alluxio.grpc.GrpcChannel
 
Authority - Interface in alluxio.uri
This interface represents the authority part of a URI.
AuthType - Enum in alluxio.security.authentication
Different authentication types for Alluxio.
available() - Method in class alluxio.hadoop.AlluxioHdfsInputStream
 
available() - Method in class alluxio.hadoop.HdfsFileInputStream
 
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 secondary 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(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.util.executor.ControllableScheduler
 
awaitTermination() - Method in interface alluxio.worker.DataServer
Waits for server to terminate.
awaitTermination() - Method in class alluxio.worker.grpc.GrpcDataServer
 

B

backup(BackupPRequest) - Method in interface alluxio.client.meta.MetaMasterClient
Takes a backup.
backup(BackupPRequest) - Method in class alluxio.client.meta.RetryHandlingMetaMasterClient
 
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.MetaMasterClientServiceImplBase
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_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_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
 
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 secondary 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.proxy.s3.S3ErrorCode
 
BAD_DIGEST - Static variable in class alluxio.proxy.s3.S3ErrorCode.Name
 
BASE_LAYOUT_FIELD_NUMBER - Static variable in class alluxio.grpc.table.Partition
 
BaseConfiguration<T extends BaseProperty> - Class in alluxio.table.common
This represents a configuration of the catalog.
BaseConfiguration() - Constructor for class alluxio.table.common.BaseConfiguration
 
BaseConfiguration(Map<String, String>) - Constructor for class alluxio.table.common.BaseConfiguration
Creates an instance.
BaseFileSystem - Class in alluxio.client.file
Default implementation of the FileSystem interface.
BaseFileSystem(FileSystemContext) - Constructor for class alluxio.client.file.BaseFileSystem
Constructs a new base file system.
BasePartitionScheme - Class in alluxio.master.table
Base implementation of PartitionScheme with default implementation of PartitionScheme.getPartition(String) and PartitionScheme.getPartitions().
BasePartitionScheme(List<Partition>) - Constructor for class alluxio.master.table.BasePartitionScheme
A map from partition spec to partitions is computed from the partitions.
BaseProperty - Class in alluxio.table.common
This represents a property name and default value for the UDB.
BaseProperty(String, String, String) - Constructor for class alluxio.table.common.BaseProperty
 
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
 
BasicCheckpoint - Class in alluxio.examples
An example to show to how use Alluxio's API.
BasicCheckpoint(String, int, FileSystemContext) - Constructor for class alluxio.examples.BasicCheckpoint
 
BasicNonByteBufferOperations - Class in alluxio.examples
Basic example of using the FileSystem for writing to and reading from files.
BasicNonByteBufferOperations(AlluxioURI, ReadType, WriteType, boolean, int, FileSystemContext) - Constructor for class alluxio.examples.BasicNonByteBufferOperations
 
BasicOperations - Class in alluxio.examples
Example to show the basic operations of Alluxio.
BasicOperations(AlluxioURI, ReadType, WriteType, FileSystemContext) - Constructor for class alluxio.examples.BasicOperations
 
beforeConnect() - Method in class alluxio.AbstractClient
This method is called before the connection is connected.
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.
BIGINT - Static variable in class alluxio.job.plan.transform.HiveConstants.Types
Hive big int type.
BINARY - Static variable in class alluxio.job.plan.transform.HiveConstants.Types
Hive binary type.
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() - Method in class alluxio.grpc.BlockMasterClientServiceGrpc.BlockMasterClientServiceImplBase
 
bindService() - Method in class alluxio.grpc.BlockMasterWorkerServiceGrpc.BlockMasterWorkerServiceImplBase
 
bindService() - Method in class alluxio.grpc.BlockWorkerGrpc.BlockWorkerImplBase
 
bindService() - Method in class alluxio.grpc.FileSystemMasterClientServiceGrpc.FileSystemMasterClientServiceImplBase
 
bindService() - Method in class alluxio.grpc.FileSystemMasterJobServiceGrpc.FileSystemMasterJobServiceImplBase
 
bindService() - Method in class alluxio.grpc.FileSystemMasterWorkerServiceGrpc.FileSystemMasterWorkerServiceImplBase
 
bindService() - Method in class alluxio.grpc.JobMasterClientServiceGrpc.JobMasterClientServiceImplBase
 
bindService() - Method in class alluxio.grpc.JobMasterWorkerServiceGrpc.JobMasterWorkerServiceImplBase
 
bindService() - Method in class alluxio.grpc.JournalMasterClientServiceGrpc.JournalMasterClientServiceImplBase
 
bindService() - Method in class alluxio.grpc.MessagingServiceGrpc.MessagingServiceImplBase
 
bindService() - Method in class alluxio.grpc.MetaMasterClientServiceGrpc.MetaMasterClientServiceImplBase
 
bindService() - Method in class alluxio.grpc.MetaMasterConfigurationServiceGrpc.MetaMasterConfigurationServiceImplBase
 
bindService() - Method in class alluxio.grpc.MetaMasterMasterServiceGrpc.MetaMasterMasterServiceImplBase
 
bindService() - Method in class alluxio.grpc.MetricsMasterClientServiceGrpc.MetricsMasterClientServiceImplBase
 
bindService() - Method in class alluxio.grpc.SaslAuthenticationServiceGrpc.SaslAuthenticationServiceImplBase
 
bindService() - Method in class alluxio.grpc.ServiceVersionClientServiceGrpc.ServiceVersionClientServiceImplBase
 
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
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(long, Block.BlockMeta) - Constructor for class alluxio.master.metastore.BlockStore.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.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_ID_FIELD_NUMBER - Static variable in class alluxio.grpc.AsyncCacheRequest
 
BLOCK_ID_FIELD_NUMBER - Static variable in class alluxio.grpc.CreateLocalBlockRequest
 
BLOCK_ID_FIELD_NUMBER - Static variable in class alluxio.grpc.MoveBlockRequest
 
BLOCK_ID_FIELD_NUMBER - Static variable in class alluxio.grpc.OpenLocalBlockRequest
 
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.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_IN_UFS_TIER_FIELD_NUMBER - Static variable in class alluxio.proto.dataserver.Protocol.OpenUfsBlockOptions
 
BLOCK_INFO_FIELD_NUMBER - Static variable in class alluxio.proto.journal.Journal.JournalEntry
 
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.proto.dataserver.Protocol.OpenUfsBlockOptions
 
BLOCK_WORKER_CLIENT_SERVICE_NAME - 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 detail message.
BlockAlreadyExistsException(String, Throwable) - Constructor for exception alluxio.exception.BlockAlreadyExistsException
Constructs a new exception with the specified detail message and cause.
BlockAlreadyExistsException(ExceptionMessage, Object...) - Constructor for exception alluxio.exception.BlockAlreadyExistsException
Constructs a new exception with the specified exception message and multiple parameters.
BlockAlreadyExistsException(ExceptionMessage, Throwable, Object...) - Constructor for exception alluxio.exception.BlockAlreadyExistsException
Constructs a new exception with the specified exception message, the cause and multiple parameters.
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.
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.
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.BlockMasterWorkerServiceImplBase
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.
BlockHeartbeatReporter - Class in alluxio.worker.block
Represents the delta of the block store within one heartbeat period.
BlockHeartbeatReporter() - Constructor for class alluxio.worker.block.BlockHeartbeatReporter
Creates a new instance of BlockHeartbeatReporter.
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.CommitBlockInUfsPRequest
 
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
 
BlockInStream - Class in alluxio.client.block.stream
Provides an InputStream implementation that is based on DataReaders to stream data chunk by chunk.
BlockInStream(DataReader.Factory, WorkerNetAddress, BlockInStream.BlockInStreamSource, long, long) - Constructor for class alluxio.client.block.stream.BlockInStream
Creates an instance of BlockInStream.
BlockInStream.BlockInStreamSource - Enum in alluxio.client.block.stream
the source tracking where the block is from.
BlockIntegrityChecker - Class in alluxio.master.file
Heartbeat executor for validating inode and block integrity.
BlockIntegrityChecker(FileSystemMaster) - Constructor for class alluxio.master.file.BlockIntegrityChecker
Constructs a block integrity checker based on the given FileSystemMaster.
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
 
BlockLocationPolicy - Interface in alluxio.client.block.policy
Interface for determining the Alluxio worker location to serve a block write or UFS block read.
BlockLocationPolicy.Factory - Class in alluxio.client.block.policy
The factory for the BlockLocationPolicy.
BlockLocationUtils - Class in alluxio.client.block.util
Utility functions for working with block locations.
BlockLockManager - Class in alluxio.worker.block
Handle all block locks.
BlockLockManager() - Constructor for class alluxio.worker.block.BlockLockManager
Constructs a new BlockLockManager.
BlockLockType - Enum in alluxio.worker.block
A read-write lock to guard one block.
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.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.
BlockMasterClientRestServiceHandler - Class in alluxio.master.block
Deprecated.
since version 1.4 and will be removed in version 2.0
BlockMasterClientRestServiceHandler(ServletContext) - Constructor for class alluxio.master.block.BlockMasterClientRestServiceHandler
Deprecated.
BlockMasterClientServiceGrpc - Class in alluxio.grpc
This interface contains block master service endpoints for Alluxio clients.
BlockMasterClientServiceGrpc.BlockMasterClientServiceBlockingStub - Class in alluxio.grpc
This interface contains block master service endpoints for Alluxio clients.
BlockMasterClientServiceGrpc.BlockMasterClientServiceFutureStub - Class in alluxio.grpc
This interface contains block master service endpoints for Alluxio clients.
BlockMasterClientServiceGrpc.BlockMasterClientServiceImplBase - Class in alluxio.grpc
This interface contains block master service endpoints for Alluxio clients.
BlockMasterClientServiceGrpc.BlockMasterClientServiceStub - Class in alluxio.grpc
This interface contains block master service endpoints for Alluxio clients.
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
 
BlockMasterSync - Class in alluxio.worker.block
Task that carries out the necessary block worker to master communications, including register and heartbeat.
BlockMasterWorkerServiceGrpc - Class in alluxio.grpc
This interface contains block master service endpoints for Alluxio workers.
BlockMasterWorkerServiceGrpc.BlockMasterWorkerServiceBlockingStub - Class in alluxio.grpc
This interface contains block master service endpoints for Alluxio workers.
BlockMasterWorkerServiceGrpc.BlockMasterWorkerServiceFutureStub - Class in alluxio.grpc
This interface contains block master service endpoints for Alluxio workers.
BlockMasterWorkerServiceGrpc.BlockMasterWorkerServiceImplBase - Class in alluxio.grpc
This interface contains block master service endpoints for Alluxio workers.
BlockMasterWorkerServiceGrpc.BlockMasterWorkerServiceStub - Class in alluxio.grpc
This interface contains block master service endpoints for Alluxio workers.
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 - Class in alluxio.worker.block.meta
Represents the metadata of a block in Alluxio managed storage.
BlockMeta(long, long, StorageDir) - Constructor for class alluxio.worker.block.meta.BlockMeta
Creates a new instance of BlockMeta.
BlockMeta(TempBlockMeta) - Constructor for class alluxio.worker.block.meta.BlockMeta
Creates a new instance of BlockMeta from TempBlockMeta.
BlockMetadataAllocatorView - Class in alluxio.worker.block
This class exposes a narrower read-only view of block metadata to allocators.
BlockMetadataAllocatorView(BlockMetadataManager) - Constructor for class alluxio.worker.block.BlockMetadataAllocatorView
Creates a new instance of BlockMetadataAllocatorView.
BlockMetadataEvictorView - Class in alluxio.worker.block
This class exposes a narrower view of BlockMetadataManager to Evictors, filtering out un-evictable blocks and un-allocatable space internally, so that evictors and allocators can be developed with much simpler logic, without worrying about various constraints, e.g.
BlockMetadataEvictorView(BlockMetadataManager, Set<Long>, Set<Long>) - Constructor for class alluxio.worker.block.BlockMetadataEvictorView
Creates a new instance of BlockMetadataEvictorView.
BlockMetadataManager - Class in alluxio.worker.block
Manages the metadata of all blocks in managed space.
BlockMetadataView - Class in alluxio.worker.block
This class is an abstract class for allocators and evictors to extend to provide limited access to block metadata.
BlockMetadataView(BlockMetadataManager) - Constructor for class alluxio.worker.block.BlockMetadataView
Creates a new instance of BlockMetadataView.
BlockMetricsReporter - Class in alluxio.worker.block
This class listens on block events and increases the metrics counters.
BlockMetricsReporter() - Constructor for class alluxio.worker.block.BlockMetricsReporter
Creates a new instance of BlockMetricsReporter.
BlockOutStream - Class in alluxio.client.block.stream
Provides an OutputStream implementation that is based on DataWriter which streams data chunk by chunk.
BlockOutStream(DataWriter, long, WorkerNetAddress) - Constructor for class alluxio.client.block.stream.BlockOutStream
Constructs a new BlockOutStream with only one DataWriter.
BlockOutStream(List<DataWriter>, long, List<WorkerNetAddress>) - Constructor for class alluxio.client.block.stream.BlockOutStream
Constructs a new BlockOutStream with only one DataWriter.
BlockReader - Interface in alluxio.worker.block.io
A reader interface to access the data of a block stored in managed storage.
BlockReadHandler - Class in alluxio.worker.grpc
This handler handles block read request.
BlockReadHandler(ExecutorService, BlockWorker, StreamObserver<ReadResponse>, AuthenticatedUserInfo, boolean) - Constructor for class alluxio.worker.grpc.BlockReadHandler
Creates an instance of AbstractReadHandler.
BlockReadHandler.BlockDataReader - Class in alluxio.worker.grpc
The data reader to read from a local block worker.
BlockReadRequest - Class in alluxio.worker.grpc
The internal representation of a block read request.
BlockReadRequestContext - Class in alluxio.worker.grpc
Context of BlockReadRequest.
BlockReadRequestContext(ReadRequest) - Constructor for class alluxio.worker.grpc.BlockReadRequestContext
 
blockReinit() - Method in class alluxio.client.file.FileSystemContext
Acquires the resource to block reinitialization.
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
 
BlockStore - Interface in alluxio.master.metastore
The block store keeps track of block sizes and block locations.
BlockStore - Interface in alluxio.worker.block
A blob store interface to represent the local storage managing and serving all the blocks in the local storage.
BlockStore.Block - Class in alluxio.master.metastore
Block metadata.
BlockStore.Factory - Interface in alluxio.master.metastore
Factory for creating block stores.
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.
BlockStoreMeta.Factory - Class in alluxio.worker.block
Factory for BlockStoreMeta.
BlockTransferInfo - Class in alluxio.worker.block.evictor
Provides information about the transfer of a block.
BlockTransferInfo(long, BlockStoreLocation, BlockStoreLocation) - Constructor for class alluxio.worker.block.evictor.BlockTransferInfo
Creates a new instance of BlockTransferInfo.
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.
BlockWorkerFactory - Class in alluxio.worker.block
Factory to create a BlockWorker instance.
BlockWorkerFactory() - Constructor for class alluxio.worker.block.BlockWorkerFactory
Constructs a new BlockWorkerFactory.
BlockWorkerGrpc - Class in alluxio.grpc
The block worker service
BlockWorkerGrpc.BlockWorkerBlockingStub - Class in alluxio.grpc
The block worker service
BlockWorkerGrpc.BlockWorkerFutureStub - Class in alluxio.grpc
The block worker service
BlockWorkerGrpc.BlockWorkerImplBase - Class in alluxio.grpc
The block worker service
BlockWorkerGrpc.BlockWorkerStub - Class in alluxio.grpc
The block worker service
BlockWorkerImpl - Class in alluxio.worker.grpc
Server side implementation of the gRPC BlockWorker interface.
BlockWorkerImpl(WorkerProcess, FileSystemContext, boolean) - Constructor for class alluxio.worker.grpc.BlockWorkerImpl
Creates a new implementation of gRPC BlockWorker interface.
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.
BlockWorkerProto - Class in alluxio.grpc
 
BlockWriteHandler - Class in alluxio.worker.grpc
This handler handles block write request.
BlockWriter - Interface in alluxio.worker.block.io
A writer interface to write or update a block stored in managed storage.
BlockWriteRequest - Class in alluxio.worker.grpc
The block write request internal representation.
BlockWriteRequestContext - Class in alluxio.worker.grpc
The block write request internal representation.
BOOLEAN - Static variable in class alluxio.job.plan.transform.HiveConstants.Types
Hive bool type.
BOOLEAN_STATS_FIELD_NUMBER - Static variable in class alluxio.grpc.table.ColumnStatisticsData
 
BOOLEAN_TYPE_FIELD_NUMBER - Static variable in class alluxio.grpc.table.Value
 
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.
BoundedStream - Interface in alluxio.client
This interface should be implemented by all Alluxio streams which are bounded at a certain byte size.
BUCKET_ALREADY_EXISTS - Static variable in class alluxio.proxy.s3.S3ErrorCode
 
BUCKET_ALREADY_EXISTS - Static variable in class alluxio.proxy.s3.S3ErrorCode.Name
 
BUCKET_COUNT_FIELD_NUMBER - Static variable in class alluxio.grpc.table.layout.hive.HiveBucketProperty
 
BUCKET_NOT_EMPTY - Static variable in class alluxio.proxy.s3.S3ErrorCode
 
BUCKET_NOT_EMPTY - Static variable in class alluxio.proxy.s3.S3ErrorCode.Name
 
BUCKET_PARAM - Static variable in class alluxio.proxy.s3.S3RestServiceHandler
 
BUCKET_PROPERTY_FIELD_NUMBER - Static variable in class alluxio.grpc.table.layout.hive.Storage
 
BUCKET_SEPARATOR - Static variable in class alluxio.proxy.s3.S3RestServiceHandler
Bucket must be a directory directly under a mount point.
BUCKETED_BY_FIELD_NUMBER - Static variable in class alluxio.grpc.table.layout.hive.HiveBucketProperty
 
BUFFER_SIZE_OPTION - Static variable in class alluxio.cli.fs.command.CpCommand
 
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.conf.PropertyKey.Builder
Creates and registers the property key.
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.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.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.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.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.Command.Builder
 
build() - Method in class alluxio.grpc.CommitBlockInUfsPOptions.Builder
 
build() - Method in class alluxio.grpc.CommitBlockInUfsPRequest.Builder
 
build() - Method in class alluxio.grpc.CommitBlockInUfsPResponse.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.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.CreateLocalBlockRequest.Builder
 
build() - Method in class alluxio.grpc.CreateLocalBlockResponse.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.ExistsPOptions.Builder
 
build() - Method in class alluxio.grpc.FileBlockInfo.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.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.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.GetJobServiceSummaryPOptions.Builder
 
build() - Method in class alluxio.grpc.GetJobServiceSummaryPRequest.Builder
 
build() - Method in class alluxio.grpc.GetJobServiceSummaryPResponse.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.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.GetPinnedFileIdsPOptions.Builder
 
build() - Method in class alluxio.grpc.GetPinnedFileIdsPRequest.Builder
 
build() - Method in class alluxio.grpc.GetPinnedFileIdsPResponse.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.GetServiceVersionPRequest.Builder
 
build() - Method in class alluxio.grpc.GetServiceVersionPResponse.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.GetSyncPathListPRequest.Builder
 
build() - Method in class alluxio.grpc.GetSyncPathListPResponse.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() - 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.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(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.JobServiceSummary.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.ListAllPOptions.Builder
 
build() - Method in class alluxio.grpc.ListAllPRequest.Builder
 
build() - Method in class alluxio.grpc.ListAllPResponse.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.LoadMetadataPOptions.Builder
 
build() - Method in class alluxio.grpc.LocalityTier.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.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() - 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.NetAddress.Builder
 
build() - Method in class alluxio.grpc.OpenFilePOptions.Builder
 
build() - Method in class alluxio.grpc.OpenLocalBlockRequest.Builder
 
build() - Method in class alluxio.grpc.OpenLocalBlockResponse.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.QuorumServerInfo.Builder
 
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.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.RemovePathConfigurationPOptions.Builder
 
build() - Method in class alluxio.grpc.RemovePathConfigurationPRequest.Builder
 
build() - Method in class alluxio.grpc.RemovePathConfigurationPResponse.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.ReverseResolvePRequest.Builder
 
build() - Method in class alluxio.grpc.ReverseResolvePResponse.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(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.StartSyncPOptions.Builder
 
build() - Method in class alluxio.grpc.StartSyncPRequest.Builder
 
build() - Method in class alluxio.grpc.StartSyncPResponse.Builder
 
build() - Method in class alluxio.grpc.StatusSummary.Builder
 
build() - Method in class alluxio.grpc.StopSyncPOptions.Builder
 
build() - Method in class alluxio.grpc.StopSyncPRequest.Builder
 
build() - Method in class alluxio.grpc.StopSyncPResponse.Builder
 
build() - Method in class alluxio.grpc.StorageList.Builder
 
build() - Method in class alluxio.grpc.SyncPointInfo.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.TieredIdentity.Builder
 
build() - Method in class alluxio.grpc.TierList.Builder
 
build() - Method in class alluxio.grpc.TransportMessage.Builder
 
build() - Method in class alluxio.grpc.UfsInfo.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.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.WorkerInfo.Builder
 
build() - Method in class alluxio.grpc.WorkerLostStorageInfo.Builder
 
build() - Method in class alluxio.grpc.WorkerNetAddress.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.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.CreateUfsBlockOptions.Builder
 
build() - Method in class alluxio.proto.dataserver.Protocol.CreateUfsFileOptions.Builder
 
build() - Method in class alluxio.proto.dataserver.Protocol.OpenUfsBlockOptions.Builder
 
build() - Method in class alluxio.proto.dataserver.Protocol.Response.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.Journal.JournalEntry.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.Table.AddTableEntry.Builder
 
build() - Method in class alluxio.proto.journal.Table.AddTransformJobInfoEntry.Builder
 
build() - Method in class alluxio.proto.journal.Table.AttachDbEntry.Builder
 
build() - Method in class alluxio.proto.journal.Table.CompleteTransformTableEntry.Builder
 
build() - Method in class alluxio.proto.journal.Table.DetachDbEntry.Builder
 
build() - Method in class alluxio.proto.journal.Table.RemoveTableEntry.Builder
 
build() - Method in class alluxio.proto.journal.Table.RemoveTransformJobInfoEntry.Builder
 
build() - Method in class alluxio.proto.journal.Table.UpdateDatabaseInfoEntry.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.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.
Builder(String) - Constructor for class alluxio.conf.PropertyKey.Builder
 
Builder(PropertyKey.Template, Object...) - Constructor for class alluxio.conf.PropertyKey.Builder
 
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
 
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.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.BlockStoreLocationProto.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.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.Command.Builder
 
buildPartial() - Method in class alluxio.grpc.CommitBlockInUfsPOptions.Builder
 
buildPartial() - Method in class alluxio.grpc.CommitBlockInUfsPRequest.Builder
 
buildPartial() - Method in class alluxio.grpc.CommitBlockInUfsPResponse.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.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.CreateLocalBlockRequest.Builder
 
buildPartial() - Method in class alluxio.grpc.CreateLocalBlockResponse.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.ExistsPOptions.Builder
 
buildPartial() - Method in class alluxio.grpc.FileBlockInfo.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.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.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.GetJobServiceSummaryPOptions.Builder
 
buildPartial() - Method in class alluxio.grpc.GetJobServiceSummaryPRequest.Builder
 
buildPartial() - Method in class alluxio.grpc.GetJobServiceSummaryPResponse.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.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.GetPinnedFileIdsPOptions.Builder
 
buildPartial() - Method in class alluxio.grpc.GetPinnedFileIdsPRequest.Builder
 
buildPartial() - Method in class alluxio.grpc.GetPinnedFileIdsPResponse.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.GetServiceVersionPRequest.Builder
 
buildPartial() - Method in class alluxio.grpc.GetServiceVersionPResponse.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.GetSyncPathListPRequest.Builder
 
buildPartial() - Method in class alluxio.grpc.GetSyncPathListPResponse.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.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.JobServiceSummary.Builder
 
buildPartial() - Method in class alluxio.grpc.JobUnused.Builder
 
buildPartial() - Method in class alluxio.grpc.JobWorkerHealth.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.ListStatusPOptions.Builder
 
buildPartial() - Method in class alluxio.grpc.ListStatusPRequest.Builder
 
buildPartial() - Method in class alluxio.grpc.ListStatusPResponse.Builder
 
buildPartial() - Method in class alluxio.grpc.LoadMetadataPOptions.Builder
 
buildPartial() - Method in class alluxio.grpc.LocalityTier.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.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.NetAddress.Builder
 
buildPartial() - Method in class alluxio.grpc.OpenFilePOptions.Builder
 
buildPartial() - Method in class alluxio.grpc.OpenLocalBlockRequest.Builder
 
buildPartial() - Method in class alluxio.grpc.OpenLocalBlockResponse.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.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.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.RemovePathConfigurationPOptions.Builder
 
buildPartial() - Method in class alluxio.grpc.RemovePathConfigurationPRequest.Builder
 
buildPartial() - Method in class alluxio.grpc.RemovePathConfigurationPResponse.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.ReverseResolvePRequest.Builder
 
buildPartial() - Method in class alluxio.grpc.ReverseResolvePResponse.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.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.StartSyncPOptions.Builder
 
buildPartial() - Method in class alluxio.grpc.StartSyncPRequest.Builder
 
buildPartial() - Method in class alluxio.grpc.StartSyncPResponse.Builder
 
buildPartial() - Method in class alluxio.grpc.StatusSummary.Builder
 
buildPartial() - Method in class alluxio.grpc.StopSyncPOptions.Builder
 
buildPartial() - Method in class alluxio.grpc.StopSyncPRequest.Builder
 
buildPartial() - Method in class alluxio.grpc.StopSyncPResponse.Builder
 
buildPartial() - Method in class alluxio.grpc.StorageList.Builder
 
buildPartial() - Method in class alluxio.grpc.SyncPointInfo.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.TieredIdentity.Builder
 
buildPartial() - Method in class alluxio.grpc.TierList.Builder
 
buildPartial() - Method in class alluxio.grpc.TransportMessage.Builder
 
buildPartial() - Method in class alluxio.grpc.UfsInfo.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.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.WorkerInfo.Builder
 
buildPartial() - Method in class alluxio.grpc.WorkerLostStorageInfo.Builder
 
buildPartial() - Method in class alluxio.grpc.WorkerNetAddress.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.CreateUfsBlockOptions.Builder
 
buildPartial() - Method in class alluxio.proto.dataserver.Protocol.CreateUfsFileOptions.Builder
 
buildPartial() - Method in class alluxio.proto.dataserver.Protocol.OpenUfsBlockOptions.Builder
 
buildPartial() - Method in class alluxio.proto.dataserver.Protocol.Response.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.Journal.JournalEntry.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.Table.AddTableEntry.Builder
 
buildPartial() - Method in class alluxio.proto.journal.Table.AddTransformJobInfoEntry.Builder
 
buildPartial() - Method in class alluxio.proto.journal.Table.AttachDbEntry.Builder
 
buildPartial() - Method in class alluxio.proto.journal.Table.CompleteTransformTableEntry.Builder
 
buildPartial() - Method in class alluxio.proto.journal.Table.DetachDbEntry.Builder
 
buildPartial() - Method in class alluxio.proto.journal.Table.RemoveTableEntry.Builder
 
buildPartial() - Method in class alluxio.proto.journal.Table.RemoveTransformJobInfoEntry.Builder
 
buildPartial() - Method in class alluxio.proto.journal.Table.UpdateDatabaseInfoEntry.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.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.
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.
byteBufferToString(ByteBuffer) - Static method in class alluxio.util.FormatUtils
Parses a ByteBuffer into a String.
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.DefaultMetaStore
 
bytes() - Method in interface alluxio.client.file.cache.MetaStore
 
BYTES_FIELD_NUMBER - Static variable in class alluxio.grpc.GetCapacityBytesPResponse
 
BYTES_FIELD_NUMBER - Static variable in class alluxio.grpc.GetUsedBytesPResponse
 
BYTES_IN_BLOCK_STORE_FIELD_NUMBER - Static variable in class alluxio.proto.dataserver.Protocol.CreateUfsBlockOptions
 
BYTES_IN_INTEGER - Static variable in class alluxio.Constants
 
BytesCommitter - Class in alluxio.job.plan.transform.format.tables
Determines whether to commit a table file based on the size of the file in bytes.
BytesCommitter(long) - Constructor for class alluxio.job.plan.transform.format.tables.BytesCommitter
 
byteToInt(byte) - Static method in class alluxio.util.io.BufferUtils
Converts a byte to an integer.

C

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) - Constructor for class alluxio.master.metastore.caching.Cache
 
Cache - Class in alluxio.proto.client
 
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_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_VALUE - Static variable in enum alluxio.grpc.ReadPType
CACHE = 2;
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.
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
Interface for client-side cache eviction policy.
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.
CACHESIZE_FIELD_NUMBER - Static variable in class alluxio.proto.client.Cache.PPageStoreCommonOptions
 
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
 
call() - Method in interface alluxio.AbstractClient.RpcCallable
The task where RPC happens.
call() - Method in class alluxio.examples.BasicCheckpoint
 
call() - Method in class alluxio.examples.BasicNonByteBufferOperations
 
call() - Method in class alluxio.examples.BasicOperations
 
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.RpcCallableThrowsIOException
The RPC implementation.
call() - Method in interface alluxio.RpcUtils.StreamingRpcCallable
The RPC implementation.
call() - Method in class alluxio.underfs.ObjectUnderFileSystem.OperationBuffer.OperationThread
 
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.
cancel() - Method in class alluxio.client.block.stream.BlockOutStream
 
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.LocalFileDataWriter
 
cancel() - Method in class alluxio.client.block.stream.UfsFallbackLocalFileDataWriter
 
cancel() - Method in interface alluxio.client.Cancelable
Cancels an operation.
cancel() - Method in class alluxio.client.file.AlluxioFileOutStream
 
cancel() - Method in class alluxio.client.file.FileOutStream
Aborts the output stream.
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) - 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.JobMasterClientServiceImplBase
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.
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.
CancelCommand - Class in alluxio.cli.job.command
Cancels a job asynchronously.
CancelCommand(FileSystemContext) - Constructor for class alluxio.cli.job.command.CancelCommand
creates the cancel command.
CANCELED_VALUE - Static variable in enum alluxio.grpc.Status
CANCELED = 2;
CANCELED_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
 
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(BlockWriteRequestContext) - Method in class alluxio.worker.grpc.BlockWriteHandler
 
cancelRequest(BlockWriteRequestContext) - Method in class alluxio.worker.grpc.UfsFallbackBlockWriteHandler
 
cancelRequest(UfsFileWriteRequestContext) - Method in class alluxio.worker.grpc.UfsFileWriteHandler
 
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
 
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
 
CapacityCommand - Class in alluxio.cli.fsadmin.report
Prints Alluxio capacity information.
CapacityCommand(BlockMasterClient, PrintStream) - Constructor for class alluxio.cli.fsadmin.report.CapacityCommand
Creates a new instance of CapacityCommand.
cascadingEvict(long, BlockStoreLocation, EvictionPlan, Evictor.Mode) - Method in class alluxio.worker.block.evictor.AbstractEvictor
A recursive implementation of cascading eviction.
castToIOException(Throwable) - Static method in class alluxio.util.CommonUtils
Casts a Throwable to an IOException.
CatalogConfiguration - Class in alluxio.master.table
This represents a configuration of the catalog.
CatalogContext - Class in alluxio.master.table
The context for the catalog.
CatalogContext(UnderDatabaseRegistry, LayoutRegistry) - Constructor for class alluxio.master.table.CatalogContext
Creates an instance.
CatalogPathUtils - Class in alluxio.table.common
A collection of utility methods for catalog paths.
CatalogProperty - Class in alluxio.master.table
This represents a property name and default value for the catalog.
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
 
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.
ChannelAuthenticationScheme - Enum in alluxio.grpc
Protobuf enum alluxio.grpc.sasl.ChannelAuthenticationScheme
ChannelAuthenticator - Class in alluxio.security.authentication
Used to authenticate with the target host.
ChannelAuthenticator(GrpcConnection, Subject, AuthType, AlluxioConfiguration) - Constructor for class alluxio.security.authentication.ChannelAuthenticator
Creates ChannelAuthenticator instance.
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.
CHANNELREF_FIELD_NUMBER - Static variable in class alluxio.grpc.SaslMessage
 
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.
CHAR - Static variable in class alluxio.job.plan.transform.HiveConstants.Types
Hive char type.
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.
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) - 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.FileSystemMasterClientServiceImplBase
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
 
CheckConsistencyCommand - Class in alluxio.cli.fs.command
Command for checking the consistency of a file or folder between Alluxio and the under storage.
CheckConsistencyCommand(FileSystemContext) - Constructor for class alluxio.cli.fs.command.CheckConsistencyCommand
 
CheckConsistencyContext - Class in alluxio.master.file.contexts
Used to merge and wrap CheckConsistencyPOptions.
checkConsistencyDefaults(AlluxioConfiguration) - Static method in class alluxio.util.FileSystemOptions
 
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
 
checkDirectory(InodeDirectory, AlluxioURI) - Method in class alluxio.master.file.UfsSyncChecker
Check if immediate children of directory are in sync with UFS.
CheckerMapper() - Constructor for class alluxio.checker.MapReduceIntegrationChecker.CheckerMapper
 
CheckerReducer() - Constructor for class alluxio.checker.MapReduceIntegrationChecker.CheckerReducer
 
CheckerUtils - Class in alluxio.checker
Class for common methods used by integration checkers.
CheckerUtils.Status - Enum in alluxio.checker
The performIntegrationChecks results.
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.
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.
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.
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) - 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.MetaMasterClientServiceImplBase
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() - Method in interface alluxio.master.journal.JournalSystem
Creates a checkpoint in the primary master journal system.
checkpoint() - Method in class alluxio.master.journal.noop.NoopJournalSystem
 
checkpoint() - 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() - 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
 
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.
checkStorage() - Method in interface alluxio.worker.block.BlockStore
Checks storage health.
checkStorage() - Method in class alluxio.worker.block.TieredBlockStore
 
ChecksumCommand - Class in alluxio.cli.fs.command
Calculates the MD5 checksum for a file.
ChecksumCommand(FileSystemContext) - Constructor for class alluxio.cli.fs.command.ChecksumCommand
 
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.
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.
checkUri(AlluxioURI) - Method in class alluxio.client.file.BaseFileSystem
Checks an AlluxioURI for scheme and authority information.
checkUri(AlluxioURI) - Static method in class alluxio.job.plan.transform.format.ReadWriterUtils
Checks preconditions of uri.
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.AlluxioFuseFileSystem
Changes the mode of an Alluxio file.
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.
chown(String, long, long) - Method in class alluxio.fuse.AlluxioFuseFileSystem
Changes the user and group ownership of an Alluxio file.
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.WriteRequest
 
CHUNK_SIZE_FIELD_NUMBER - Static variable in class alluxio.grpc.ReadRequest
 
ChunkOrBuilder - Interface in alluxio.grpc
 
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.LocalFileDataWriter
 
chunkSize() - Method in class alluxio.client.block.stream.UfsFallbackLocalFileDataWriter
 
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.underfs.hdfs.HdfsUnderFileSystem
 
cleanup() - Method in class alluxio.underfs.local.LocalUnderFileSystem
 
cleanup() - Method in class alluxio.underfs.ObjectUnderFileSystem
 
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
 
cleanup() - Method in class alluxio.underfs.web.WebUnderFileSystem
 
CLEANUP_ON_FAILURE_FIELD_NUMBER - Static variable in class alluxio.grpc.CreateLocalBlockRequest
 
cleanupRequest(BlockWriteRequestContext) - Method in class alluxio.worker.grpc.BlockWriteHandler
 
cleanupRequest(BlockWriteRequestContext) - Method in class alluxio.worker.grpc.UfsFallbackBlockWriteHandler
 
cleanupRequest(UfsFileWriteRequestContext) - Method in class alluxio.worker.grpc.UfsFileWriteHandler
 
cleanupSession(long) - Method in class alluxio.worker.block.BlockLockManager
Cleans up the locks currently hold by a specific session.
cleanupSession(long) - Method in interface alluxio.worker.block.BlockStore
Cleans up the data associated with a specific session (typically a dead session).
cleanupSession(long) - Method in class alluxio.worker.block.DefaultBlockWorker
 
cleanupSession(long) - Method in class alluxio.worker.block.TieredBlockStore
 
cleanupSession(long) - Method in class alluxio.worker.block.UnderFileSystemBlockStore
Cleans up all the block information(e.g.
cleanupSession(long) - Method in interface alluxio.worker.SessionCleanable
Cleans up the session.
cleanupSessionTempBlocks(long, List<Long>) - Method in class alluxio.worker.block.BlockMetadataManager
Deprecated.
As of version 0.8.
cleanupSessionTempBlocks(long, List<Long>) - Method in class alluxio.worker.block.meta.StorageDir
Cleans up the temp block metadata for each block id passed in.
cleanupUfs() - Method in class alluxio.master.file.DefaultFileSystemMaster
 
cleanupUfs() - Method in interface alluxio.master.file.FileSystemMaster
Periodically clean up the under file systems.
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.conf.AlluxioProperties
Clears all existing user-specified properties.
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.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.BlockStoreLocationProto.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.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.Command.Builder
 
clear() - Method in class alluxio.grpc.CommitBlockInUfsPOptions.Builder
 
clear() - Method in class alluxio.grpc.CommitBlockInUfsPRequest.Builder
 
clear() - Method in class alluxio.grpc.CommitBlockInUfsPResponse.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.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.CreateLocalBlockRequest.Builder
 
clear() - Method in class alluxio.grpc.CreateLocalBlockResponse.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.ExistsPOptions.Builder
 
clear() - Method in class alluxio.grpc.FileBlockInfo.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.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.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.GetJobServiceSummaryPOptions.Builder
 
clear() - Method in class alluxio.grpc.GetJobServiceSummaryPRequest.Builder
 
clear() - Method in class alluxio.grpc.GetJobServiceSummaryPResponse.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.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.GetPinnedFileIdsPOptions.Builder
 
clear() - Method in class alluxio.grpc.GetPinnedFileIdsPRequest.Builder
 
clear() - Method in class alluxio.grpc.GetPinnedFileIdsPResponse.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.GetServiceVersionPRequest.Builder
 
clear() - Method in class alluxio.grpc.GetServiceVersionPResponse.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.GetSyncPathListPRequest.Builder
 
clear() - Method in class alluxio.grpc.GetSyncPathListPResponse.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.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.JobServiceSummary.Builder
 
clear() - Method in class alluxio.grpc.JobUnused.Builder
 
clear() - Method in class alluxio.grpc.JobWorkerHealth.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.ListStatusPOptions.Builder
 
clear() - Method in class alluxio.grpc.ListStatusPRequest.Builder
 
clear() - Method in class alluxio.grpc.ListStatusPResponse.Builder
 
clear() - Method in class alluxio.grpc.LoadMetadataPOptions.Builder
 
clear() - Method in class alluxio.grpc.LocalityTier.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.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.NetAddress.Builder
 
clear() - Method in class alluxio.grpc.OpenFilePOptions.Builder
 
clear() - Method in class alluxio.grpc.OpenLocalBlockRequest.Builder
 
clear() - Method in class alluxio.grpc.OpenLocalBlockResponse.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.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.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.RemovePathConfigurationPOptions.Builder
 
clear() - Method in class alluxio.grpc.RemovePathConfigurationPRequest.Builder
 
clear() - Method in class alluxio.grpc.RemovePathConfigurationPResponse.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.ReverseResolvePRequest.Builder
 
clear() - Method in class alluxio.grpc.ReverseResolvePResponse.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.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.StartSyncPOptions.Builder
 
clear() - Method in class alluxio.grpc.StartSyncPRequest.Builder
 
clear() - Method in class alluxio.grpc.StartSyncPResponse.Builder
 
clear() - Method in class alluxio.grpc.StatusSummary.Builder
 
clear() - Method in class alluxio.grpc.StopSyncPOptions.Builder
 
clear() - Method in class alluxio.grpc.StopSyncPRequest.Builder
 
clear() - Method in class alluxio.grpc.StopSyncPResponse.Builder
 
clear() - Method in class alluxio.grpc.StorageList.Builder
 
clear() - Method in class alluxio.grpc.SyncPointInfo.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.TieredIdentity.Builder
 
clear() - Method in class alluxio.grpc.TierList.Builder
 
clear() - Method in class alluxio.grpc.TransportMessage.Builder
 
clear() - Method in class alluxio.grpc.UfsInfo.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.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.WorkerInfo.Builder
 
clear() - Method in class alluxio.grpc.WorkerLostStorageInfo.Builder
 
clear() - Method in class alluxio.grpc.WorkerNetAddress.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 interface alluxio.master.metastore.BlockStore
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.HeapBlockStore
 
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.RocksBlockStore
 
clear() - Method in class alluxio.master.metastore.rocks.RocksInodeStore
 
clear() - Method in class alluxio.master.metastore.rocks.RocksStore
Clears and re-initializes the database.
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.CreateUfsBlockOptions.Builder
 
clear() - Method in class alluxio.proto.dataserver.Protocol.CreateUfsFileOptions.Builder
 
clear() - Method in class alluxio.proto.dataserver.Protocol.OpenUfsBlockOptions.Builder
 
clear() - Method in class alluxio.proto.dataserver.Protocol.Response.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.Journal.JournalEntry.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.Table.AddTableEntry.Builder
 
clear() - Method in class alluxio.proto.journal.Table.AddTransformJobInfoEntry.Builder
 
clear() - Method in class alluxio.proto.journal.Table.AttachDbEntry.Builder
 
clear() - Method in class alluxio.proto.journal.Table.CompleteTransformTableEntry.Builder
 
clear() - Method in class alluxio.proto.journal.Table.DetachDbEntry.Builder
 
clear() - Method in class alluxio.proto.journal.Table.RemoveTableEntry.Builder
 
clear() - Method in class alluxio.proto.journal.Table.RemoveTransformJobInfoEntry.Builder
 
clear() - Method in class alluxio.proto.journal.Table.UpdateDatabaseInfoEntry.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.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
 
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;
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;
clearActiveSyncTxId() - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
optional .alluxio.proto.journal.ActiveSyncTxIdEntry active_sync_tx_id = 34;
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;
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
clearAddSyncPoint() - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
optional .alluxio.proto.journal.AddSyncPointEntry add_sync_point = 32;
clearAddTable() - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
optional .alluxio.proto.journal.AddTableEntry add_table = 43;
clearAddTransformJobInfo() - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
optional .alluxio.proto.journal.AddTransformJobInfoEntry add_transform_job_info = 46;
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
optional .alluxio.grpc.table.AllOrNoneSet all_or_none = 3;
clearAllowExists() - Method in class alluxio.grpc.CreateDirectoryPOptions.Builder
optional bool allowExists = 2;
clearAllowLeader() - Method in class alluxio.grpc.BackupPOptions.Builder
optional bool allowLeader = 3;
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.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;
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;
clearAttachDb() - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
optional .alluxio.proto.journal.AttachDbEntry attach_db = 44;
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;
clearBaseLayout() - Method in class alluxio.grpc.table.Partition.Builder
optional .alluxio.grpc.table.Layout base_layout = 2;
clearBinaryStats() - Method in class alluxio.grpc.table.ColumnStatisticsData.Builder
optional .alluxio.grpc.table.BinaryColumnStatsData binary_stats = 5;
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;
clearBlockContainerIdGenerator() - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
optional .alluxio.proto.journal.BlockContainerIdGeneratorEntry block_container_id_generator = 3;
clearBlockId() - Method in class alluxio.grpc.AsyncCacheRequest.Builder
optional 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.CommitBlockInUfsPRequest.Builder
the id of the worker
clearBlockId() - Method in class alluxio.grpc.CommitBlockPRequest.Builder
the id of the block being committed
clearBlockId() - Method in class alluxio.grpc.CreateLocalBlockRequest.Builder
optional int64 block_id = 1;
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.OpenLocalBlockRequest.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.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;
clearBlockInUfsTier() - Method in class alluxio.proto.dataserver.Protocol.OpenUfsBlockOptions.Builder
If set to true, the block is possibly stored as a UFS block.
clearBlockMarks() - Method in class alluxio.worker.block.BlockMetadataEvictorView
Clears all marks of blocks to move in/out in all dir views.
clearBlockMarks() - Method in class alluxio.worker.block.meta.StorageDirEvictorView
Clears all marks about blocks to move in/out in this view.
clearBlockMasterInfo() - Method in class alluxio.grpc.GetBlockMasterInfoPResponse.Builder
optional .alluxio.grpc.block.BlockMasterInfo blockMasterInfo = 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.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
clearBooleanStats() - Method in class alluxio.grpc.table.ColumnStatisticsData.Builder
optional .alluxio.grpc.table.BooleanColumnStatsData boolean_stats = 1;
clearBooleanType() - Method in class alluxio.grpc.table.Value.Builder
optional 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;
clearBytes() - Method in class alluxio.grpc.GetCapacityBytesPResponse.Builder
optional int64 bytes = 1;
clearBytes() - Method in class alluxio.grpc.GetUsedBytesPResponse.Builder
optional int64 bytes = 1;
clearBytesInBlockStore() - Method in class alluxio.proto.dataserver.Protocol.CreateUfsBlockOptions.Builder
the number of bytes previously written to block store zero if no previous temp block created
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;
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;
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;
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.WriteRequest.Builder
optional .alluxio.grpc.block.Chunk chunk = 2;
clearChunkSize() - Method in class alluxio.grpc.ReadRequest.Builder
optional int64 chunk_size = 5;
clearCleanupOnFailure() - Method in class alluxio.grpc.CreateLocalBlockRequest.Builder
optional bool cleanup_on_failure = 6;
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;
clearClusterConfigs() - Method in class alluxio.grpc.GetConfigurationPResponse.Builder
repeated .alluxio.grpc.ConfigProperty clusterConfigs = 1;
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;
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.MasterHeartbeatPResponse.Builder
optional .alluxio.grpc.meta.MetaCommand command = 1;
clearCommand() - Method in class alluxio.grpc.WriteRequest.Builder
optional .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;
clearComment() - Method in class alluxio.proto.journal.Table.UpdateDatabaseInfoEntry.Builder
optional string comment = 6;
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.StartSyncPOptions.Builder
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 1;
clearCommonOptions() - Method in class alluxio.grpc.StopSyncPOptions.Builder
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 1;
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;
clearCompleteTransformTable() - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
optional .alluxio.proto.journal.CompleteTransformTableEntry complete_transform_table = 48;
clearConfig() - Method in class alluxio.proto.journal.Table.AttachDbEntry.Builder
 
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;
clearContainerId() - Method in class alluxio.proto.journal.File.InodeDirectoryIdGeneratorEntry.Builder
optional int64 container_id = 1;
clearCount() - Method in class alluxio.grpc.StatusSummary.Builder
optional int64 count = 2;
clearCreateAncestors() - Method in class alluxio.grpc.LoadMetadataPOptions.Builder
optional bool createAncestors = 2;
clearCreateUfsBlockOptions() - Method in class alluxio.grpc.WriteRequestCommand.Builder
optional .alluxio.proto.dataserver.CreateUfsBlockOptions create_ufs_block_options = 7;
clearCreateUfsFileOptions() - Method in class alluxio.grpc.WriteRequestCommand.Builder
Cancel, close and error will be handled by standard gRPC stream APIs.
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.table.ColumnStatisticsData.Builder
 
clearData() - Method in class alluxio.grpc.table.ColumnStatisticsInfo.Builder
optional .alluxio.grpc.table.ColumnStatisticsData data = 3;
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
optional .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;
clearDbName() - Method in class alluxio.proto.journal.Table.AddTableEntry.Builder
optional string db_name = 1;
clearDbName() - Method in class alluxio.proto.journal.Table.AddTransformJobInfoEntry.Builder
optional string db_name = 1;
clearDbName() - Method in class alluxio.proto.journal.Table.AttachDbEntry.Builder
optional string db_name = 4;
clearDbName() - Method in class alluxio.proto.journal.Table.CompleteTransformTableEntry.Builder
optional string db_name = 1;
clearDbName() - Method in class alluxio.proto.journal.Table.DetachDbEntry.Builder
optional string db_name = 1;
clearDbName() - Method in class alluxio.proto.journal.Table.RemoveTableEntry.Builder
optional string db_name = 1;
clearDbName() - Method in class alluxio.proto.journal.Table.RemoveTransformJobInfoEntry.Builder
optional string db_name = 1;
clearDbName() - Method in class alluxio.proto.journal.Table.UpdateDatabaseInfoEntry.Builder
optional string db_name = 1;
clearDecimalStats() - Method in class alluxio.grpc.table.ColumnStatisticsData.Builder
optional .alluxio.grpc.table.DecimalColumnStatsData decimal_stats = 6;
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;
clearDefinition() - Method in class alluxio.proto.journal.Table.AddTransformJobInfoEntry.Builder
optional string definition = 3;
clearDefinition() - Method in class alluxio.proto.journal.Table.CompleteTransformTableEntry.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.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;
clearDetachDb() - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
optional .alluxio.proto.journal.DetachDbEntry detach_db = 45;
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;
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
optional .alluxio.grpc.table.DoubleColumnStatsData double_stats = 3;
clearDoubleType() - Method in class alluxio.grpc.table.Value.Builder
optional double double_type = 2;
clearDoubleValue() - Method in class alluxio.grpc.MetricValue.Builder
optional double doubleValue = 1;
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
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;
clearEquatable() - Method in class alluxio.grpc.table.Domain.Builder
optional .alluxio.grpc.table.EquatableValueSet equatable = 2;
clearErrorMessage() - Method in class alluxio.grpc.JobInfo.Builder
optional string errorMessage = 2;
clearErrors() - Method in class alluxio.grpc.ConfigCheckReport.Builder
 
clearFallback() - Method in class alluxio.proto.dataserver.Protocol.CreateUfsBlockOptions.Builder
true if the write request is already a fallback from a failed short-circuit write.
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.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.BlockStoreLocationProto.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.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.Command.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.CommitBlockInUfsPOptions.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.CommitBlockInUfsPRequest.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.CommitBlockInUfsPResponse.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.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.CreateLocalBlockRequest.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.CreateLocalBlockResponse.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.ExistsPOptions.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.FileBlockInfo.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.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.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.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.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.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.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.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.GetServiceVersionPRequest.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.GetServiceVersionPResponse.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.GetSyncPathListPRequest.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.GetSyncPathListPResponse.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.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.JobServiceSummary.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.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.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.LoadMetadataPOptions.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.LocalityTier.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.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.NetAddress.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.OpenFilePOptions.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.OpenLocalBlockRequest.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.OpenLocalBlockResponse.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.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.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.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.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.ReverseResolvePRequest.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.ReverseResolvePResponse.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.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.StartSyncPOptions.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.StartSyncPRequest.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.StartSyncPResponse.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.StatusSummary.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.StopSyncPOptions.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.StopSyncPRequest.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.StopSyncPResponse.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.StorageList.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.SyncPointInfo.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.TieredIdentity.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.TierList.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.TransportMessage.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.UfsInfo.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.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.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.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.CreateUfsBlockOptions.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class alluxio.proto.dataserver.Protocol.CreateUfsFileOptions.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class alluxio.proto.dataserver.Protocol.OpenUfsBlockOptions.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class alluxio.proto.dataserver.Protocol.Response.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.Journal.JournalEntry.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.Table.AddTableEntry.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class alluxio.proto.journal.Table.AddTransformJobInfoEntry.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class alluxio.proto.journal.Table.AttachDbEntry.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class alluxio.proto.journal.Table.CompleteTransformTableEntry.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class alluxio.proto.journal.Table.DetachDbEntry.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class alluxio.proto.journal.Table.RemoveTableEntry.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class alluxio.proto.journal.Table.RemoveTransformJobInfoEntry.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class alluxio.proto.journal.Table.UpdateDatabaseInfoEntry.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.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;
clearFileBlockInfos() - Method in class alluxio.grpc.FileInfo.Builder
repeated .alluxio.grpc.file.FileBlockInfo fileBlockInfos = 21;
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;
clearFileInfos() - Method in class alluxio.grpc.ListStatusPResponse.Builder
repeated .alluxio.grpc.file.FileInfo fileInfos = 1;
clearFilter() - Method in class alluxio.grpc.GetMasterInfoPOptions.Builder
repeated .alluxio.grpc.meta.MasterInfoField filter = 1;
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;
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.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.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.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.meta.InodeMeta.Inode.Builder
optional int64 id = 1;
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;
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;
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;
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.proto.meta.InodeMeta.Inode.Builder
optional bool is_directory = 3;
clearIsEmpty() - Method in class alluxio.proto.shared.Acl.AccessControlList.Builder
optional bool isEmpty = 8;
clearIsMountPoint() - Method in class alluxio.proto.meta.InodeMeta.Inode.Builder
directory only
clearIsPinned() - Method in class alluxio.proto.meta.InodeMeta.Inode.Builder
optional bool is_pinned = 9;
clearIsThrowable() - Method in class alluxio.grpc.MessagingResponseHeader.Builder
optional bool isThrowable = 2;
clearJobConfig() - Method in class alluxio.grpc.RunPRequest.Builder
optional bytes jobConfig = 1;
clearJobConfig() - Method in class alluxio.grpc.RunTaskCommand.Builder
optional bytes jobConfig = 3;
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.GetJobStatusPRequest.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.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.Table.AddTransformJobInfoEntry.Builder
optional int64 job_id = 4;
clearJobIds() - Method in class alluxio.grpc.ListAllPResponse.Builder
repeated int64 jobIds = 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;
clearJobStatus() - Method in class alluxio.grpc.table.TransformJobInfo.Builder
optional .alluxio.grpc.job.Status job_status = 5;
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.
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;
clearLastContactSec() - Method in class alluxio.grpc.WorkerInfo.Builder
optional int32 lastContactSec = 3;
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;
clearLastUpdated() - Method in class alluxio.grpc.JobInfo.Builder
optional int64 lastUpdated = 6;
clearLastUpdated() - Method in class alluxio.grpc.JobWorkerHealth.Builder
optional int64 lastUpdated = 3;
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;
clearLayout() - Method in class alluxio.proto.journal.Table.AddTableEntry.Builder
optional .alluxio.grpc.table.Layout layout = 5;
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;
clearLength() - Method in class alluxio.grpc.AsyncCacheRequest.Builder
optional int64 length = 5;
clearLength() - Method in class alluxio.grpc.BlockInfo.Builder
optional int64 length = 2;
clearLength() - Method in class alluxio.grpc.CommitBlockInUfsPRequest.Builder
the space used in bytes on the target tier
clearLength() - Method in class alluxio.grpc.CommitBlockPRequest.Builder
the length of the block being committed
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.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.
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;
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;
clearLocation() - Method in class alluxio.proto.journal.Table.UpdateDatabaseInfoEntry.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
optional .alluxio.grpc.table.LongColumnStatsData long_stats = 2;
clearLongType() - Method in class alluxio.grpc.table.Value.Builder
optional int64 long_type = 1;
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.GetMasterIdPRequest.Builder
optional .alluxio.grpc.NetAddress masterAddress = 1;
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.GetMasterIdPResponse.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;
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.CreateLocalBlockRequest.Builder
optional string medium_type = 7;
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.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) - 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.BlockWorkerImplBase
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) - 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.MetricsMasterClientServiceImplBase
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.
clearMetrics() - Method in class alluxio.worker.block.DefaultBlockWorker
 
clearMetrics(ClearMetricsRequest, StreamObserver<ClearMetricsResponse>) - Method in class alluxio.worker.grpc.BlockWorkerImpl
 
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.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;
clearMountId() - Method in class alluxio.grpc.FileInfo.Builder
optional int64 mountId = 23;
clearMountId() - Method in class alluxio.grpc.GetUfsInfoPRequest.Builder
the id of the ufs
clearMountId() - Method in class alluxio.proto.dataserver.Protocol.CreateUfsBlockOptions.Builder
mount ID of the UFS to write to
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
 
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 do not have these
clearName() - Method in class alluxio.grpc.Metric.Builder
optional string name = 3;
clearName() - Method in class alluxio.grpc.table.FieldSchema.Builder
optional string name = 2;
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.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.
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.WriteRequestCommand.Builder
optional int64 offset = 3;
clearOffset() - Method in class alluxio.grpc.WriteResponse.Builder
Errors will be handled by standard gRPC stream APIs.
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.ReadRequest.Builder
Read receipt
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.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.BlockStoreLocationProto.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.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.Command.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.CommitBlockInUfsPOptions.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.CommitBlockInUfsPRequest.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.CommitBlockInUfsPResponse.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.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.CreateLocalBlockRequest.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.CreateLocalBlockResponse.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.ExistsPOptions.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.FileBlockInfo.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.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.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.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.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.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.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.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.GetServiceVersionPRequest.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.GetServiceVersionPResponse.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.GetSyncPathListPRequest.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.GetSyncPathListPResponse.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.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.JobServiceSummary.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.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.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.LoadMetadataPOptions.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.LocalityTier.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.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.NetAddress.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.OpenFilePOptions.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.OpenLocalBlockRequest.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.OpenLocalBlockResponse.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.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.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.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.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.ReverseResolvePRequest.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.ReverseResolvePResponse.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.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.StartSyncPOptions.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.StartSyncPRequest.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.StartSyncPResponse.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.StatusSummary.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.StopSyncPOptions.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.StopSyncPRequest.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.StopSyncPResponse.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.StorageList.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.SyncPointInfo.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.TieredIdentity.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.TierList.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.TransportMessage.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.UfsInfo.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.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.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.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.CreateUfsBlockOptions.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.proto.dataserver.Protocol.CreateUfsFileOptions.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.proto.dataserver.Protocol.OpenUfsBlockOptions.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.proto.dataserver.Protocol.Response.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.Journal.JournalEntry.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.Table.AddTableEntry.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.proto.journal.Table.AddTransformJobInfoEntry.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.proto.journal.Table.AttachDbEntry.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.proto.journal.Table.CompleteTransformTableEntry.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.proto.journal.Table.DetachDbEntry.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.proto.journal.Table.RemoveTableEntry.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.proto.journal.Table.RemoveTransformJobInfoEntry.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.proto.journal.Table.UpdateDatabaseInfoEntry.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.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.grpc.CreateLocalBlockRequest.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.ReadRequest.Builder
This is only set for UFS block read.
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.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.CheckConsistencyPRequest.Builder
optional .alluxio.grpc.file.CheckConsistencyPOptions options = 2;
clearOptions() - Method in class alluxio.grpc.CommitBlockInUfsPRequest.Builder
optional .alluxio.grpc.block.CommitBlockInUfsPOptions options = 3;
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.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.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.GetFileInfoPRequest.Builder
optional .alluxio.grpc.file.GetFileInfoPOptions options = 2;
clearOptions() - Method in class alluxio.grpc.GetJobServiceSummaryPRequest.Builder
optional .alluxio.grpc.job.GetJobServiceSummaryPOptions options = 1;
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.GetQuorumInfoPRequest.Builder
optional .alluxio.grpc.journal.GetQuorumInfoPOptions 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.ListAllPRequest.Builder
optional .alluxio.grpc.job.ListAllPOptions options = 1;
clearOptions() - Method in class alluxio.grpc.ListStatusPRequest.Builder
optional .alluxio.grpc.file.ListStatusPOptions 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.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.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.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.StartSyncPRequest.Builder
optional .alluxio.grpc.file.StartSyncPOptions options = 2;
clearOptions() - Method in class alluxio.grpc.StopSyncPRequest.Builder
optional .alluxio.grpc.file.StopSyncPOptions options = 2;
clearOptions() - Method in class alluxio.grpc.table.AttachDatabasePRequest.Builder
 
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;
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;
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.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;
clearOwner() - Method in class alluxio.proto.journal.Table.AddTableEntry.Builder
optional string owner = 3;
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;
clearOwnerName() - Method in class alluxio.proto.journal.Table.UpdateDatabaseInfoEntry.Builder
optional string owner_name = 4;
clearOwnerType() - Method in class alluxio.grpc.table.Database.Builder
optional .alluxio.grpc.table.PrincipalType owner_type = 6;
clearOwnerType() - Method in class alluxio.proto.journal.Table.UpdateDatabaseInfoEntry.Builder
optional .alluxio.grpc.table.PrincipalType owner_type = 5;
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
 
clearParameter() - Method in class alluxio.proto.journal.Table.UpdateDatabaseInfoEntry.Builder
 
clearParameters() - Method in class alluxio.grpc.table.layout.hive.PartitionInfo.Builder
 
clearParameters() - Method in class alluxio.grpc.table.TableInfo.Builder
 
clearParameters() - Method in class alluxio.proto.journal.Table.AddTableEntry.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;
clearPartitionCols() - Method in class alluxio.grpc.table.TableInfo.Builder
partitioning scheme
clearPartitionCols() - Method in class alluxio.proto.journal.Table.AddTableEntry.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;
clearPartitions() - Method in class alluxio.proto.journal.Table.AddTableEntry.Builder
repeated .alluxio.grpc.table.Partition partitions = 9;
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.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.CreateLocalBlockResponse.Builder
optional string path = 1;
clearPath() - Method in class alluxio.grpc.DeletePRequest.Builder
the path of the file or directory
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.ListStatusPRequest.Builder
the path of the file or directory
clearPath() - Method in class alluxio.grpc.OpenLocalBlockResponse.Builder
optional 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.grpc.StartSyncPRequest.Builder
optional string path = 1;
clearPath() - Method in class alluxio.grpc.StopSyncPRequest.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;
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;
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.CreateLocalBlockRequest.Builder
optional bool pin_on_create = 8;
clearPinOnCreate() - Method in class alluxio.grpc.WriteRequestCommand.Builder
optional bool pin_on_create = 9;
clearPositionShort() - Method in class alluxio.grpc.ReadRequest.Builder
Is position read to a small buffer
clearPreviousVersion() - Method in class alluxio.grpc.table.TableInfo.Builder
optional int64 previous_version = 9;
clearPreviousVersion() - Method in class alluxio.proto.journal.Table.AddTableEntry.Builder
optional int64 previous_version = 10;
clearPromote() - Method in class alluxio.grpc.OpenLocalBlockRequest.Builder
optional bool promote = 2;
clearPromote() - Method in class alluxio.grpc.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.proto.journal.File.AddMountPointEntry.Builder
repeated .alluxio.proto.journal.StringPairEntry properties = 4;
clearProperties() - Method in class alluxio.proto.journal.Meta.PathPropertiesEntry.Builder
 
clearRange() - Method in class alluxio.grpc.table.Domain.Builder
optional .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;
clearRemoveTable() - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
optional .alluxio.proto.journal.RemoveTableEntry remove_table = 50;
clearRemoveTransformJobInfo() - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
optional .alluxio.proto.journal.RemoveTransformJobInfoEntry remove_transform_job_info = 47;
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;
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;
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;
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
clearSchema() - Method in class alluxio.grpc.table.TableInfo.Builder
optional .alluxio.grpc.table.Schema schema = 5;
clearSchema() - Method in class alluxio.proto.journal.Table.AddTableEntry.Builder
optional .alluxio.grpc.table.Schema schema = 4;
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
optional int64 sequence_number = 1;
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.QuorumServerInfo.Builder
optional .alluxio.grpc.NetAddress serverAddress = 1;
clearServerAddress() - Method in class alluxio.grpc.RemoveQuorumServerPRequest.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
optional .alluxio.grpc.version.ServiceType serviceType = 1;
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;
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
clearSourcePort() - Method in class alluxio.grpc.AsyncCacheRequest.Builder
optional int32 source_port = 3;
clearSpaceToReserve() - Method in class alluxio.grpc.CreateLocalBlockRequest.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;
clearStartTimeMs() - Method in class alluxio.grpc.MasterInfo.Builder
optional int64 startTimeMs = 5;
clearStartTimeMs() - Method in class alluxio.grpc.WorkerInfo.Builder
optional int64 startTimeMs = 7;
clearState() - Method in class alluxio.grpc.WorkerInfo.Builder
optional string state = 4;
clearStateLockSleepDurationMs() - Method in class alluxio.grpc.BackupPOptions.Builder
optional int64 stateLockSleepDurationMs = 5;
clearStateLockTimeoutMs() - Method in class alluxio.grpc.BackupPOptions.Builder
optional int64 stateLockTimeoutMs = 6;
clearStateLockTryDurationMs() - Method in class alluxio.grpc.BackupPOptions.Builder
optional int64 stateLockTryDurationMs = 4;
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.ConfigCheckReport.Builder
optional .alluxio.grpc.meta.ConfigStatus status = 3;
clearStatus() - Method in class alluxio.grpc.JobInfo.Builder
optional .alluxio.grpc.job.Status status = 4;
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.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
optional .alluxio.grpc.table.StringColumnStatsData string_stats = 4;
clearStringType() - Method in class alluxio.grpc.table.Value.Builder
optional 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;
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;
clearSyncPaths() - Method in class alluxio.grpc.GetSyncPathListPResponse.Builder
repeated .alluxio.grpc.file.SyncPointInfo syncPaths = 1;
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;
clearSyncPointUri() - Method in class alluxio.grpc.SyncPointInfo.Builder
optional string syncPointUri = 1;
clearSyncStatus() - Method in class alluxio.grpc.SyncPointInfo.Builder
optional .alluxio.grpc.file.SyncPointStatus syncStatus = 2;
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;
clearTableName() - Method in class alluxio.proto.journal.Table.AddTableEntry.Builder
optional string table_name = 2;
clearTableName() - Method in class alluxio.proto.journal.Table.AddTransformJobInfoEntry.Builder
optional string table_name = 2;
clearTableName() - Method in class alluxio.proto.journal.Table.CompleteTransformTableEntry.Builder
optional string table_name = 2;
clearTableName() - Method in class alluxio.proto.journal.Table.RemoveTableEntry.Builder
optional string table_name = 2;
clearTableName() - Method in class alluxio.proto.journal.Table.RemoveTransformJobInfoEntry.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;
clearTableStats() - Method in class alluxio.proto.journal.Table.AddTableEntry.Builder
repeated .alluxio.grpc.table.ColumnStatisticsInfo table_stats = 6;
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;
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;
clearTier() - Method in class alluxio.grpc.CreateLocalBlockRequest.Builder
optional int32 tier = 3;
clearTier() - Method in class alluxio.grpc.WriteRequestCommand.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
clearTieredIdentity() - Method in class alluxio.grpc.WorkerNetAddress.Builder
optional .alluxio.grpc.TieredIdentity tieredIdentity = 6;
clearTierName() - Method in class alluxio.grpc.LocalityTier.Builder
optional string tierName = 1;
clearTiers() - Method in class alluxio.grpc.TieredIdentity.Builder
repeated .alluxio.grpc.LocalityTier tiers = 1;
clearTiers() - Method in class alluxio.grpc.TierList.Builder
repeated int64 tiers = 1;
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
 
clearTransformations() - Method in class alluxio.grpc.table.Partition.Builder
The latest transformation is in the back of the list.
clearTransformedLayouts() - Method in class alluxio.proto.journal.Table.AddTransformJobInfoEntry.Builder
 
clearTransformedLayouts() - Method in class alluxio.proto.journal.Table.CompleteTransformTableEntry.Builder
 
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.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.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;
clearUdbConnectionUri() - Method in class alluxio.proto.journal.Table.AttachDbEntry.Builder
optional string udb_connection_uri = 2;
clearUdbDbName() - Method in class alluxio.grpc.table.AttachDatabasePRequest.Builder
optional string udb_db_name = 3;
clearUdbDbName() - Method in class alluxio.proto.journal.Table.AttachDbEntry.Builder
optional string udb_db_name = 3;
clearUdbType() - Method in class alluxio.grpc.table.AttachDatabasePRequest.Builder
optional string udb_type = 1;
clearUdbType() - Method in class alluxio.proto.journal.Table.AttachDbEntry.Builder
optional string udb_type = 1;
clearUfsCapacityBytes() - Method in class alluxio.grpc.MountPointInfo.Builder
optional int64 ufsCapacityBytes = 3 [default = -1];
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;
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.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;
clearUfsStringLocations() - Method in class alluxio.grpc.FileBlockInfo.Builder
repeated string ufsStringLocations = 4;
clearUfsType() - Method in class alluxio.grpc.MountPointInfo.Builder
optional string ufsType = 2;
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
clearUpdateDatabaseInfo() - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
optional .alluxio.proto.journal.UpdateDatabaseInfoEntry update_database_info = 49;
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
 
clearUser() - Method in class alluxio.proto.dataserver.Protocol.OpenUfsBlockOptions.Builder
The client does not need to set this.
clearUserActions() - Method in class alluxio.proto.shared.Acl.AccessControlList.Builder
repeated .alluxio.proto.shared.NamedAclActions userActions = 3;
clearValue() - Method in class alluxio.grpc.ConfigProperty.Builder
optional string value = 3;
clearValue() - Method in class alluxio.grpc.LocalityTier.Builder
optional string value = 2;
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;
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
 
clearVersion() - Method in class alluxio.grpc.GetServiceVersionPResponse.Builder
optional int64 version = 1;
clearVersion() - Method in class alluxio.grpc.MasterInfo.Builder
optional string version = 7;
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.proto.journal.Table.AddTableEntry.Builder
optional int64 version = 11;
clearVersion() - Method in class alluxio.proto.journal.Table.RemoveTableEntry.Builder
optional int64 version = 4;
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;
clearVersionCreationTime() - Method in class alluxio.proto.journal.Table.AddTableEntry.Builder
optional int64 version_creation_time = 12;
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;
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.GetWorkerIdPResponse.Builder
optional int64 workerId = 1;
clearWorkerId() - Method in class alluxio.grpc.JobWorkerHealth.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;
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.RegisterJobWorkerPRequest.Builder
optional .alluxio.grpc.WorkerNetAddress workerNetAddress = 1;
clearWorkerRange() - Method in class alluxio.grpc.GetWorkerReportPOptions.Builder
optional .alluxio.grpc.block.WorkerRange workerRange = 3;
clearWriteTier() - Method in class alluxio.grpc.CreateFilePOptions.Builder
optional int32 writeTier = 7;
clearWriteType() - Method in class alluxio.grpc.CreateDirectoryPOptions.Builder
optional .alluxio.grpc.file.WritePType writeType = 4;
clearWriteType() - Method in class alluxio.grpc.CreateFilePOptions.Builder
optional .alluxio.grpc.file.WritePType writeType = 8;
clearXattr() - Method in class alluxio.grpc.FileInfo.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
 
clearZookeeperAddresses() - Method in class alluxio.grpc.MasterInfo.Builder
Empty means zookeeper is not enabled
Client - Interface in alluxio
Interface for a client in the Alluxio system.
client() - Method in class alluxio.master.transport.GrpcMessagingTransport
 
CLIENT_BYTES_READ_LOCAL - Static variable in class alluxio.metrics.MetricKey
 
CLIENT_BYTES_READ_LOCAL - Static variable in class alluxio.metrics.MetricKey.Name
 
CLIENT_BYTES_READ_LOCAL_THROUGHPUT - Static variable in class alluxio.metrics.MetricKey
 
CLIENT_BYTES_READ_LOCAL_THROUGHPUT - Static variable in class alluxio.metrics.MetricKey.Name
 
CLIENT_BYTES_WRITTEN_LOCAL - Static variable in class alluxio.metrics.MetricKey
 
CLIENT_BYTES_WRITTEN_LOCAL - Static variable in class alluxio.metrics.MetricKey.Name
 
CLIENT_BYTES_WRITTEN_LOCAL_THROUGHPUT - Static variable in class alluxio.metrics.MetricKey
 
CLIENT_BYTES_WRITTEN_LOCAL_THROUGHPUT - Static variable in class alluxio.metrics.MetricKey.Name
 
CLIENT_BYTES_WRITTEN_UFS - Static variable in class alluxio.metrics.MetricKey
 
CLIENT_BYTES_WRITTEN_UFS - Static variable in class alluxio.metrics.MetricKey.Name
 
CLIENT_CACHE_BYTES_EVICTED - Static variable in class alluxio.metrics.MetricKey
 
CLIENT_CACHE_BYTES_EVICTED - Static variable in class alluxio.metrics.MetricKey.Name
 
CLIENT_CACHE_BYTES_READ_CACHE - Static variable in class alluxio.metrics.MetricKey
 
CLIENT_CACHE_BYTES_READ_CACHE - Static variable in class alluxio.metrics.MetricKey.Name
 
CLIENT_CACHE_BYTES_READ_EXTERNAL - Static variable in class alluxio.metrics.MetricKey
 
CLIENT_CACHE_BYTES_READ_EXTERNAL - Static variable in class alluxio.metrics.MetricKey.Name
 
CLIENT_CACHE_BYTES_REQUESTED_EXTERNAL - Static variable in class alluxio.metrics.MetricKey
 
CLIENT_CACHE_BYTES_REQUESTED_EXTERNAL - Static variable in class alluxio.metrics.MetricKey.Name
 
CLIENT_CACHE_BYTES_WRITTEN_CACHE - Static variable in class alluxio.metrics.MetricKey
 
CLIENT_CACHE_BYTES_WRITTEN_CACHE - Static variable in class alluxio.metrics.MetricKey.Name
 
CLIENT_CACHE_CREATE_ERRORS - Static variable in class alluxio.metrics.MetricKey
 
CLIENT_CACHE_CREATE_ERRORS - Static variable in class alluxio.metrics.MetricKey.Name
 
CLIENT_CACHE_DELETE_ERRORS - Static variable in class alluxio.metrics.MetricKey
 
CLIENT_CACHE_DELETE_ERRORS - Static variable in class alluxio.metrics.MetricKey.Name
 
CLIENT_CACHE_GET_ERRORS - Static variable in class alluxio.metrics.MetricKey
 
CLIENT_CACHE_GET_ERRORS - Static variable in class alluxio.metrics.MetricKey.Name
 
CLIENT_CACHE_GET_FAILED_READ_ERRORS - Static variable in class alluxio.metrics.MetricKey
 
CLIENT_CACHE_GET_FAILED_READ_ERRORS - Static variable in class alluxio.metrics.MetricKey.Name
 
CLIENT_CACHE_HIT_RATE - Static variable in class alluxio.metrics.MetricKey
 
CLIENT_CACHE_HIT_RATE - Static variable in class alluxio.metrics.MetricKey.Name
 
CLIENT_CACHE_PAGES_EVICTED - Static variable in class alluxio.metrics.MetricKey
 
CLIENT_CACHE_PAGES_EVICTED - Static variable in class alluxio.metrics.MetricKey.Name
 
CLIENT_CACHE_PUT_ERRORS - Static variable in class alluxio.metrics.MetricKey
 
CLIENT_CACHE_PUT_ERRORS - Static variable in class alluxio.metrics.MetricKey.Name
 
CLIENT_CACHE_PUT_FAILED_WRITE_ERRORS - Static variable in class alluxio.metrics.MetricKey
 
CLIENT_CACHE_PUT_FAILED_WRITE_ERRORS - Static variable in class alluxio.metrics.MetricKey.Name
 
CLIENT_CACHE_SPACE_AVAILABLE - Static variable in class alluxio.metrics.MetricKey
 
CLIENT_CACHE_SPACE_AVAILABLE - Static variable in class alluxio.metrics.MetricKey.Name
 
CLIENT_CACHE_SPACE_USED - Static variable in class alluxio.metrics.MetricKey
 
CLIENT_CACHE_SPACE_USED - Static variable in class alluxio.metrics.MetricKey.Name
 
CLIENT_VALUE - Static variable in enum alluxio.grpc.Scope
CLIENT = 4;
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.
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
 
ClientIpAddressInjector - Class in alluxio.security.authentication
Server side interceptor that is used to put remote client's IP Address to thread local storage.
ClientIpAddressInjector() - Constructor for class alluxio.security.authentication.ClientIpAddressInjector
 
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
 
ClientPool - Class in alluxio.master
Keeps a collection of all clients (FileSystem) returned.
ClientRWLock - Class in alluxio.worker.block
Read/write lock associated with clients rather than threads.
ClientRWLock() - Constructor for class alluxio.worker.block.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
 
CliUtils - Class in alluxio.cli
Utilities to run the examples.
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.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.BlockStoreLocationProto.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.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.Command.Builder
 
clone() - Method in class alluxio.grpc.CommitBlockInUfsPOptions.Builder
 
clone() - Method in class alluxio.grpc.CommitBlockInUfsPRequest.Builder
 
clone() - Method in class alluxio.grpc.CommitBlockInUfsPResponse.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.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.CreateLocalBlockRequest.Builder
 
clone() - Method in class alluxio.grpc.CreateLocalBlockResponse.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.ExistsPOptions.Builder
 
clone() - Method in class alluxio.grpc.FileBlockInfo.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.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.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.GetJobServiceSummaryPOptions.Builder
 
clone() - Method in class alluxio.grpc.GetJobServiceSummaryPRequest.Builder
 
clone() - Method in class alluxio.grpc.GetJobServiceSummaryPResponse.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.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.GetPinnedFileIdsPOptions.Builder
 
clone() - Method in class alluxio.grpc.GetPinnedFileIdsPRequest.Builder
 
clone() - Method in class alluxio.grpc.GetPinnedFileIdsPResponse.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.GetServiceVersionPRequest.Builder
 
clone() - Method in class alluxio.grpc.GetServiceVersionPResponse.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.GetSyncPathListPRequest.Builder
 
clone() - Method in class alluxio.grpc.GetSyncPathListPResponse.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.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.JobServiceSummary.Builder
 
clone() - Method in class alluxio.grpc.JobUnused.Builder
 
clone() - Method in class alluxio.grpc.JobWorkerHealth.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.ListStatusPOptions.Builder
 
clone() - Method in class alluxio.grpc.ListStatusPRequest.Builder
 
clone() - Method in class alluxio.grpc.ListStatusPResponse.Builder
 
clone() - Method in class alluxio.grpc.LoadMetadataPOptions.Builder
 
clone() - Method in class alluxio.grpc.LocalityTier.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.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.NetAddress.Builder
 
clone() - Method in class alluxio.grpc.OpenFilePOptions.Builder
 
clone() - Method in class alluxio.grpc.OpenLocalBlockRequest.Builder
 
clone() - Method in class alluxio.grpc.OpenLocalBlockResponse.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.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.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.RemovePathConfigurationPOptions.Builder
 
clone() - Method in class alluxio.grpc.RemovePathConfigurationPRequest.Builder
 
clone() - Method in class alluxio.grpc.RemovePathConfigurationPResponse.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.ReverseResolvePRequest.Builder
 
clone() - Method in class alluxio.grpc.ReverseResolvePResponse.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.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.StartSyncPOptions.Builder
 
clone() - Method in class alluxio.grpc.StartSyncPRequest.Builder
 
clone() - Method in class alluxio.grpc.StartSyncPResponse.Builder
 
clone() - Method in class alluxio.grpc.StatusSummary.Builder
 
clone() - Method in class alluxio.grpc.StopSyncPOptions.Builder
 
clone() - Method in class alluxio.grpc.StopSyncPRequest.Builder
 
clone() - Method in class alluxio.grpc.StopSyncPResponse.Builder
 
clone() - Method in class alluxio.grpc.StorageList.Builder
 
clone() - Method in class alluxio.grpc.SyncPointInfo.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.TieredIdentity.Builder
 
clone() - Method in class alluxio.grpc.TierList.Builder
 
clone() - Method in class alluxio.grpc.TransportMessage.Builder
 
clone() - Method in class alluxio.grpc.UfsInfo.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.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.WorkerInfo.Builder
 
clone() - Method in class alluxio.grpc.WorkerLostStorageInfo.Builder
 
clone() - Method in class alluxio.grpc.WorkerNetAddress.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.CreateUfsBlockOptions.Builder
 
clone() - Method in class alluxio.proto.dataserver.Protocol.CreateUfsFileOptions.Builder
 
clone() - Method in class alluxio.proto.dataserver.Protocol.OpenUfsBlockOptions.Builder
 
clone() - Method in class alluxio.proto.dataserver.Protocol.Response.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.Journal.JournalEntry.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.Table.AddTableEntry.Builder
 
clone() - Method in class alluxio.proto.journal.Table.AddTransformJobInfoEntry.Builder
 
clone() - Method in class alluxio.proto.journal.Table.AttachDbEntry.Builder
 
clone() - Method in class alluxio.proto.journal.Table.CompleteTransformTableEntry.Builder
 
clone() - Method in class alluxio.proto.journal.Table.DetachDbEntry.Builder
 
clone() - Method in class alluxio.proto.journal.Table.RemoveTableEntry.Builder
 
clone() - Method in class alluxio.proto.journal.Table.RemoveTransformJobInfoEntry.Builder
 
clone() - Method in class alluxio.proto.journal.Table.UpdateDatabaseInfoEntry.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.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.CopyFromLocalCommand
 
close() - Method in class alluxio.cli.fs.command.DistributedLoadCommand
 
close() - Method in class alluxio.cli.fsadmin.command.Context
 
close() - Method in class alluxio.client.block.stream.BlockInStream
 
close() - Method in class alluxio.client.block.stream.BlockOutStream
 
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.LocalFileDataReader
 
close() - Method in class alluxio.client.block.stream.LocalFileDataReader.Factory
 
close() - Method in class alluxio.client.block.stream.LocalFileDataWriter
 
close() - Method in class alluxio.client.block.stream.UfsFallbackLocalFileDataWriter
 
close() - Method in class alluxio.client.file.AlluxioFileInStream
 
close() - Method in class alluxio.client.file.AlluxioFileOutStream
 
close() - Method in class alluxio.client.file.BaseFileSystem
Shuts down the FileSystem.
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.NoExceptionCacheManager
 
close() - Method in class alluxio.client.file.cache.store.LocalPageStore
 
close() - Method in class alluxio.client.file.cache.store.RocksPageStore
 
close() - Method in class alluxio.client.file.ConfigHashSync
 
close() - Method in class alluxio.client.file.DelegatingFileSystem
 
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.MetadataCachingBaseFileSystem
 
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.concurrent.ManagedBlockingUfsForwarder
 
close() - Method in interface alluxio.grpc.BufferRepository
Closes the repository and all its buffers.
close() - Method in class alluxio.grpc.DataMessageMarshaller
 
close() - Method in class alluxio.grpc.GrpcConnection
Releases the connection to the pool.
close() - Method in class alluxio.hadoop.AbstractFileSystem
 
close() - Method in class alluxio.hadoop.AlluxioHdfsFileSystem
 
close() - Method in class alluxio.hadoop.AlluxioHdfsInputStream
 
close() - Method in class alluxio.hadoop.HdfsFileInputStream
 
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.job.plan.transform.format.csv.CsvReader
 
close() - Method in class alluxio.job.plan.transform.format.csv.CsvWriter
 
close() - Method in class alluxio.job.plan.transform.format.parquet.ParquetReader
 
close() - Method in class alluxio.job.plan.transform.format.parquet.ParquetWriter
 
close() - Method in interface alluxio.job.plan.transform.format.TableReader
Closes the reader, which will close the underlying stream.
close() - Method in class alluxio.job.plan.transform.format.tables.TablesWriter
 
close() - Method in interface alluxio.job.plan.transform.format.TableWriter
Closes a writer, which means the table is complete now.
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.ClientPool
 
close() - Method in class alluxio.master.file.activesync.ActiveSyncer
 
close() - Method in class alluxio.master.file.BlockIntegrityChecker
 
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.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.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.NoopBlockDeletionContext
 
close() - Method in class alluxio.master.file.replication.ReplicationChecker
 
close() - Method in class alluxio.master.file.RpcContext
 
close() - Method in class alluxio.master.journal.AsyncJournalWriter
Closes the async writer.
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.noop.NoopJournal
 
close() - Method in class alluxio.master.journal.NoopJournalContext
 
close() - Method in class alluxio.master.journal.raft.JournalStateMachine
Closes the journal state machine, causing all further modification requests to be ignored.
close() - Method in class alluxio.master.journal.raft.RaftJournal
 
close() - Method in class alluxio.master.journal.raft.RaftJournalWriter
 
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.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.MetaMasterSync
 
close() - Method in class alluxio.master.meta.UpdateChecker
 
close() - Method in interface alluxio.master.metastore.BlockStore
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.HeapBlockStore
 
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.RocksBlockStore
 
close() - Method in class alluxio.master.metastore.rocks.RocksInodeStore
 
close() - Method in class alluxio.master.metastore.rocks.RocksStore
 
close() - Method in class alluxio.master.NoopMaster
 
close() - Method in class alluxio.master.PrimarySelectorClient
 
close() - Method in class alluxio.master.table.DefaultTableMaster
 
close() - Method in class alluxio.master.transport.GrpcMessagingClient
 
close() - Method in class alluxio.master.transport.GrpcMessagingClientConnection
 
close() - Method in class alluxio.master.transport.GrpcMessagingConnection
 
close() - Method in class alluxio.master.transport.GrpcMessagingServer
 
close() - Method in class alluxio.master.transport.GrpcMessagingTransport
 
close() - Method in class alluxio.master.ZkMasterInquireClient
 
close() - Method in class alluxio.multi.process.Master
 
close() - Method in class alluxio.multi.process.Worker
 
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
Performs any cleanup operations necessary when the resource is no longer in use.
close() - Method in class alluxio.resource.DynamicResourcePool
Closes the pool and clears all the resources.
close() - Method in class alluxio.resource.LockResource
Releases the lock.
close() - Method in class alluxio.resource.RefCountLockResource
Releases the lock and decrement the ref count if a ref counter was provided at construction time.
close() - Method in class alluxio.resource.ResourcePool
Closes the resource pool.
close() - Method in class alluxio.security.authentication.AbstractSaslClientHandler
This is synchronized in order to protect AbstractSaslClientHandler.mSaslClient.
close() - Method in class alluxio.security.authentication.AbstractSaslServerHandler
 
close() - Method in class alluxio.security.authentication.AuthenticatedChannelClientDriver
Stops authenticated session with the server by releasing the long poll.
close() - Method in class alluxio.security.authentication.AuthenticatedChannelServerDriver
Completes authenticated channel.
close() - Method in interface alluxio.security.authentication.AuthenticationServer
Closes the server, releases all authentication sessions.
close() - Method in class alluxio.security.authentication.DefaultAuthenticationServer
 
close() - Method in interface alluxio.security.authentication.SaslClientHandler
Close the handler and dispose internal resources.
close() - Method in interface alluxio.security.authentication.SaslServerHandler
Close the handler and dispose internal resources.
close() - Method in interface alluxio.Server
Closes the server.
close() - Method in class alluxio.underfs.AbstractUfsManager
 
close() - Method in class alluxio.underfs.AtomicFileOutputStream
 
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.hdfs.HdfsUnderFileOutputStream
 
close() - Method in class alluxio.underfs.hdfs.HdfsUnderFileSystem
 
close() - Method in class alluxio.underfs.kodo.KodoOutputStream
Closes this output stream.
close() - Method in class alluxio.underfs.local.LocalUnderFileSystem
 
close() - Method in class alluxio.underfs.MultiRangeObjectInputStream
 
close() - Method in class alluxio.underfs.ObjectUnderFileSystem
 
close() - Method in class alluxio.underfs.oss.OSSOutputStream
Closes this output stream.
close() - Method in class alluxio.underfs.s3a.S3AInputStream
 
close() - Method in class alluxio.underfs.s3a.S3ALowLevelOutputStream
 
close() - Method in class alluxio.underfs.s3a.S3AOutputStream
 
close() - Method in class alluxio.underfs.swift.SwiftMockOutputStream
 
close() - Method in class alluxio.underfs.swift.SwiftOutputStream
 
close() - Method in class alluxio.underfs.UnderFileSystemWithLogging
 
close() - Method in class alluxio.underfs.web.WebUnderFileSystem
 
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.BlockMasterSync
 
close() - Method in class alluxio.worker.block.DefaultBlockWorker.StorageChecker
 
close() - Method in class alluxio.worker.block.io.LocalFileBlockReader
 
close() - Method in class alluxio.worker.block.io.LocalFileBlockWriter
 
close() - Method in class alluxio.worker.block.PinListSync
 
close() - Method in class alluxio.worker.block.RemoteBlockReader
 
close() - Method in class alluxio.worker.block.SpaceReserver
 
close() - Method in class alluxio.worker.block.UnderFileSystemBlockReader
Closes the block reader.
close() - Method in class alluxio.worker.grpc.GrpcDataServer
 
close() - Method in class alluxio.worker.job.command.CommandHandlingExecutor
 
close() - Method in class alluxio.worker.SessionCleaner
Stops the checking, once this method is called, the object should be discarded.
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.
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
CLOSED_FS_ERROR_MESSAGE - Static variable in class alluxio.client.file.FileSystemCache.InstanceCachingFileSystem
 
closeMasters() - Method in class alluxio.master.AlluxioMasterProcess
Closes all masters, including block master, fileSystem master and additional masters.
closeReaderOrWriter(long, long) - Method in class alluxio.worker.block.UnderFileSystemBlockStore
Closes the block reader or writer and checks whether it is necessary to commit the block to Local block store.
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(T) - Method in class alluxio.resource.DynamicResourcePool
Closes the resource.
closeResource(IMetaStoreClient) - Method in class alluxio.table.under.hive.util.HiveClientPool
 
closeUfsBlock(long, long) - Method in interface alluxio.worker.block.BlockWorker
Closes a UFS block for a client session.
closeUfsBlock(long, long) - Method in class alluxio.worker.block.DefaultBlockWorker
 
CLUSTER - Static variable in class alluxio.metrics.MetricsSystem
 
CLUSTER_BYTES_READ_ALLUXIO - Static variable in class alluxio.metrics.MetricKey
 
CLUSTER_BYTES_READ_ALLUXIO - Static variable in class alluxio.metrics.MetricKey.Name
 
CLUSTER_BYTES_READ_ALLUXIO_THROUGHPUT - Static variable in class alluxio.metrics.MetricKey
 
CLUSTER_BYTES_READ_ALLUXIO_THROUGHPUT - Static variable in class alluxio.metrics.MetricKey.Name
 
CLUSTER_BYTES_READ_DOMAIN - Static variable in class alluxio.metrics.MetricKey
 
CLUSTER_BYTES_READ_DOMAIN - Static variable in class alluxio.metrics.MetricKey.Name
 
CLUSTER_BYTES_READ_DOMAIN_THROUGHPUT - Static variable in class alluxio.metrics.MetricKey
 
CLUSTER_BYTES_READ_DOMAIN_THROUGHPUT - Static variable in class alluxio.metrics.MetricKey.Name
 
CLUSTER_BYTES_READ_LOCAL - Static variable in class alluxio.metrics.MetricKey
 
CLUSTER_BYTES_READ_LOCAL - Static variable in class alluxio.metrics.MetricKey.Name
 
CLUSTER_BYTES_READ_LOCAL_THROUGHPUT - Static variable in class alluxio.metrics.MetricKey
 
CLUSTER_BYTES_READ_LOCAL_THROUGHPUT - Static variable in class alluxio.metrics.MetricKey.Name
 
CLUSTER_BYTES_READ_UFS - Static variable in class alluxio.metrics.MetricKey
 
CLUSTER_BYTES_READ_UFS - Static variable in class alluxio.metrics.MetricKey.Name
 
CLUSTER_BYTES_READ_UFS_ALL - Static variable in class alluxio.metrics.MetricKey
 
CLUSTER_BYTES_READ_UFS_ALL - Static variable in class alluxio.metrics.MetricKey.Name
 
CLUSTER_BYTES_READ_UFS_THROUGHPUT - Static variable in class alluxio.metrics.MetricKey
 
CLUSTER_BYTES_READ_UFS_THROUGHPUT - Static variable in class alluxio.metrics.MetricKey.Name
 
CLUSTER_BYTES_WRITTEN_ALLUXIO - Static variable in class alluxio.metrics.MetricKey
 
CLUSTER_BYTES_WRITTEN_ALLUXIO - Static variable in class alluxio.metrics.MetricKey.Name
 
CLUSTER_BYTES_WRITTEN_ALLUXIO_THROUGHPUT - Static variable in class alluxio.metrics.MetricKey
 
CLUSTER_BYTES_WRITTEN_ALLUXIO_THROUGHPUT - Static variable in class alluxio.metrics.MetricKey.Name
 
CLUSTER_BYTES_WRITTEN_DOMAIN - Static variable in class alluxio.metrics.MetricKey
 
CLUSTER_BYTES_WRITTEN_DOMAIN - Static variable in class alluxio.metrics.MetricKey.Name
 
CLUSTER_BYTES_WRITTEN_DOMAIN_THROUGHPUT - Static variable in class alluxio.metrics.MetricKey
 
CLUSTER_BYTES_WRITTEN_DOMAIN_THROUGHPUT - Static variable in class alluxio.metrics.MetricKey.Name
 
CLUSTER_BYTES_WRITTEN_LOCAL - Static variable in class alluxio.metrics.MetricKey
 
CLUSTER_BYTES_WRITTEN_LOCAL - Static variable in class alluxio.metrics.MetricKey.Name
 
CLUSTER_BYTES_WRITTEN_LOCAL_THROUGHPUT - Static variable in class alluxio.metrics.MetricKey
 
CLUSTER_BYTES_WRITTEN_LOCAL_THROUGHPUT - Static variable in class alluxio.metrics.MetricKey.Name
 
CLUSTER_BYTES_WRITTEN_UFS - Static variable in class alluxio.metrics.MetricKey
 
CLUSTER_BYTES_WRITTEN_UFS - Static variable in class alluxio.metrics.MetricKey.Name
 
CLUSTER_BYTES_WRITTEN_UFS_ALL - Static variable in class alluxio.metrics.MetricKey
 
CLUSTER_BYTES_WRITTEN_UFS_ALL - Static variable in class alluxio.metrics.MetricKey.Name
 
CLUSTER_BYTES_WRITTEN_UFS_THROUGHPUT - Static variable in class alluxio.metrics.MetricKey
 
CLUSTER_BYTES_WRITTEN_UFS_THROUGHPUT - Static variable in class alluxio.metrics.MetricKey.Name
 
CLUSTER_CAPACITY_FREE - Static variable in class alluxio.metrics.MetricKey
 
CLUSTER_CAPACITY_FREE - Static variable in class alluxio.metrics.MetricKey.Name
 
CLUSTER_CAPACITY_TOTAL - Static variable in class alluxio.metrics.MetricKey
 
CLUSTER_CAPACITY_TOTAL - Static variable in class alluxio.metrics.MetricKey.Name
 
CLUSTER_CAPACITY_USED - Static variable in class alluxio.metrics.MetricKey
 
CLUSTER_CAPACITY_USED - Static variable in class alluxio.metrics.MetricKey.Name
 
CLUSTER_DEFAULT - Static variable in class alluxio.conf.Source
 
CLUSTER_ID_FIELD_NUMBER - Static variable in class alluxio.proto.journal.Meta.ClusterInfoEntry
 
CLUSTER_INFO_FIELD_NUMBER - Static variable in class alluxio.proto.journal.Journal.JournalEntry
 
CLUSTER_ROOT_UFS_CAPACITY_FREE - Static variable in class alluxio.metrics.MetricKey
 
CLUSTER_ROOT_UFS_CAPACITY_FREE - Static variable in class alluxio.metrics.MetricKey.Name
 
CLUSTER_ROOT_UFS_CAPACITY_TOTAL - Static variable in class alluxio.metrics.MetricKey
 
CLUSTER_ROOT_UFS_CAPACITY_TOTAL - Static variable in class alluxio.metrics.MetricKey.Name
 
CLUSTER_ROOT_UFS_CAPACITY_USED - Static variable in class alluxio.metrics.MetricKey
 
CLUSTER_ROOT_UFS_CAPACITY_USED - Static variable in class alluxio.metrics.MetricKey.Name
 
CLUSTER_WORKERS - Static variable in class alluxio.metrics.MetricKey
 
CLUSTER_WORKERS - Static variable in class alluxio.metrics.MetricKey.Name
 
ClusterConfConsistencyValidationTask - Class in alluxio.cli.validation
Task for validating system limit for current user.
ClusterConfConsistencyValidationTask() - Constructor for class alluxio.cli.validation.ClusterConfConsistencyValidationTask
 
CLUSTERCONFIGHASH_FIELD_NUMBER - Static variable in class alluxio.grpc.GetConfigHashPResponse
 
CLUSTERCONFIGHASH_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.conf.path.SpecificPathConfiguration
 
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
 
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.
CollectInfo - Class in alluxio.cli.bundler
Class for collecting various information about all nodes in the cluster.
CollectInfo(InstancedConfiguration) - 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.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
 
COMMENT_FIELD_NUMBER - Static variable in class alluxio.proto.journal.Table.UpdateDatabaseInfoEntry
 
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) - 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.BlockMasterWorkerServiceImplBase
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 temporary block to the local store.
commitBlock(long, long, boolean) - Method in interface alluxio.worker.block.BlockWorker
Commits a block to Alluxio managed space.
commitBlock(long, long, boolean) - Method in class alluxio.worker.block.DefaultBlockWorker
 
commitBlock(long, long, boolean) - Method in class alluxio.worker.block.TieredBlockStore
 
commitBlockInUfs(CommitBlockInUfsPRequest) - Method in class alluxio.grpc.BlockMasterWorkerServiceGrpc.BlockMasterWorkerServiceBlockingStub
Marks the given block as committed which resides in UFS.
commitBlockInUfs(CommitBlockInUfsPRequest) - Method in class alluxio.grpc.BlockMasterWorkerServiceGrpc.BlockMasterWorkerServiceFutureStub
Marks the given block as committed which resides in UFS.
commitBlockInUfs(CommitBlockInUfsPRequest, StreamObserver<CommitBlockInUfsPResponse>) - Method in class alluxio.grpc.BlockMasterWorkerServiceGrpc.BlockMasterWorkerServiceImplBase
Marks the given block as committed which resides in UFS.
commitBlockInUfs(CommitBlockInUfsPRequest, StreamObserver<CommitBlockInUfsPResponse>) - Method in class alluxio.grpc.BlockMasterWorkerServiceGrpc.BlockMasterWorkerServiceStub
Marks the given block as committed which resides in UFS.
commitBlockInUFS(long, long) - Method in interface alluxio.master.block.BlockMaster
Marks a block as committed, but without a worker location.
commitBlockInUfs(CommitBlockInUfsPRequest, StreamObserver<CommitBlockInUfsPResponse>) - Method in class alluxio.master.block.BlockMasterWorkerServiceHandler
 
commitBlockInUFS(long, long) - Method in class alluxio.master.block.DefaultBlockMaster
 
commitBlockInUfs(long, long) - Method in class alluxio.worker.block.BlockMasterClient
Commits a block in Ufs.
commitBlockInUfs(long, long) - Method in interface alluxio.worker.block.BlockWorker
Commits a block in UFS.
commitBlockInUfs(long, long) - Method in class alluxio.worker.block.DefaultBlockWorker
 
CommitBlockInUfsPOptions - Class in alluxio.grpc
Protobuf type alluxio.grpc.block.CommitBlockInUfsPOptions
CommitBlockInUfsPOptions.Builder - Class in alluxio.grpc
Protobuf type alluxio.grpc.block.CommitBlockInUfsPOptions
CommitBlockInUfsPOptionsOrBuilder - Interface in alluxio.grpc
 
CommitBlockInUfsPRequest - Class in alluxio.grpc
Protobuf type alluxio.grpc.block.CommitBlockInUfsPRequest
CommitBlockInUfsPRequest.Builder - Class in alluxio.grpc
Protobuf type alluxio.grpc.block.CommitBlockInUfsPRequest
CommitBlockInUfsPRequestOrBuilder - Interface in alluxio.grpc
 
CommitBlockInUfsPResponse - Class in alluxio.grpc
Protobuf type alluxio.grpc.block.CommitBlockInUfsPResponse
CommitBlockInUfsPResponse.Builder - Class in alluxio.grpc
Protobuf type alluxio.grpc.block.CommitBlockInUfsPResponse
CommitBlockInUfsPResponseOrBuilder - Interface in alluxio.grpc
 
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
 
commitPath(StorageDir, long) - Static method in class alluxio.worker.block.meta.AbstractBlockMeta
Committed block is stored in BlockStore under its StorageDir as a block file named after its blockId.
commitTempBlockMeta(TempBlockMeta) - Method in class alluxio.worker.block.BlockMetadataManager
Commits a temp block.
Committer - Interface in alluxio.job.plan.transform.format.tables
Determines when to commit/complete a table file when writing a stream of rows to a group of table files.
COMMON_SSH_OPTS - Static variable in class alluxio.util.ShellUtils
Common shell OPTS to prevent stalling.
commonDefaults(AlluxioConfiguration) - Static method in class alluxio.util.FileSystemOptions
 
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.StartSyncPOptions
 
COMMONOPTIONS_FIELD_NUMBER - Static variable in class alluxio.grpc.StopSyncPOptions
 
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.
compact(List<TableReader>, TableWriter) - Method in interface alluxio.job.plan.transform.compact.Compactor
Compacts a list of inputs to the output.
CompactConfig - Class in alluxio.job.plan.transform
Configuration for a job to compact files directly under a directory.
CompactConfig(PartitionInfo, String, String, String, Integer, Long) - Constructor for class alluxio.job.plan.transform.CompactConfig
 
CompactDefinition - Class in alluxio.job.plan.transform
The job definition for compacting files representing a structured table under a directory.
CompactDefinition() - Constructor for class alluxio.job.plan.transform.CompactDefinition
Constructs a new CompactDefinition.
Compactor - Interface in alluxio.job.plan.transform.compact
Compacts a list of inputs to an output.
CompactTask - Class in alluxio.job.plan.transform
A task for a job worker to compact files into one file.
CompactTask(ArrayList<String>, String) - Constructor for class alluxio.job.plan.transform.CompactTask
 
compare(String, String) - Static method in class alluxio.util.URIUtils
 
compare(WorkerInfo, WorkerInfo) - Method in class alluxio.wire.WorkerInfo.LastContactSecComparator
 
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.
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(UfsJournalFile) - Method in class alluxio.master.journal.ufs.UfsJournalFile
 
compareTo(MetricKey) - Method in class alluxio.metrics.MetricKey
 
compareTo(Authority) - Method in interface alluxio.uri.Authority
 
compareTo(Authority) - Method in class alluxio.uri.MultiMasterAuthority
 
compareTo(URI) - Method in class alluxio.uri.StandardURI
 
compareTo(NodeInfo) - Method in class alluxio.util.webui.NodeInfo
Compare NodeInfo by lexicographical order of their associated host.
CompletableFuture<T> - Class in alluxio.concurrent.jsr
A Future that may be explicitly completed (setting its value and status), and may be used as a CompletionStage, supporting dependent functions and actions that trigger upon its completion.
CompletableFuture() - Constructor for class alluxio.concurrent.jsr.CompletableFuture
Creates a new incomplete CompletableFuture.
CompletableFuture.AsynchronousCompletionTask - Interface in alluxio.concurrent.jsr
A marker interface identifying asynchronous tasks produced by async methods.
complete(T) - Method in class alluxio.concurrent.jsr.CompletableFuture
If not already completed, sets the value returned by CompletableFuture.get() and related methods to the given value.
complete(T) - Method in class alluxio.concurrent.jsr.CountedCompleter
Regardless of pending count, invokes CountedCompleter.onCompletion(CountedCompleter), marks this task as complete and further triggers CountedCompleter.tryComplete() on this task's completer, if one exists.
complete(V) - Method in class alluxio.concurrent.jsr.ForkJoinTask
Completes this task, and if not already aborted or cancelled, returning the given value as the result of subsequent invocations of join and related operations.
complete() - Method in class alluxio.master.file.ListStatusResultStream
Used to complete the stream.
COMPLETE_FILE_FIELD_NUMBER - Static variable in class alluxio.proto.journal.Journal.JournalEntry
 
COMPLETE_TRANSFORM_TABLE_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.
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) - 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.FileSystemMasterClientServiceImplBase
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
 
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
 
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.
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(BlockReadRequestContext) - Method in class alluxio.worker.grpc.BlockReadHandler.BlockDataReader
 
completeRequest(BlockWriteRequestContext) - Method in class alluxio.worker.grpc.BlockWriteHandler
 
completeRequest(BlockWriteRequestContext) - Method in class alluxio.worker.grpc.UfsFallbackBlockWriteHandler
 
completeRequest(UfsFileWriteRequestContext) - Method in class alluxio.worker.grpc.UfsFileWriteHandler
 
completeTransformTable(JournalContext, String, String, String, Map<String, Layout>) - Method in class alluxio.master.table.AlluxioCatalog
Completes table transformation by updating the layouts of the table's partitions.
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.
composeCallTracker(CallTracker) - Method in class alluxio.master.file.DefaultFileSystemMaster
 
composeCallTracker(CallTracker) - Method in interface alluxio.master.file.FileSystemMaster
Composes an FSM call-tracker over given transport tracker.
CompositeCallTracker - Class in alluxio.master.file.contexts
A call-tracker that is composed of other call-trackers.
CompositeCallTracker(CallTracker...) - Constructor for class alluxio.master.file.contexts.CompositeCallTracker
A new composite call-tracker that combines many call-trackers.
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
 
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) - 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.
compute() - Method in class alluxio.concurrent.jsr.CountedCompleter
The main computation performed by this task.
compute() - Method in class alluxio.worker.job.command.JobWorkerHealthReporter
Computes all of the metrics needed for JobWorkerHealthReporter.
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.
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.
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).
CONF_DIR - Static variable in class alluxio.conf.PropertyKey
 
CONF_DIR - Static variable in class alluxio.conf.PropertyKey.Name
 
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
 
CONFIG_FIELD_NUMBER - Static variable in class alluxio.proto.journal.Table.AttachDbEntry
 
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) - 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.wire
Represents cluster level and path level configuration returned by meta master.
Configuration.Builder - Class in alluxio.wire
Configuration builder.
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.
ConfigurationUtils - Class in alluxio.table.common
A set of utility methods for configuration.
ConfigurationUtils - Class in alluxio.util
Utilities for working with Alluxio configurations.
ConfigurationValueOptions - Class in alluxio.conf
Options for getting configuration values.
connect() - Method in class alluxio.AbstractClient
Connects with the remote.
connect() - Method in interface alluxio.Client
Connects with the remote.
connect(StreamObserver<TransportMessage>) - Method in class alluxio.grpc.MessagingServiceGrpc.MessagingServiceImplBase
 
connect(StreamObserver<TransportMessage>) - Method in class alluxio.grpc.MessagingServiceGrpc.MessagingServiceStub
 
connect(Address) - Method in class alluxio.master.transport.GrpcMessagingClient
 
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.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
 
connectFromMaster(String) - Method in class alluxio.underfs.web.WebUnderFileSystem
 
connectFromWorker(String) - Method in class alluxio.concurrent.ManagedBlockingUfsForwarder
 
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
 
connectFromWorker(String) - Method in class alluxio.underfs.web.WebUnderFileSystem
 
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.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
 
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
 
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(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
 
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
containsConfig(String) - Method in class alluxio.proto.journal.Table.AttachDbEntry.Builder
map<string, string> config = 5;
containsConfig(String) - Method in class alluxio.proto.journal.Table.AttachDbEntry
map<string, string> config = 5;
containsConfig(String) - Method in interface alluxio.proto.journal.Table.AttachDbEntryOrBuilder
map<string, string> config = 5;
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
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.
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;
containsParameter(String) - Method in class alluxio.proto.journal.Table.UpdateDatabaseInfoEntry.Builder
map<string, string> parameter = 3;
containsParameter(String) - Method in class alluxio.proto.journal.Table.UpdateDatabaseInfoEntry
map<string, string> parameter = 3;
containsParameter(String) - Method in interface alluxio.proto.journal.Table.UpdateDatabaseInfoEntryOrBuilder
map<string, string> parameter = 3;
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;
containsParameters(String) - Method in class alluxio.proto.journal.Table.AddTableEntry.Builder
map<string, string> parameters = 7;
containsParameters(String) - Method in class alluxio.proto.journal.Table.AddTableEntry
map<string, string> parameters = 7;
containsParameters(String) - Method in interface alluxio.proto.journal.Table.AddTableEntryOrBuilder
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.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;
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
containsTransformedLayouts(String) - Method in class alluxio.proto.journal.Table.AddTransformJobInfoEntry.Builder
map<string, .alluxio.grpc.table.Layout> transformed_layouts = 5;
containsTransformedLayouts(String) - Method in class alluxio.proto.journal.Table.AddTransformJobInfoEntry
map<string, .alluxio.grpc.table.Layout> transformed_layouts = 5;
containsTransformedLayouts(String) - Method in interface alluxio.proto.journal.Table.AddTransformJobInfoEntryOrBuilder
map<string, .alluxio.grpc.table.Layout> transformed_layouts = 5;
containsTransformedLayouts(String) - Method in class alluxio.proto.journal.Table.CompleteTransformTableEntry.Builder
Map from partition spec to transformed layout
containsTransformedLayouts(String) - Method in class alluxio.proto.journal.Table.CompleteTransformTableEntry
Map from partition spec to transformed layout
containsTransformedLayouts(String) - Method in interface alluxio.proto.journal.Table.CompleteTransformTableEntryOrBuilder
Map from partition spec to transformed layout
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.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.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() - Constructor for class alluxio.proxy.s3.ListBucketResult.Content
Constructs a new ListBucketResult.Content.
Content(String, String, String, String, String) - Constructor for class alluxio.proxy.s3.ListBucketResult.Content
Constructs a new ListBucketResult.Content.
Context - Class in alluxio.cli.fsadmin.command
Context for running an fsadmin command.
Context(FileSystemMasterClient, BlockMasterClient, MetaMasterClient, MetaMasterConfigClient, MetricsMasterClient, JournalMasterClient, JournalMasterClient, JobMasterClient, PrintStream) - Constructor for class alluxio.cli.fsadmin.command.Context
 
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.checker.HiveIntegrationChecker.ModeConverter
 
convertAclToStringEntries() - Method in class alluxio.wire.FileInfo
 
convertByteArrayToStringWithoutEscape(byte[], int, int) - Static method in class alluxio.util.webui.WebUtils
Converts a byte array to string.
convertDefaultAclToStringEntries() - Method in class alluxio.wire.FileInfo
 
convertFromByteString(Map<String, ByteString>) - Static method in class alluxio.util.CommonUtils
 
convertMsToClockTime(long) - Static method in class alluxio.util.CommonUtils
Converts milliseconds to clock time.
convertMsToDate(long, String) - Static method in class alluxio.util.CommonUtils
Converts a millisecond number to a formatted date String.
convertMsToShortClockTime(long) - Static method in class alluxio.util.webui.WebUtils
Converts milliseconds to short clock time.
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.
coordinators() - Method in class alluxio.master.job.plan.PlanTracker
A collection of all PlanCoordinator currently tracked by the job master.
copy() - Method in class alluxio.concurrent.jsr.CompletableFuture
Returns a new CompletableFuture that is completed normally with the same value as this CompletableFuture when it completes normally.
copy() - Method in class alluxio.conf.AlluxioProperties
Makes a copy of the backing properties and returns them in a new object.
copy() - Method in class alluxio.underfs.UfsDirectoryStatus
 
copy() - Method in class alluxio.underfs.UfsFileStatus
 
copy() - Method in class alluxio.underfs.UfsStatus
Create a copy of UfsStatus.
CopyFromLocalCommand - Class in alluxio.cli.fs.command
Copies the specified file specified by "source path" to the path specified by "remote path".
CopyFromLocalCommand(FileSystemContext) - Constructor for class alluxio.cli.fs.command.CopyFromLocalCommand
 
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.kodo.KodoClient
Copys object in Qiniu kodo.
copyObject(String, String) - Method in class alluxio.underfs.kodo.KodoUnderFileSystem
 
copyObject(String, String) - Method in class alluxio.underfs.ObjectUnderFileSystem
Copies an object to another key.
copyObject(String, String) - Method in class alluxio.underfs.oss.OSSUnderFileSystem
 
copyObject(String, String) - Method in class alluxio.underfs.s3a.S3AUnderFileSystem
 
copyObject(String, String) - Method in class alluxio.underfs.swift.SwiftUnderFileSystem
 
copyProperties() - Method in interface alluxio.conf.AlluxioConfiguration
Gets a copy of the AlluxioProperties which back the AlluxioConfiguration.
copyProperties() - Method in class alluxio.conf.InstancedConfiguration
 
copyProperties() - Method in class alluxio.conf.path.SpecificPathConfiguration
 
copyProperties() - Static method in class alluxio.conf.ServerConfiguration
Create and return a copy of all properties.
CopyToLocalCommand - Class in alluxio.cli.fs.command
Copies a file or a directory from the Alluxio filesystem to the local filesystem.
CopyToLocalCommand(FileSystemContext) - Constructor for class alluxio.cli.fs.command.CopyToLocalCommand
 
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.
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.
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.
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
 
CountCommand - Class in alluxio.cli.fs.command
Displays the number of folders and files matching the specified prefix in args.
CountCommand(FileSystemContext) - Constructor for class alluxio.cli.fs.command.CountCommand
 
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
 
create(FileSystemContext) - Static method in class alluxio.client.block.AlluxioBlockStore
Creates an Alluxio block store with default local hostname.
create(MasterClientContext) - Static method in class alluxio.client.block.BlockMasterClient.Factory
Factory method for BlockMasterClient.
create(String, AlluxioConfiguration) - Static method in class alluxio.client.block.policy.BlockLocationPolicy.Factory
Factory for creating BlockLocationPolicy.
create(FileSystemContext, BlockInfo, WorkerNetAddress, BlockInStream.BlockInStreamSource, InStreamOptions) - Static method in class alluxio.client.block.stream.BlockInStream
Creates a BlockInStream.
create(FileSystemContext, long, long, WorkerNetAddress, OutStreamOptions) - Static method in class alluxio.client.block.stream.BlockOutStream
Creates an BlockOutStream.
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 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.LocalFileDataReader.Factory
 
create(FileSystemContext, WorkerNetAddress, long, OutStreamOptions) - Static method in class alluxio.client.block.stream.LocalFileDataWriter
Creates an instance of LocalFileDataWriter.
create(FileSystemContext, WorkerNetAddress, long, long, OutStreamOptions) - Static method in class alluxio.client.block.stream.UfsFallbackLocalFileDataWriter
 
create(FileSystemContext, WorkerNetAddress, OutStreamOptions) - Static method in class alluxio.client.block.stream.UnderFileSystemFileOutStream
Creates an instance of UnderFileSystemFileOutStream that writes to a UFS file.
create(AlluxioConfiguration) - Static method in interface alluxio.client.file.cache.CacheEvictor
 
create(AlluxioConfiguration) - Static method in class alluxio.client.file.cache.LocalCacheManager
 
create() - Static method in interface alluxio.client.file.cache.MetaStore
 
create(PageStoreOptions, boolean) - Static method in interface alluxio.client.file.cache.PageStore
Creates a PageStore.
create(AlluxioConfiguration) - Static method in class alluxio.client.file.cache.store.PageStoreOptions
 
create(RocksPageStoreOptions) - Static method in class alluxio.client.file.cache.store.RocksPageStore
 
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(AlluxioConfiguration) - Static method in class alluxio.client.file.FileSystemContext
Creates a FileSystemContext with a null subject.
create(Subject, AlluxioConfiguration) - Static method in class alluxio.client.file.FileSystemContext
 
create(ClientContext) - Static method in class alluxio.client.file.FileSystemContext
 
create(Subject, MasterInquireClient, AlluxioConfiguration) - Static method in class alluxio.client.file.FileSystemContext
This method is provided for testing, use the FileSystemContext.create(alluxio.conf.AlluxioConfiguration) methods.
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(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(Map<String, AlluxioConfiguration>) - Static method in interface alluxio.conf.path.PathConfiguration
Factory method to create an implementation of PathConfiguration.
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.AlluxioFuseFileSystem
Creates and opens a new file.
create(AlluxioConfiguration) - Static method in class alluxio.grpc.GrpcChannelKey
Creates a GrpcChannelKey.
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(AlluxioURI, PartitionInfo) - Static method in class alluxio.job.plan.transform.format.csv.CsvReader
Creates a CSV reader.
create(AlluxioURI) - Static method in class alluxio.job.plan.transform.format.parquet.ParquetReader
Creates a parquet reader.
create(TableSchema, AlluxioURI) - Static method in class alluxio.job.plan.transform.format.parquet.ParquetWriter
Creates a Parquet writer.
create(TableSchema, AlluxioURI, int, boolean) - Static method in class alluxio.job.plan.transform.format.parquet.ParquetWriter
Creates a Parquet writer specifying a row group size.
create(AlluxioURI, PartitionInfo) - Static method in interface alluxio.job.plan.transform.format.TableReader
 
create(TableSchema, Committer, AlluxioURI) - Static method in class alluxio.job.plan.transform.format.tables.TablesWriter
 
create(TableSchema, AlluxioURI) - Static method in interface alluxio.job.plan.transform.format.TableWriter
 
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(FileSystemMasterView) - Static method in class alluxio.master.file.async.AsyncPersistHandler.Factory
Creates a new instance of AsyncPersistHandler.
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(DeletePOptions.Builder, CallTracker) - Static method in class alluxio.master.file.contexts.DeleteContext
 
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(ListStatusPOptions.Builder, CallTracker) - 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(SetAclPOptions.Builder, CallTracker) - Static method in class alluxio.master.file.contexts.SetAclContext
 
create(SetAttributePOptions.Builder) - Static method in class alluxio.master.file.contexts.SetAttributeContext
 
create(SetAttributePOptions.Builder, CallTracker) - 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(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) - Static method in class alluxio.master.file.meta.UfsAbsentPathCache.Factory
 
create(MountTable) - Static method in class alluxio.master.file.meta.UfsBlockLocationCache.Factory
 
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(RaftJournalConfiguration) - Static method in class alluxio.master.journal.raft.RaftJournalSystem
Creates and initializes a raft journal system.
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(boolean) - Static method in class alluxio.master.LocalAlluxioMaster
Creates a new local Alluxio master with an isolated work directory and port.
create(String, boolean) - 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(CatalogContext, UdbContext, String, String, Map<String, String>) - Static method in class alluxio.master.table.Database
Creates an instance of a database.
create(List<Partition>, Layout, List<FieldSchema>) - Static method in interface alluxio.master.table.PartitionScheme
create a partition scheme object.
create(Database, UdbTable, Table) - Static method in class alluxio.master.table.Table
 
create(Database, Table.AddTableEntry) - Static method in class alluxio.master.table.Table
 
create(MasterRegistry, CoreMasterContext) - Method in class alluxio.master.table.TableMasterFactory
 
create() - Static method in class alluxio.proxy.ProxyProcess.Factory
 
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(Layout) - Method in class alluxio.table.common.layout.HiveLayout.HiveLayoutFactory
 
create(Layout) - Method in interface alluxio.table.common.LayoutFactory
 
create(Layout) - Method in class alluxio.table.common.LayoutRegistry
Creates a new instance of a Layout.
create(String, List<String>, Map<String, String>) - Method in interface alluxio.table.common.transform.action.TransformActionFactory
 
create(String, String, List<String>, Map<String, String>) - Static method in class alluxio.table.common.transform.action.TransformActionRegistry
Creates a new instance of a TransformAction.
create(String, List<String>, Map<String, String>) - Method in class alluxio.table.common.transform.action.WriteAction.WriteActionFactory
 
create(UdbContext, UdbConfiguration) - Method in interface alluxio.table.common.udb.UnderDatabaseFactory
Creates a new instance of the udb.
create(UdbContext, String, UdbConfiguration) - Method in class alluxio.table.common.udb.UnderDatabaseRegistry
Creates a new instance of an UnderDatabase.
create(UdbContext, UdbConfiguration) - Static method in class alluxio.table.under.hive.HiveDatabase
Creates an instance of the Hive database UDB.
create(UdbContext, UdbConfiguration) - Method in class alluxio.table.under.hive.HiveDatabaseFactory
 
create(String) - Method in class alluxio.underfs.BaseUnderFileSystem
 
create(String, UnderFileSystemConfiguration) - Method in class alluxio.underfs.cos.COSUnderFileSystemFactory
 
create(String, UfsStatus) - Static method in class alluxio.underfs.Fingerprint
Parses the input string and returns the fingerprint object.
create(String, UfsStatus, AccessControlList) - Static method in class alluxio.underfs.Fingerprint
Parses the input string and returns the fingerprint object.
create(String, UnderFileSystemConfiguration) - 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, UnderFileSystemConfiguration) - Method in class alluxio.underfs.kodo.KodoUnderFileSystemFactory
 
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.oss.OSSUnderFileSystemFactory
 
create(String, UnderFileSystemConfiguration) - Method in class alluxio.underfs.s3a.S3AUnderFileSystemFactory
 
create(String, UnderFileSystemConfiguration) - Method in class alluxio.underfs.swift.SwiftUnderFileSystemFactory
 
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, CreateOptions) - Method in class alluxio.underfs.web.WebUnderFileSystem
 
create(String, UnderFileSystemConfiguration) - Method in class alluxio.underfs.web.WebUnderFileSystemFactory
 
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() - Method in interface alluxio.util.executor.ExecutorServiceFactory
 
create(BlockMetadataView) - Static method in class alluxio.worker.block.allocator.Allocator.Factory
Factory for Allocator.
create(BlockMetadataManager) - Static method in class alluxio.worker.block.BlockStoreMeta.Factory
Factory method to return a BlockStoreMeta instance without blockIds.
create(WorkerRegistry, UfsManager) - Method in class alluxio.worker.block.BlockWorkerFactory
 
create(BlockMetadataEvictorView, Allocator) - Static method in class alluxio.worker.block.evictor.Evictor.Factory
Factory for Evictor.
create(UnderFileSystemBlockMeta, long, boolean, BlockStore, UfsManager, UfsInputStreamManager) - Static method in class alluxio.worker.block.UnderFileSystemBlockReader
Creates an instance of UnderFileSystemBlockReader and initializes it with a reading offset.
create(String, SocketAddress, WorkerProcess) - Static method in class alluxio.worker.DataServer.Factory
Factory for DataServer.
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(WorkerRegistry, UfsManager) - Method in interface alluxio.worker.WorkerFactory
Factory method to create a new worker instance.
create() - Static method in class alluxio.worker.WorkerProcess.Factory
 
create(TieredIdentity) - Static method in class alluxio.worker.WorkerProcess.Factory
 
CREATE_DIRECTORY - Static variable in class alluxio.proxy.PathsRestServiceHandler
 
CREATE_FILE - Static variable in class alluxio.proxy.PathsRestServiceHandler
 
CREATE_UFS_BLOCK_OPTIONS_FIELD_NUMBER - Static variable in class alluxio.grpc.WriteRequestCommand
 
CREATE_UFS_FILE_OPTIONS_FIELD_NUMBER - Static variable in class alluxio.grpc.WriteRequestCommand
 
CREATEANCESTORS_FIELD_NUMBER - Static variable in class alluxio.grpc.LoadMetadataPOptions
 
createAndAbortMultipartFileTest() - Method in class alluxio.examples.S3ASpecificOperations
Test for creating and aborting a multipart file.
createAtomicTest() - Method in class alluxio.examples.UnderFileSystemCommonOperations
Test for creating file atomic.
createAwsCredentialsProvider(UnderFileSystemConfiguration) - Static method in class alluxio.underfs.s3a.S3AUnderFileSystem
 
createBlock(long, long, BlockStoreLocation, long) - Method in interface alluxio.worker.block.BlockStore
Creates the metadata of a new block and assigns a temporary path (e.g., a subdir of the final location named after session id) to store its data.
createBlock(long, long, String, String, long) - Method in interface alluxio.worker.block.BlockWorker
Creates a block in Alluxio managed space for short-circuit writes.
createBlock(long, long, String, String, long) - Method in class alluxio.worker.block.DefaultBlockWorker
 
createBlock(long, long, BlockStoreLocation, long) - Method in class alluxio.worker.block.TieredBlockStore
 
createBlockId(long, long) - Static method in class alluxio.master.block.BlockId
 
createBlockMetadataManager() - Static method in class alluxio.worker.block.BlockMetadataManager
Creates a new instance of BlockMetadataManager.
createBlockPath(String, String) - Static method in class alluxio.util.io.FileUtils
Creates the local block path and all the parent directories.
createBlockRemote(long, long, String, String, long) - Method in interface alluxio.worker.block.BlockWorker
Creates a block for non short-circuit writes or caching requests.
createBlockRemote(long, long, String, String, long) - Method in class alluxio.worker.block.DefaultBlockWorker
 
createBucket(String) - Method in class alluxio.proxy.s3.S3RestServiceHandler
 
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_VALUE - Static variable in enum alluxio.grpc.Status
CREATED = 1;
createDataReader(BlockReadRequestContext, StreamObserver<ReadResponse>) - Method in class alluxio.worker.grpc.BlockReadHandler
 
createDeleteFileConjuctionTest() - Method in class alluxio.examples.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.hdfs.HdfsUnderFileSystem
 
createDirect(String, CreateOptions) - Method in class alluxio.underfs.local.LocalUnderFileSystem
 
createDirectory(AlluxioURI, CreateDirectoryPOptions) - Method in class alluxio.client.file.BaseFileSystem
 
createDirectory(AlluxioURI, CreateDirectoryPOptions) - Method in class alluxio.client.file.DelegatingFileSystem
 
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.RetryHandlingFileSystemMasterClient
 
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.FileSystemMasterClientServiceImplBase
Creates a directory.
createDirectory(CreateDirectoryPRequest, StreamObserver<CreateDirectoryPResponse>) - Method in class alluxio.grpc.FileSystemMasterClientServiceGrpc.FileSystemMasterClientServiceStub
Creates a directory.
createDirectory(AlluxioURI, CreateDirectoryPOptions) - Method in class alluxio.hadoop.AlluxioHdfsFileSystem
 
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
 
CreateDirectoryContext - Class in alluxio.master.file.contexts
Used to merge and wrap CreateDirectoryPOptions.
createDirectoryDefaults(AlluxioConfiguration) - Static method in class alluxio.util.FileSystemOptions
 
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
 
createEmptyFileTest() - Method in class alluxio.examples.S3ASpecificOperations
Test for creating an empty file using streaming upload.
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.kodo.KodoClient
Creates empty Object in Qiniu kodo.
createEmptyObject(String) - Method in class alluxio.underfs.kodo.KodoUnderFileSystem
 
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.oss.OSSUnderFileSystem
 
createEmptyObject(String) - Method in class alluxio.underfs.s3a.S3AUnderFileSystem
 
createEmptyObject(String) - Method in class alluxio.underfs.swift.SwiftUnderFileSystem
 
createEmptyTest() - Method in class alluxio.examples.UnderFileSystemCommonOperations
Test for creating empty file.
createEventLoop(ChannelType, int, String, boolean) - Static method in class alluxio.util.network.NettyUtils
Creates a Netty EventLoopGroup based on ChannelType.
createFile(AlluxioURI, CreateFilePOptions) - Method in class alluxio.client.file.BaseFileSystem
 
createFile(AlluxioURI, CreateFilePOptions) - Method in class alluxio.client.file.DelegatingFileSystem
 
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.RetryHandlingFileSystemMasterClient
 
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.FileSystemMasterClientServiceImplBase
Creates a file.
createFile(CreateFilePRequest, StreamObserver<CreateFilePResponse>) - Method in class alluxio.grpc.FileSystemMasterClientServiceGrpc.FileSystemMasterClientServiceStub
Creates a file.
createFile(AlluxioURI, CreateFilePOptions) - Method in class alluxio.hadoop.AlluxioHdfsFileSystem
 
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.
CreateFileContext - Class in alluxio.master.file.contexts
Implementation of OperationContext used to merge and wrap CreateFilePOptions.
createFileDefaults(AlluxioConfiguration) - Static method in class alluxio.util.FileSystemOptions
 
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.examples.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
 
createFileSystemContextId() - Static method in class alluxio.util.IdUtils
 
createForJobMaster(AlluxioConfiguration, UserState) - Static method in class alluxio.master.MasterInquireClient.Factory
 
createForRoot(AlluxioConfiguration) - Static method in class alluxio.underfs.UnderFileSystem.Factory
 
createFull(BlockMetadataManager) - Static method in class alluxio.worker.block.BlockStoreMeta.Factory
Factory method to return a BlockStoreMeta instance with blockIds.
createFullAccess() - Static method in class alluxio.security.authorization.Mode
Creates the "full access" mode.
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.gcs.GCSUnderFileSystem
Constructs a new instance of GCSUnderFileSystem.
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.oss.OSSUnderFileSystem
Constructs a new instance of OSSUnderFileSystem.
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
 
createIterator(RocksIterator, RocksUtils.RocksIteratorParser<T>) - Static method in class alluxio.master.metastore.rocks.RocksUtils
Used to wrap an Iterator over RocksIterator.
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 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
 
createLocalBlock(StreamObserver<CreateLocalBlockResponse>) - Method in interface alluxio.client.block.stream.BlockWorkerClient
Creates a local block on the worker.
createLocalBlock(StreamObserver<CreateLocalBlockResponse>) - Method in class alluxio.client.block.stream.DefaultBlockWorkerClient
 
createLocalBlock(StreamObserver<CreateLocalBlockResponse>) - Method in class alluxio.grpc.BlockWorkerGrpc.BlockWorkerImplBase
Replaces ShortCircuitBlockWriteHandler.
createLocalBlock(StreamObserver<CreateLocalBlockResponse>) - Method in class alluxio.grpc.BlockWorkerGrpc.BlockWorkerStub
Replaces ShortCircuitBlockWriteHandler.
createLocalBlock(StreamObserver<CreateLocalBlockResponse>) - Method in class alluxio.worker.grpc.BlockWorkerImpl
 
CreateLocalBlockRequest - Class in alluxio.grpc
next available id: 9
CreateLocalBlockRequest.Builder - Class in alluxio.grpc
next available id: 9
CreateLocalBlockRequestOrBuilder - Interface in alluxio.grpc
 
CreateLocalBlockResponse - Class in alluxio.grpc
next available id: 2
CreateLocalBlockResponse.Builder - Class in alluxio.grpc
next available id: 2
CreateLocalBlockResponseOrBuilder - Interface in alluxio.grpc
 
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.
createMountId() - Static method in class alluxio.util.IdUtils
 
createMountSpecificConf(Map<String, String>) - Method in class alluxio.underfs.UnderFileSystemConfiguration
Creates a new instance from the current configuration and adds in new properties.
createMultipartFileTest() - Method in class alluxio.examples.S3ASpecificOperations
Test for creating a multipart file.
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.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.table.under.hive.util.HiveClientPool
 
createNewResource() - Method in class alluxio.worker.block.BlockMasterClientPool
 
createNext(UdbPartition) - Method in class alluxio.master.table.Partition
Creates the next version of an existing partition.
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.examples.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.kodo.KodoUnderFileSystem
 
createObject(String) - Method in class alluxio.underfs.ObjectUnderFileSystem
Creates an OutputStream for object uploads.
createObject(String) - Method in class alluxio.underfs.oss.OSSUnderFileSystem
 
createObject(String) - Method in class alluxio.underfs.s3a.S3AUnderFileSystem
 
createObject(String) - Method in class alluxio.underfs.swift.SwiftUnderFileSystem
 
createObjectOrUploadPart(String, String, String, Integer, Long, InputStream) - Method in class alluxio.proxy.s3.S3RestServiceHandler
 
createOpenAtPositionTest() - Method in class alluxio.examples.UnderFileSystemCommonOperations
Test for creating file and opening at position.
createOpenEmptyTest() - Method in class alluxio.examples.UnderFileSystemCommonOperations
Test for creating and opening empty file.
createOpenExistingLargeFileTest() - Method in class alluxio.examples.UnderFileSystemCommonOperations
Test for creating and open existing large file.
createOpenFilesLimitValidationTask() - Static method in class alluxio.cli.validation.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.examples.UnderFileSystemCommonOperations
Test for creating and opening large file.
createOpenSkip() - Method in class alluxio.examples.UnderFileSystemCommonOperations
Test for create file, open and seek.
createOpenTest() - Method in class alluxio.examples.UnderFileSystemCommonOperations
Test for creating and opening file.
CreateOptions - Class in alluxio.underfs.options
Method options for creating a file in UnderFileSystem.
createOrGetAppIdFromConfig(AlluxioConfiguration) - Static method in class alluxio.util.IdUtils
 
createParentTest() - Method in class alluxio.examples.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> - 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.
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.
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
 
createRemoteBlockInStream(FileSystemContext, long, WorkerNetAddress, BlockInStream.BlockInStreamSource, long, Protocol.OpenUfsBlockOptions) - Static method in class alluxio.client.block.stream.BlockInStream
Creates a BlockInStream to read from a specific remote server.
createReplicatedBlockOutStream(FileSystemContext, long, long, List<WorkerNetAddress>, OutStreamOptions) - Static method in class alluxio.client.block.stream.BlockOutStream
Creates a new remote block output stream.
createRequestContext(ReadRequest) - Method in class alluxio.worker.grpc.BlockReadHandler
 
createRequestContext(WriteRequest) - Method in class alluxio.worker.grpc.BlockWriteHandler
 
createRequestContext(WriteRequest) - Method in class alluxio.worker.grpc.UfsFallbackBlockWriteHandler
 
createRequestContext(WriteRequest) - Method in class alluxio.worker.grpc.UfsFileWriteHandler
 
createRpcContext() - Method in class alluxio.master.file.DefaultFileSystemMaster
 
createRpcId() - Static method in class alluxio.util.IdUtils
 
createSaslHandler(ChannelAuthenticationScheme) - Method in interface alluxio.security.authentication.AuthenticationServer
Creates server-side Sasl handler for given scheme.
createSaslHandler(ChannelAuthenticationScheme) - Method in class alluxio.security.authentication.DefaultAuthenticationServer
 
createSaslServer(String, String, String, Map<String, ?>, CallbackHandler) - Method in class alluxio.security.authentication.plain.PlainSaslServer.Factory
Creates a SaslServer using the parameters supplied.
createSerializer() - Static method in class alluxio.master.journal.raft.RaftJournalSystem
 
createSessionId() - Static method in class alluxio.util.IdUtils
 
createStorageDirPath(String, String) - Static method in class alluxio.util.io.FileUtils
Creates the storage directory path, including any necessary but nonexistent parent directories.
createStream(long, long) - Method in class alluxio.underfs.cos.COSInputStream
 
createStream(long, long) - Method in class alluxio.underfs.kodo.KodoInputStream
 
createStream(long, long) - Method in class alluxio.underfs.MultiRangeObjectInputStream
Opens a new stream reading a range.
createStream(long, long) - Method in class alluxio.underfs.oss.OSSInputStream
 
createStream(long, long) - Method in class alluxio.underfs.swift.SwiftInputStream
 
createTable(String, Schema) - Method in class alluxio.master.table.Database
Creates a new table within this database.
createTempBlockMeta(long, long, long) - Method in class alluxio.worker.block.meta.StorageDirView
Creates a TempBlockMeta given sessionId, blockId, and initialBlockSize.
createThenDeleteExistingDirectoryTest() - Method in class alluxio.examples.UnderFileSystemCommonOperations
Test for creating and deleting existing directory.
createThenGetExistingDirectoryStatusTest() - Method in class alluxio.examples.UnderFileSystemCommonOperations
Test for getting existing directory status.
createThenGetExistingFileStatusTest() - Method in class alluxio.examples.UnderFileSystemCommonOperations
Test for getting existing file status.
createThenGetExistingStatusTest() - Method in class alluxio.examples.UnderFileSystemCommonOperations
Test for getting existing status.
createUserProcessesLimitValidationTask() - Static method in class alluxio.cli.validation.UserLimitValidationTask
Creates a validation task for checking whether the user limit for number of user processes is within reasonable range.
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
 
creatInstance(AlluxioURI, UnderFileSystemConfiguration) - Static method in class alluxio.underfs.kodo.KodoUnderFileSystem
 
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
 
CSV_FILE_HEADER - Static variable in class alluxio.cli.docgen.ConfigurationDocGenerator
 
CSV_SERDE_CLASS - Static variable in class alluxio.job.plan.transform.HiveConstants
CSV serde class.
CsvReader - Class in alluxio.job.plan.transform.format.csv
A reader for reading CsvRow.
CsvRow - Class in alluxio.job.plan.transform.format.csv
A row in a CSV table represented in Avro format.
CsvRow(CsvSchema, GenericData.Record) - Constructor for class alluxio.job.plan.transform.format.csv.CsvRow
 
CsvSchema - Class in alluxio.job.plan.transform.format.csv
CSV table schema in Avro format.
CsvSchema(ArrayList<FieldSchema>) - Constructor for class alluxio.job.plan.transform.format.csv.CsvSchema
CsvReader uses AvroCSVReader to read records from CSV.
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.
CsvUtils - Class in alluxio.job.plan.transform.format.csv
Utilities for implementing csv reader and writer.
CsvWriter - Class in alluxio.job.plan.transform.format.csv
A writer for writing CsvRow.
CsvWriter() - Constructor for class alluxio.job.plan.transform.format.csv.CsvWriter
 
CUR_DIR - Static variable in class alluxio.AlluxioURI
 
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_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(String) - Constructor for class alluxio.security.authentication.plain.CustomAuthenticationProvider
Constructs a new custom authentication provider.

D

DailyMetadataBackup - Class in alluxio.master.meta
Backing up primary master metadata everyday at a fixed UTC time.
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.table.ColumnStatisticsInfo
 
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 - Class in alluxio.master.table
The database implementation that manages a collection of tables.
Database.Builder - Class in alluxio.grpc.table
Protobuf type alluxio.grpc.table.Database
DATABASE_FIELD_NUMBER - Static variable in class alluxio.grpc.table.GetAllDatabasesPResponse
 
DATABASE_FIELD_NUMBER - Static variable in class alluxio.grpc.table.GetAllTablesPRequest
 
DatabaseInfo - Class in alluxio.master.table
The database information class.
DatabaseInfo(String, String, PrincipalType, String, Map<String, String>) - Constructor for class alluxio.master.table.DatabaseInfo
Full constructor for database info.
DatabaseOrBuilder - Interface in alluxio.grpc.table
 
DataBuffer - Interface in alluxio.network.protocol.databuffer
This interface is a simple wrapper for the optional data that an RPCMessage may have.
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.
DataServer - Interface in alluxio.worker
Defines how to interact with a server running the data protocol.
DataServer.Factory - Class in alluxio.worker
Factory for DataServer.
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 - Static variable in class alluxio.job.plan.transform.HiveConstants.Types
Hive date type.
Date.Builder - Class in alluxio.grpc.table
Protobuf type alluxio.grpc.table.Date
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
 
DateOrBuilder - Interface in alluxio.grpc.table
 
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_FIELD_NUMBER - Static variable in class alluxio.grpc.table.GetDatabasePResponse
 
DB_IGNORE_TABLES - Static variable in class alluxio.master.table.CatalogProperty
 
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
 
DB_NAME_FIELD_NUMBER - Static variable in class alluxio.proto.journal.Table.AddTableEntry
 
DB_NAME_FIELD_NUMBER - Static variable in class alluxio.proto.journal.Table.AddTransformJobInfoEntry
 
DB_NAME_FIELD_NUMBER - Static variable in class alluxio.proto.journal.Table.AttachDbEntry
 
DB_NAME_FIELD_NUMBER - Static variable in class alluxio.proto.journal.Table.CompleteTransformTableEntry
 
DB_NAME_FIELD_NUMBER - Static variable in class alluxio.proto.journal.Table.DetachDbEntry
 
DB_NAME_FIELD_NUMBER - Static variable in class alluxio.proto.journal.Table.RemoveTableEntry
 
DB_NAME_FIELD_NUMBER - Static variable in class alluxio.proto.journal.Table.RemoveTransformJobInfoEntry
 
DB_NAME_FIELD_NUMBER - Static variable in class alluxio.proto.journal.Table.UpdateDatabaseInfoEntry
 
DB_SYNC_THREADS - Static variable in class alluxio.master.table.CatalogProperty
 
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
 
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
 
dec() - Method in class alluxio.concurrent.CountingLatch
Decreases the counter.
decide(LoggingEvent) - Method in class alluxio.AlluxioRemoteLogFilter
 
Decimal - Class in alluxio.grpc.table
Protobuf type alluxio.grpc.table.Decimal
Decimal - Class in alluxio.job.plan.transform.format.csv
Logical decimal type in Parquet.
Decimal(String) - Constructor for class alluxio.job.plan.transform.format.csv.Decimal
 
DECIMAL - Static variable in class alluxio.job.plan.transform.HiveConstants.Types
Hive decimal type.
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.
decompress(String, File) - Static method in class alluxio.cli.bundler.TarUtils
Decompresses a tarball to one destination.
decreaseUsageCount() - Method in class alluxio.worker.block.io.LocalFileBlockReader
decrease the file reader usage count.
decrementPendingCountUnlessZero() - Method in class alluxio.concurrent.jsr.CountedCompleter
If the pending count is nonzero, (atomically) decrements it.
DEFAULT - Static variable in class alluxio.conf.Source
 
DEFAULT_ACL_FIELD_NUMBER - Static variable in class alluxio.proto.meta.InodeMeta.Inode
 
DEFAULT_DB_SYNC_THREADS - Static variable in class alluxio.master.table.CatalogProperty
 
DEFAULT_FILE_SYSTEM_MODE - Static variable in class alluxio.Constants
 
DEFAULT_FILE_SYSTEM_UMASK - Static variable in class alluxio.Constants
 
DEFAULT_REGISTRY_GET_TIMEOUT_MS - Static variable in class alluxio.Constants
 
DEFAULT_TEST_NAME - Static variable in class alluxio.master.LocalAlluxioCluster
 
DEFAULT_TRANSFORMATION - Static variable in class alluxio.master.table.DefaultTableMaster
 
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
 
defaultActiveSyncClientRetry(long) - Static method in class alluxio.retry.RetryUtils
 
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.Metrics - Class in alluxio.master.block
Class that contains metrics related to BlockMaster.
defaultBlockReadRetry(Duration, Duration, Duration) - Static method in class alluxio.retry.RetryUtils
Gives a ClientRetry based on the given parameters.
DefaultBlockStoreMeta - Class in alluxio.worker.block
This class holds the metadata information of a block store.
DefaultBlockStoreMeta(BlockMetadataManager, boolean) - Constructor for class alluxio.worker.block.DefaultBlockStoreMeta
Creates a new instance of DefaultBlockStoreMeta.
DefaultBlockWorker - Class in alluxio.worker.block
The class is responsible for managing all top level components of the Block Worker.
DefaultBlockWorker.Metrics - Class in alluxio.worker.block
This class contains some metrics related to the block worker.
DefaultBlockWorker.StorageChecker - Class in alluxio.worker.block
StorageChecker periodically checks the health of each storage path and report missing blocks to BlockWorker.
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.
defaultClientRetry(Duration, Duration, Duration) - Static method in class alluxio.retry.RetryUtils
Gives a ClientRetry based on the given parameters.
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) - 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.
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, JournalSystem) - 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.
DefaultMetaStore - Class in alluxio.client.file.cache
The default implementation of a metadata store for pages stored in cache.
DefaultMetaStore() - Constructor for class alluxio.client.file.cache.DefaultMetaStore
 
defaultMetricsClientRetry() - Static method in class alluxio.retry.RetryUtils
 
DefaultMetricsMaster - Class in alluxio.master.metrics
Default implementation of the metrics master.
defaultOptions() - Static method in class alluxio.resource.DynamicResourcePool.Options
 
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.
DefaultReplicationHandler - Class in alluxio.job.plan.replicate
The implementation of ReplicationHandler that utilizes job service.
DefaultReplicationHandler(JobMasterClientPool) - Constructor for class alluxio.job.plan.replicate.DefaultReplicationHandler
Creates a new instance of DefaultReplicationHandler.
defaults() - Static method in class alluxio.client.block.options.GetWorkerReportOptions
 
defaults() - Static method in class alluxio.client.block.policy.options.GetWorkerOptions
 
defaults(ClientContext, AlluxioConfiguration) - Static method in class alluxio.client.file.options.OutStreamOptions
 
defaults(ClientContext) - Static method in class alluxio.client.file.options.OutStreamOptions
 
defaults() - Static method in class alluxio.conf.ConfigurationValueOptions
 
defaults() - Static method in class alluxio.conf.InstancedConfiguration
Users should use this API to obtain a configuration for modification before passing to a FileSystem constructor.
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.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(NetworkAddressUtils.ServiceType) - Static method in class alluxio.master.journal.raft.RaftJournalConfiguration
 
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.proxy.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.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.ConfigurationUtils
Returns an instance of AlluxioConfiguration with the defaults and values from alluxio-site properties.
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.
defaultsForDailyBackup() - Static method in class alluxio.master.StateLockOptions
 
defaultsForShellBackup() - Static method in class alluxio.master.StateLockOptions
 
DefaultSupplier - Class in alluxio
Supplier for a configuration property default.
DefaultSupplier(Supplier<Object>, String) - Constructor for class alluxio.DefaultSupplier
 
DefaultTableMaster - Class in alluxio.master.table
This table master manages catalogs metadata information.
DefaultTableMaster(CoreMasterContext, JobMasterClient) - Constructor for class alluxio.master.table.DefaultTableMaster
Constructor for DefaultTableMaster.
defaultWorkerMasterClientRetry(Duration) - Static method in class alluxio.retry.RetryUtils
 
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
 
DEFINITION_FIELD_NUMBER - Static variable in class alluxio.proto.journal.Table.AddTransformJobInfoEntry
 
DEFINITION_FIELD_NUMBER - Static variable in class alluxio.proto.journal.Table.CompleteTransformTableEntry
 
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
 
DelegationWriteHandler - Class in alluxio.worker.grpc
A write request handler that delegate worker write request of different types to corresponding write handlers.
DelegationWriteHandler(WorkerProcess, StreamObserver<WriteResponse>, AuthenticatedUserInfo, boolean) - Constructor for class alluxio.worker.grpc.DelegationWriteHandler
 
delete(AlluxioURI, DeletePOptions) - Method in class alluxio.client.file.BaseFileSystem
 
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.LocalCacheManager
 
delete(PageId) - Method in class alluxio.client.file.cache.NoExceptionCacheManager
 
delete(PageId, long) - Method in interface alluxio.client.file.cache.PageStore
Deletes a page from the store.
delete(PageId, long) - Method in class alluxio.client.file.cache.store.LocalPageStore
 
delete(PageId, long) - Method in class alluxio.client.file.cache.store.RocksPageStore
 
delete(AlluxioURI, DeletePOptions) - Method in class alluxio.client.file.DelegatingFileSystem
 
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.RetryHandlingFileSystemMasterClient
 
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(AlluxioURI, DeletePOptions) - Method in class alluxio.hadoop.AlluxioHdfsFileSystem
 
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_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_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) - Method in class alluxio.proxy.s3.S3RestServiceHandler
 
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.FileSystemOptions
 
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.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
 
deleteDirectory(String, DeleteOptions) - Method in class alluxio.underfs.web.WebUnderFileSystem
 
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.examples.UnderFileSystemCommonOperations
Test for deleting directory.
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
 
deleteFile(String) - Method in class alluxio.concurrent.ManagedBlockingUfsForwarder
 
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
 
deleteFile(String) - Method in class alluxio.underfs.web.WebUnderFileSystem
 
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.examples.UnderFileSystemCommonOperations
Test for deleting file.
deleteIf(String, Function<TrieNode, Boolean>) - Method in class alluxio.conf.path.TrieNode
Deletes the path from the Trie if the given predicate is true.
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) - Method in class alluxio.master.file.DefaultFileSystemMaster
Implements file deletion.
deleteLargeDirectoryTest() - Method in class alluxio.examples.UnderFileSystemCommonOperations
Test for deleting large directory.
deleteLeaf(T) - Method in class alluxio.collections.DirectedAcyclicGraph
Deletes a leaf DAG node that carries the given payload.
deleteObject(String) - Method in class alluxio.underfs.cos.COSUnderFileSystem
 
deleteObject(String) - Method in class alluxio.underfs.gcs.GCSUnderFileSystem
 
deleteObject(String) - Method in class alluxio.underfs.kodo.KodoClient
Deletes Object in Qiniu kodo.
deleteObject(String) - Method in class alluxio.underfs.kodo.KodoUnderFileSystem
 
deleteObject(String) - Method in class alluxio.underfs.ObjectUnderFileSystem
Internal function to delete a key.
deleteObject(String) - Method in class alluxio.underfs.oss.OSSUnderFileSystem
 
deleteObject(String) - Method in class alluxio.underfs.s3a.S3AUnderFileSystem
 
deleteObject(String) - Method in class alluxio.underfs.swift.SwiftUnderFileSystem
 
deleteObjectOrAbortMultipartUpload(String, String, Long) - Method in class alluxio.proxy.s3.S3RestServiceHandler
 
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.s3a.S3AUnderFileSystem
 
DeleteOptions - Class in alluxio.underfs.options
Method options for deleting a directory in UnderFileSystem.
deletePathRecursively(String) - Static method in class alluxio.util.io.FileUtils
Deletes a file or a directory, recursively if it is a directory.
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
 
DependencyDoesNotExistException - Exception in alluxio.exception
The exception thrown when a dependency does not exist in Alluxio.
DependencyDoesNotExistException(String) - Constructor for exception alluxio.exception.DependencyDoesNotExistException
Constructs a new exception with the specified detail message.
DependencyDoesNotExistException(String, Throwable) - Constructor for exception alluxio.exception.DependencyDoesNotExistException
Constructs a new exception with the specified detail message and cause.
DependencyDoesNotExistException(ExceptionMessage, Object...) - Constructor for exception alluxio.exception.DependencyDoesNotExistException
Constructs a new exception with the specified exception message and multiple parameters.
DependencyDoesNotExistException(ExceptionMessage, Throwable, Object...) - Constructor for exception alluxio.exception.DependencyDoesNotExistException
Constructs a new exception with the specified exception message, the cause and multiple parameters.
Deprecated - Annotation Type in alluxio.conf
An annotation for PropertyKeys that can be used to mark a key as deprecated (slated for removal).
DeprecatedKeyChecker - Class in alluxio.conf
This annotation checker should be used to determine whether a PropertyKey or PropertyKey.Template has a given annotation.
DeprecatedKeyChecker() - Constructor for class alluxio.conf.DeprecatedKeyChecker
Create a new instance of DeprecatedKeyChecker.
DescendantType - Enum in alluxio.file.options
Type of descendant level processing for filesystem inodes.
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.PathConfCommand
 
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.QuorumInfoCommand
 
description() - Static method in class alluxio.cli.fsadmin.journal.QuorumRemoveCommand
 
description() - Static method in class alluxio.cli.fsadmin.metrics.ClearCommand
 
description() - Static method in class alluxio.cli.fsadmin.pathconf.AddCommand
 
description() - Static method in class alluxio.cli.fsadmin.pathconf.ListCommand
 
description() - Static method in class alluxio.cli.fsadmin.pathconf.RemoveCommand
 
description() - Static method in class alluxio.cli.fsadmin.pathconf.ShowCommand
 
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(JsonParser, DeserializationContext) - Method in class alluxio.security.authorization.AccessControlList.AccessControlListDeserializer
Deserialize an AccessControlList object.
destroy() - Method in class alluxio.multi.process.MultiProcessCluster
Destroys the cluster.
DETACH_DB_FIELD_NUMBER - Static variable in class alluxio.proto.journal.Journal.JournalEntry
 
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) - 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.TableMasterClientServiceImplBase
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
detachDatabase(JournalContext, String) - Method in class alluxio.master.table.AlluxioCatalog
Removes an existing database.
detachDatabase(String) - Method in class alluxio.master.table.DefaultTableMaster
 
detachDatabase(String) - Method in interface alluxio.master.table.TableMaster
Remove an existing database in the catalog.
detachDatabase(DetachDatabasePRequest, StreamObserver<DetachDatabasePResponse>) - Method in class alluxio.master.table.TableMasterClientServiceHandler
 
DetachDatabaseCommand - Class in alluxio.cli.table.command
This command removes a database from the table master.
DetachDatabaseCommand(AlluxioConfiguration, TableMasterClient) - Constructor for class alluxio.cli.table.command.DetachDatabaseCommand
Creates a new instance of DetachDatabaseCommand.
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
 
DeterministicHashPolicy - Class in alluxio.client.block.policy
This policy maps blockId to several deterministic Alluxio workers.
DeterministicHashPolicy(AlluxioConfiguration) - Constructor for class alluxio.client.block.policy.DeterministicHashPolicy
Constructs a new DeterministicHashPolicy.
dir() - Method in class alluxio.worker.block.BlockStoreLocation
Gets the directory index of the location.
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
 
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.
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.
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
 
disconnect() - Method in class alluxio.AbstractClient
Closes the connection with the Alluxio remote and does the necessary cleanup.
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
 
DistributedCpCommand - Class in alluxio.cli.fs.command
Copies a file or directory specified by args.
DistributedCpCommand(FileSystemContext) - Constructor for class alluxio.cli.fs.command.DistributedCpCommand
 
DistributedLoadCommand - Class in alluxio.cli.fs.command
Loads a file or directory in Alluxio space, makes it resident in memory.
DistributedLoadCommand(FileSystemContext) - Constructor for class alluxio.cli.fs.command.DistributedLoadCommand
Constructs a new instance to load a file or directory in Alluxio space.
DistributedMvCommand - Class in alluxio.cli.fs.command
Moves a file or directory specified by args.
DistributedMvCommand(FileSystemContext) - Constructor for class alluxio.cli.fs.command.DistributedMvCommand
 
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
 
Domain - Class in alluxio.grpc.table
Protobuf type alluxio.grpc.table.Domain
Domain<T> - Class in alluxio.master.table
Domain represetation to check values.
Domain() - Constructor for class alluxio.master.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
 
DOUBLE - Static variable in class alluxio.job.plan.transform.HiveConstants.Types
Hive double type.
DOUBLE_STATS_FIELD_NUMBER - Static variable in class alluxio.grpc.table.ColumnStatisticsData
 
DOUBLE_TYPE_FIELD_NUMBER - Static variable in class alluxio.grpc.table.Value
 
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
 
downgradeEdgeToInode(Inode, LockMode) - Method in class alluxio.master.file.meta.CompositeInodeLockList
 
downgradeEdgeToInode(Inode, LockMode) - Method in interface alluxio.master.file.meta.InodeLockList
Downgrades from edge write-locking to inode write-locking.
downgradeEdgeToInode(Inode, LockMode) - Method in class alluxio.master.file.meta.SimpleInodeLockList
 
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
 
downgradeLastInode() - Method in class alluxio.master.file.meta.CompositeInodeLockList
 
downgradeLastInode() - Method in interface alluxio.master.file.meta.InodeLockList
Downgrades the last inode from a write lock to a read lock.
downgradeLastInode() - Method in class alluxio.master.file.meta.SimpleInodeLockList
 
downgradeToPattern(InodeTree.LockPattern) - Method in class alluxio.master.file.meta.LockedInodePath
Downgrades from the current locking scheme to the desired locking scheme.
DOWNLOAD_FILE - Static variable in class alluxio.proxy.PathsRestServiceHandler
 
downloadFile(String) - Method in class alluxio.proxy.PathsRestServiceHandler
 
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.
dropReference() - Method in class alluxio.worker.block.ClientRWLock
Decrements the reference count.
DST_PATH_FIELD_NUMBER - Static variable in class alluxio.proto.journal.File.RenameEntry
 
DSTPATH_FIELD_NUMBER - Static variable in class alluxio.grpc.RenamePRequest
 
DuCommand - Class in alluxio.cli.fs.command
Displays the size of a file or a directory specified by argv.
DuCommand(FileSystemContext) - Constructor for class alluxio.cli.fs.command.DuCommand
 
dumpJournal() - Method in class alluxio.master.journal.tool.UfsJournalDumper
 
DynamicResourcePool<T> - Class in alluxio.resource
A dynamic pool that manages the resources.
DynamicResourcePool(DynamicResourcePool.Options) - Constructor for class alluxio.resource.DynamicResourcePool
Creates a dynamic pool instance.
DynamicResourcePool.Options - Class in alluxio.resource
Options to initialize a Dynamic resource pool.
DynamicResourcePool.ResourceInternal<R> - Class in alluxio.resource
A wrapper on the resource to include the last time at which it was used.

E

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
 
ElapsedTimeClock - Class in alluxio.clock
A monotonically increasing clock for calculating elapsed time.
ElapsedTimeClock() - Constructor for class alluxio.clock.ElapsedTimeClock
 
EMBEDDED_JOURNAL_FAILOVER - Static variable in class alluxio.multi.process.PortCoordination
 
EMBEDDED_JOURNAL_GROW - Static variable in class alluxio.multi.process.PortCoordination
 
EMBEDDED_JOURNAL_GROW_NEWMASTER - 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
 
EMPTY_ACL - Static variable in class alluxio.security.authorization.AccessControlList
 
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
 
emptyInfo() - Static method in class alluxio.SyncInfo
Returns an empty SyncInfo object.
encode(T) - Method in interface alluxio.master.file.meta.xattr.ExtendedAttribute
Encode a single object into a byte string.
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
 
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).
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
 
EnvironmentUtils - Class in alluxio.util
Utilities to detect environment Alluxio is running in.
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.
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.client.block.options.GetWorkerReportOptions
 
equals(Object) - Method in class alluxio.client.block.policy.DeterministicHashPolicy
 
equals(Object) - Method in class alluxio.client.block.policy.LocalFirstAvoidEvictionPolicy
 
equals(Object) - Method in class alluxio.client.block.policy.LocalFirstPolicy
 
equals(Object) - Method in class alluxio.client.block.policy.MostAvailableFirstPolicy
 
equals(Object) - Method in class alluxio.client.block.policy.options.GetWorkerOptions
 
equals(Object) - Method in class alluxio.client.block.policy.RoundRobinPolicy
 
equals(Object) - Method in class alluxio.client.block.policy.SpecificHostPolicy
 
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.FileSystemCache.Key
 
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.collections.DelegatingSet
 
equals(Object) - Method in class alluxio.collections.Pair
 
equals(Object) - Method in class alluxio.collections.TwoKeyConcurrentMap
The equals implementation for this map simply uses the superclass's equals.
equals(Object) - Method in class alluxio.conf.PropertyKey
 
equals(Object) - Method in class alluxio.conf.Source
 
equals(Object) - Method in class alluxio.grpc.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.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.BlockStoreLocationProto
 
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.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.Command
 
equals(Object) - Method in class alluxio.grpc.CommitBlockInUfsPOptions
 
equals(Object) - Method in class alluxio.grpc.CommitBlockInUfsPRequest
 
equals(Object) - Method in class alluxio.grpc.CommitBlockInUfsPResponse
 
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.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.CreateLocalBlockRequest
 
equals(Object) - Method in class alluxio.grpc.CreateLocalBlockResponse
 
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.ExistsPOptions
 
equals(Object) - Method in class alluxio.grpc.FileBlockInfo
 
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.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.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.GetJobServiceSummaryPOptions
 
equals(Object) - Method in class alluxio.grpc.GetJobServiceSummaryPRequest
 
equals(Object) - Method in class alluxio.grpc.GetJobServiceSummaryPResponse
 
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.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.GetPinnedFileIdsPOptions
 
equals(Object) - Method in class alluxio.grpc.GetPinnedFileIdsPRequest
 
equals(Object) - Method in class alluxio.grpc.GetPinnedFileIdsPResponse
 
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.GetServiceVersionPRequest
 
equals(Object) - Method in class alluxio.grpc.GetServiceVersionPResponse
 
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.GetSyncPathListPRequest
 
equals(Object) - Method in class alluxio.grpc.GetSyncPathListPResponse
 
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.GrpcChannelKey
 
equals(Object) - Method in class alluxio.grpc.GrpcConnection
 
equals(Object) - Method in class alluxio.grpc.GrpcConnectionKey
 
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.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.JobServiceSummary
 
equals(Object) - Method in class alluxio.grpc.JobUnused
 
equals(Object) - Method in class alluxio.grpc.JobWorkerHealth
 
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.ListStatusPOptions
 
equals(Object) - Method in class alluxio.grpc.ListStatusPRequest
 
equals(Object) - Method in class alluxio.grpc.ListStatusPResponse
 
equals(Object) - Method in class alluxio.grpc.LoadMetadataPOptions
 
equals(Object) - Method in class alluxio.grpc.LocalityTier
 
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.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.NetAddress
 
equals(Object) - Method in class alluxio.grpc.OpenFilePOptions
 
equals(Object) - Method in class alluxio.grpc.OpenLocalBlockRequest
 
equals(Object) - Method in class alluxio.grpc.OpenLocalBlockResponse
 
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.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.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.RemovePathConfigurationPOptions
 
equals(Object) - Method in class alluxio.grpc.RemovePathConfigurationPRequest
 
equals(Object) - Method in class alluxio.grpc.RemovePathConfigurationPResponse
 
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.ReverseResolvePRequest
 
equals(Object) - Method in class alluxio.grpc.ReverseResolvePResponse
 
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.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.StartSyncPOptions
 
equals(Object) - Method in class alluxio.grpc.StartSyncPRequest
 
equals(Object) - Method in class alluxio.grpc.StartSyncPResponse
 
equals(Object) - Method in class alluxio.grpc.StatusSummary
 
equals(Object) - Method in class alluxio.grpc.StopSyncPOptions
 
equals(Object) - Method in class alluxio.grpc.StopSyncPRequest
 
equals(Object) - Method in class alluxio.grpc.StopSyncPResponse
 
equals(Object) - Method in class alluxio.grpc.StorageList
 
equals(Object) - Method in class alluxio.grpc.SyncPointInfo
 
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.TieredIdentity
 
equals(Object) - Method in class alluxio.grpc.TierList
 
equals(Object) - Method in class alluxio.grpc.TransportMessage
 
equals(Object) - Method in class alluxio.grpc.UfsInfo
 
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.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.WorkerInfo
 
equals(Object) - Method in class alluxio.grpc.WorkerLostStorageInfo
 
equals(Object) - Method in class alluxio.grpc.WorkerNetAddress
 
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.job.plan.load.LoadConfig
 
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.persist.PersistConfig
 
equals(Object) - Method in class alluxio.job.plan.replicate.EvictConfig
 
equals(Object) - Method in class alluxio.job.plan.replicate.MoveConfig
 
equals(Object) - Method in class alluxio.job.plan.replicate.ReplicateConfig
 
equals(Object) - Method in class alluxio.job.plan.transform.CompactConfig
 
equals(Object) - Method in class alluxio.job.plan.transform.CompactTask
 
equals(Object) - Method in class alluxio.job.plan.transform.FieldSchema
 
equals(Object) - Method in class alluxio.job.plan.transform.format.csv.CsvRow
 
equals(Object) - Method in class alluxio.job.plan.transform.format.csv.CsvSchema
 
equals(Object) - Method in class alluxio.job.plan.transform.format.parquet.ParquetRow
 
equals(Object) - Method in class alluxio.job.plan.transform.format.parquet.ParquetSchema
 
equals(Object) - Method in class alluxio.job.plan.transform.PartitionInfo
 
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.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.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.SingleMasterInquireClient.SingleMasterConnectDetails
 
equals(Object) - Method in class alluxio.master.table.DatabaseInfo
 
equals(Object) - Method in class alluxio.master.ZkMasterInquireClient.ZkMasterConnectDetails
 
equals(Object) - Method in class alluxio.metrics.Metric
 
equals(Object) - Method in class alluxio.metrics.MetricKey
 
equals(Object) - Method in class alluxio.metrics.MetricsFilter
 
equals(Object) - Method in class alluxio.proto.client.Cache.PPageStoreCommonOptions
 
equals(Object) - Method in class alluxio.proto.client.Cache.PRocksPageStoreOptions
 
equals(Object) - Method in class alluxio.proto.dataserver.Protocol.CreateUfsBlockOptions
 
equals(Object) - Method in class alluxio.proto.dataserver.Protocol.CreateUfsFileOptions
 
equals(Object) - Method in class alluxio.proto.dataserver.Protocol.OpenUfsBlockOptions
 
equals(Object) - Method in class alluxio.proto.dataserver.Protocol.Response
 
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.Journal.JournalEntry
 
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.Table.AddTableEntry
 
equals(Object) - Method in class alluxio.proto.journal.Table.AddTransformJobInfoEntry
 
equals(Object) - Method in class alluxio.proto.journal.Table.AttachDbEntry
 
equals(Object) - Method in class alluxio.proto.journal.Table.CompleteTransformTableEntry
 
equals(Object) - Method in class alluxio.proto.journal.Table.DetachDbEntry
 
equals(Object) - Method in class alluxio.proto.journal.Table.RemoveTableEntry
 
equals(Object) - Method in class alluxio.proto.journal.Table.RemoveTransformJobInfoEntry
 
equals(Object) - Method in class alluxio.proto.journal.Table.UpdateDatabaseInfoEntry
 
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.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.ListBucketOptions
 
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.table.common.BaseProperty
 
equals(Object) - Method in class alluxio.table.common.layout.HiveLayout
 
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.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.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.MountPointInfo
 
equals(Object) - Method in class alluxio.wire.TieredIdentity
 
equals(Object) - Method in class alluxio.wire.TieredIdentity.LocalityTier
 
equals(Object) - Method in class alluxio.wire.WorkerInfo
 
equals(Object) - Method in class alluxio.wire.WorkerNetAddress
 
equals(Object) - Method in class alluxio.worker.block.BlockStoreLocation
Compares to a specific object.
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
 
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
 
ERRORMESSAGE_FIELD_NUMBER - Static variable in class alluxio.grpc.JobInfo
 
ErrorResponse(Status.Code, String) - Constructor for class alluxio.RestUtils.ErrorResponse
ERRORS_FIELD_NUMBER - Static variable in class alluxio.grpc.ConfigCheckReport
 
escape(AlluxioURI) - Static method in class alluxio.metrics.MetricsSystem
Escapes a URI, replacing "/" with "%2F".
evaluateResponse(byte[]) - Method in class alluxio.security.authentication.plain.PlainSaslServer
 
evict() - Method in interface alluxio.client.file.cache.CacheEvictor
 
evict() - Method in class alluxio.client.file.cache.evictor.LFUCacheEvictor
 
evict() - Method in class alluxio.client.file.cache.evictor.LRUCacheEvictor
 
evict(AlluxioURI, long, int) - Method in class alluxio.job.plan.replicate.DefaultReplicationHandler
 
evict(AlluxioURI, long, int) - Method in interface alluxio.job.plan.replicate.ReplicationHandler
Decreases the block replication level by a target number of replicas.
EvictConfig - Class in alluxio.job.plan.replicate
Configuration of a job evicting a block.
EvictConfig(long, int) - Constructor for class alluxio.job.plan.replicate.EvictConfig
Creates a new instance of EvictConfig.
EvictDefinition - Class in alluxio.job.plan.replicate
A job to evict a block.
EvictDefinition() - Constructor for class alluxio.job.plan.replicate.EvictDefinition
Constructs a new EvictDefinition.
EvictionPlan - Class in alluxio.worker.block.evictor
This class provides information about the blocks that need to be moved when evicting.
EvictionPlan(List<BlockTransferInfo>, List<Pair<Long, BlockStoreLocation>>) - Constructor for class alluxio.worker.block.evictor.EvictionPlan
Creates a new instance of EvictionPlan.
Evictor - Interface in alluxio.worker.block.evictor
Interface for the eviction policy in Alluxio.
Evictor.Factory - Class in alluxio.worker.block.evictor
Factory for Evictor.
Evictor.Mode - Enum in alluxio.worker.block.evictor
The eviction mode.
EvictorUtils - Class in alluxio.worker.block.evictor
Utility functions for the evictor package.
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(Throwable) - Method in interface alluxio.RpcUtils.StreamingRpcCallable
Handles exception.
ExceptionMessage - Enum in alluxio.exception
Exception messages used across Alluxio.
ExceptionUtils - Class in alluxio.util
Utility methods for working with exceptions.
exec() - Method in class alluxio.concurrent.jsr.CountedCompleter
Implements execution conventions for CountedCompleters.
exec() - Method in class alluxio.concurrent.jsr.ForkJoinTask
Immediately performs the base action of this task and returns true if, upon return from this method, this task is guaranteed to have completed normally.
execCmdWithBackup(ShellCommand, ShellCommand) - Static method in class alluxio.util.ShellUtils
Executes a shell command.
execCommand(String...) - Static method in class alluxio.util.ShellUtils
Static method to execute a shell command.
execCommandWithOutput(String...) - Static method in class alluxio.util.ShellUtils
Static method to execute a shell command and tolerate non-zero exit code.
execute(ForkJoinTask<?>) - Method in class alluxio.concurrent.jsr.ForkJoinPool
Arranges for (asynchronous) execution of the given task.
execute(Runnable) - Method in class alluxio.concurrent.jsr.ForkJoinPool
 
execute(String) - Static method in class alluxio.heartbeat.HeartbeatScheduler
Convenience method for executing a heartbeat and waiting for it to complete.
execute(String, String, TransformDefinition) - Method in class alluxio.master.table.transform.TransformManager
Executes the plans for the table transformation.
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.
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.
exists(AlluxioURI, ExistsPOptions) - Method in class alluxio.client.file.BaseFileSystem
 
exists(AlluxioURI, ExistsPOptions) - Method in class alluxio.client.file.DelegatingFileSystem
 
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(String) - Method in class alluxio.concurrent.ManagedBlockingUfsForwarder
 
exists(AlluxioURI, ExistsPOptions) - Method in class alluxio.hadoop.AlluxioHdfsFileSystem
 
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.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) - Method in class alluxio.underfs.web.WebUnderFileSystem
 
exists(String) - Static method in class alluxio.util.io.FileUtils
Checks if a path exists.
existsDefaults(AlluxioConfiguration) - Static method in class alluxio.util.FileSystemOptions
 
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
 
existsTest() - Method in class alluxio.examples.UnderFileSystemCommonOperations
Test for checking file existence.
ExitCodeException(int, String) - Constructor for exception alluxio.util.ShellUtils.ExitCodeException
Constructs an ExitCodeException.
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.
ExtensionsShellUtils - Class in alluxio.cli.extensions
Class for convenience methods used by instances of ExtensionsShell.
ExtensionUtils - Class in alluxio.util
Utility functions for working with extensions.
ExternalProcess - Class in alluxio.multi.process
Class for launching another class in a new processes.
ExternalProcess(Map<PropertyKey, String>, Class<?>, File) - Constructor for class alluxio.multi.process.ExternalProcess
 
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(FileSystemContext, WorkerNetAddress, ReadRequest) - Constructor for class alluxio.client.block.stream.GrpcDataReader.Factory
Creates an instance of GrpcDataReader.Factory for block reads.
Factory(FileSystemContext, WorkerNetAddress, long, long, InStreamOptions) - Constructor for class alluxio.client.block.stream.LocalFileDataReader.Factory
Creates an instance of LocalFileDataReader.Factory.
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.security.authentication.plain.PlainSaslServer.Factory
Constructs a new PlainSaslServer.Factory for the PlainSaslServer.
Factory() - Constructor for class alluxio.security.user.NoopUserState.Factory
 
Factory() - Constructor for class alluxio.security.user.SimpleUserState.Factory
 
Factory() - Constructor for class alluxio.security.user.UserState.Factory
 
fail(Throwable) - Method in class alluxio.master.file.ListStatusResultStream
Used to fail streaming with an error.
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;
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
 
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.
FailedToCheckpointException - Exception in alluxio.exception
The exception thrown when Alluxio failed to create a checkpoint.
FailedToCheckpointException(String) - Constructor for exception alluxio.exception.FailedToCheckpointException
Constructs a new exception with the specified detail message.
FailedToCheckpointException(String, Throwable) - Constructor for exception alluxio.exception.FailedToCheckpointException
Constructs a new exception with the specified detail message and cause.
FailedToCheckpointException(ExceptionMessage, Object...) - Constructor for exception alluxio.exception.FailedToCheckpointException
Constructs a new exception with the specified exception message and multiple parameters.
FailedToCheckpointException(ExceptionMessage, Throwable, Object...) - Constructor for exception alluxio.exception.FailedToCheckpointException
Constructs a new exception with the specified exception message, the cause and multiple parameters.
failTasksForWorker(long) - Method in class alluxio.master.job.plan.PlanCoordinator
Fails any incomplete tasks being run on the specified worker.
FALLBACK_FIELD_NUMBER - Static variable in class alluxio.proto.dataserver.Protocol.CreateUfsBlockOptions
 
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.
FIELD_DELIM - Static variable in class alluxio.job.plan.transform.HiveConstants
Field delimiter for CSV.
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
Protobuf type alluxio.grpc.table.FieldSchema
FieldSchema - Class in alluxio.job.plan.transform
Metadata of a field in the schema.
FieldSchema(int, String, String, String) - Constructor for class alluxio.job.plan.transform.FieldSchema
 
FieldSchema.Builder - Class in alluxio.grpc.table
Protobuf type alluxio.grpc.table.FieldSchema
FieldSchemaOrBuilder - Interface in alluxio.grpc.table
 
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.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: 20
File.UpdateInodeEntry.Builder - Class in alluxio.proto.journal
next available id: 20
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_DIR_PERMISSION_DIFF - Static variable in class alluxio.Constants
 
FILE_ID_FIELD_NUMBER - Static variable in class alluxio.proto.journal.File.AsyncPersistRequestEntry
 
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
 
FILE_SYSTEM_WORKER_WORKER_SERVICE_VALUE - Static variable in enum alluxio.grpc.ServiceType
FILE_SYSTEM_WORKER_WORKER_SERVICE = 12;
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.
FileAlreadyExistsException(AlluxioURI) - Constructor for exception alluxio.exception.FileAlreadyExistsException
Constructs a new exception reporting that the given path already exists.
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
 
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.
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(String, Throwable) - Constructor for exception alluxio.exception.FileIncompleteException
Constructs a new exception with the specified detail message and cause.
FileIncompleteException(ExceptionMessage, Object...) - Constructor for exception alluxio.exception.FileIncompleteException
Constructs a new exception with the specified exception message and multiple parameters.
FileIncompleteException(ExceptionMessage, Throwable, Object...) - Constructor for exception alluxio.exception.FileIncompleteException
Constructs a new exception with the specified exception message, the cause and multiple parameters.
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
 
FileInfoOrBuilder - Interface in alluxio.grpc
 
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
 
FileLocationOptions - Class in alluxio.underfs.options
Method options for file locations in UnderFileSystem.
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
 
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
 
FileSystem - Interface in alluxio.client.file
Basic file system interface supporting metadata operations and data operations.
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(InstancedConfiguration) - 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.
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.
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.
FileSystemContextReinitializer - Class in alluxio.client.file
Reinitializes FileSystemContext inside BaseFileSystem.
FileSystemContextReinitializer(FileSystemContext) - 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) - 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.FileSystemMasterWorkerServiceImplBase
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
 
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.
FileSystemMasterAuditContext(AsyncUserAccessAuditLogWriter) - Constructor for class alluxio.master.file.FileSystemMasterAuditContext
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.FileSystemMasterClientServiceBlockingStub - Class in alluxio.grpc
This interface contains file system master service endpoints for Alluxio clients.
FileSystemMasterClientServiceGrpc.FileSystemMasterClientServiceFutureStub - Class in alluxio.grpc
This interface contains file system master service endpoints for Alluxio clients.
FileSystemMasterClientServiceGrpc.FileSystemMasterClientServiceImplBase - Class in alluxio.grpc
This interface contains file system master service endpoints for Alluxio clients.
FileSystemMasterClientServiceGrpc.FileSystemMasterClientServiceStub - Class in alluxio.grpc
This interface contains file system master service endpoints for Alluxio clients.
FileSystemMasterClientServiceHandler - Class in alluxio.master.file
This class is a gRPC handler for file system master RPCs invoked by an Alluxio client.
FileSystemMasterClientServiceHandler(FileSystemMaster) - 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.FileSystemMasterJobServiceBlockingStub - Class in alluxio.grpc
This interface contains file system master service endpoints for Alluxio workers.
FileSystemMasterJobServiceGrpc.FileSystemMasterJobServiceFutureStub - Class in alluxio.grpc
This interface contains file system master service endpoints for Alluxio workers.
FileSystemMasterJobServiceGrpc.FileSystemMasterJobServiceImplBase - Class in alluxio.grpc
This interface contains file system master service endpoints for Alluxio workers.
FileSystemMasterJobServiceGrpc.FileSystemMasterJobServiceStub - Class in alluxio.grpc
This interface contains file system master service endpoints for Alluxio workers.
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.FileSystemMasterWorkerServiceBlockingStub - Class in alluxio.grpc
This interface contains file system master service endpoints for Alluxio workers.
FileSystemMasterWorkerServiceGrpc.FileSystemMasterWorkerServiceFutureStub - Class in alluxio.grpc
This interface contains file system master service endpoints for Alluxio workers.
FileSystemMasterWorkerServiceGrpc.FileSystemMasterWorkerServiceImplBase - Class in alluxio.grpc
This interface contains file system master service endpoints for Alluxio workers.
FileSystemMasterWorkerServiceGrpc.FileSystemMasterWorkerServiceStub - Class in alluxio.grpc
This interface contains file system master service endpoints for Alluxio workers.
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
 
FileSystemOptions - 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.
FileSystemOptions() - Constructor for class alluxio.util.FileSystemOptions
 
FileSystemShell - Class in alluxio.cli.fs
Class for handling command line inputs.
FileSystemShell(InstancedConfiguration) - 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.
FileUtils - Class in alluxio.util.io
Provides utility methods for working with files and directories.
FileWriterKey(String, String) - Constructor for class alluxio.cli.docgen.MetricsDocGenerator.FileWriterKey
fill(byte[], int, int) - Method in class alluxio.master.journal.PatchedInputChunked
 
FILTER_FIELD_NUMBER - Static variable in class alluxio.grpc.GetMasterInfoPOptions
 
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.
findAll(String, S) - Method in class alluxio.extensions.ExtensionFactoryRegistry
Finds all the factories that support the given path.
findAll(String, UnderFileSystemConfiguration) - Static method in class alluxio.underfs.UnderFileSystemFactoryRegistry
Finds all the Under File System factories that support the given path.
findClass(String) - Method in class alluxio.extensions.ExtensionsClassLoader
 
findLowestCommonAncestor(Collection<AlluxioURI>) - Static method in class alluxio.util.io.PathUtils
 
Fingerprint - Class in alluxio.underfs
Fingerprint for a UFS file or directory.
Fingerprint.Tag - Enum in alluxio.underfs
The possible tags within the fingerprint.
Fingerprint.Type - Enum in alluxio.underfs
The possible types of the fingerprint.
FIRST_COM_PATH - Static variable in class alluxio.hadoop.AbstractFileSystem
 
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
 
FIRST_VERSION - Static variable in class alluxio.master.table.Table
 
firstComplete() - Method in class alluxio.concurrent.jsr.CountedCompleter
If this task's pending count is zero, returns this task; otherwise decrements its pending count and returns null.
fixedThreadPool(String, int) - Static method in class alluxio.util.executor.ExecutorServiceFactories
Returns a ExecutorServiceFactory which creates threadpool executors with the given base name and number of threads.
flattenEntries(TwoKeyConcurrentMap.TriFunction<K1, K2, V, R>) - Method in class alluxio.collections.TwoKeyConcurrentMap
Flattens the (key1, key2, value) triples according to the given function.
FLOAT - Static variable in class alluxio.job.plan.transform.HiveConstants.Types
Hive float type.
flowControlWindow(int) - Method in class alluxio.grpc.GrpcServerBuilder
Sets flow control window.
flush() - Method in class alluxio.client.block.stream.BlockOutStream
 
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.LocalFileDataWriter
 
flush() - Method in class alluxio.client.block.stream.UfsFallbackLocalFileDataWriter
 
flush() - Method in class alluxio.client.file.AlluxioFileOutStream
 
flush(String, FuseFileInfo) - Method in class alluxio.fuse.AlluxioFuseFileSystem
Flushes cached data on Alluxio.
flush(long) - Method in class alluxio.master.journal.AsyncJournalWriter
Submits a ticket to flush thread and waits until ticket is served.
flush() - Method in interface alluxio.master.journal.JournalWriter
Flushes all the entries written to the underlying storage.
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.ufs.UfsJournal
Flushes the journal.
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.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.hdfs.HdfsUnderFileOutputStream
 
flush() - Method in class alluxio.underfs.kodo.KodoOutputStream
 
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.S3ALowLevelOutputStream
 
flush() - Method in class alluxio.underfs.s3a.S3AOutputStream
 
flush() - Method in class alluxio.underfs.swift.SwiftMockOutputStream
 
flush() - Method in class alluxio.underfs.swift.SwiftOutputStream
 
FLUSH_FIELD_NUMBER - Static variable in class alluxio.grpc.WriteRequestCommand
 
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.
flushRequest(BlockWriteRequestContext) - Method in class alluxio.worker.grpc.BlockWriteHandler
 
flushRequest(BlockWriteRequestContext) - Method in class alluxio.worker.grpc.UfsFallbackBlockWriteHandler
 
flushRequest(UfsFileWriteRequestContext) - Method in class alluxio.worker.grpc.UfsFileWriteHandler
 
FOLDER_FIELD_NUMBER - Static variable in class alluxio.grpc.FileInfo
 
forAddress(GrpcServerAddress, AlluxioConfiguration, UserState) - Static method in class alluxio.grpc.GrpcServerBuilder
Create an new instance of GrpcServerBuilder with authentication support.
forAddress(GrpcServerAddress, AuthenticationServer, AlluxioConfiguration, UserState) - Static method in class alluxio.grpc.GrpcServerBuilder
Create an new instance of GrpcServerBuilder with authentication support.
FORCED_FIELD_NUMBER - Static variable in class alluxio.grpc.FreePOptions
 
forEach(Consumer<? super T>) - Method in class alluxio.collections.DelegatingSet
 
forEach(BiConsumer<? super PropertyKey, ? super String>) - Method in class alluxio.conf.AlluxioProperties
Iterates over all the key value pairs and performs the given action.
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.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 - Enum in alluxio.job.plan.transform
Supported formats.
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.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.
formatAndRestartMasters() - Method in class alluxio.master.AbstractLocalAlluxioCluster
Stops the masters, formats them, and then restarts them.
formatJournal() - Method in class alluxio.multi.process.MultiProcessCluster
Formats the cluster journal.
formatLsString(boolean, boolean, boolean, String, String, String, long, long, int, 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
 
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.
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.JobType
 
forNumber(int) - Static method in enum alluxio.grpc.JournalDomain
 
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.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.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.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.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
 
free(AlluxioURI, FreePOptions) - Method in class alluxio.client.file.BaseFileSystem
 
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(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.FileSystemMasterClientServiceImplBase
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, FreePOptions) - Method in class alluxio.hadoop.AlluxioHdfsFileSystem
 
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.FileSystemOptions
 
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
 
freeSpace(long, long, BlockStoreLocation) - Method in interface alluxio.worker.block.BlockStore
Frees space to make a specific amount of bytes available in a best-effort way in the location.
freeSpace(long, long, String) - Method in interface alluxio.worker.block.BlockWorker
Frees space to make a specific amount of bytes available in a best-effort way in the tier.
freeSpace(long, long, String) - Method in class alluxio.worker.block.DefaultBlockWorker
 
freeSpace(long, long, BlockStoreLocation) - Method in class alluxio.worker.block.TieredBlockStore
 
freeSpaceWithView(long, BlockStoreLocation, BlockMetadataEvictorView) - Method in class alluxio.worker.block.evictor.AbstractEvictor
 
freeSpaceWithView(long, BlockStoreLocation, BlockMetadataEvictorView, Evictor.Mode) - Method in class alluxio.worker.block.evictor.AbstractEvictor
 
freeSpaceWithView(long, BlockStoreLocation, BlockMetadataEvictorView) - Method in interface alluxio.worker.block.evictor.Evictor
Frees space with the guaranteed mode.
freeSpaceWithView(long, BlockStoreLocation, BlockMetadataEvictorView, Evictor.Mode) - Method in interface alluxio.worker.block.evictor.Evictor
Frees space in the given block store location and with the given view.
freeSpaceWithView(long, BlockStoreLocation, BlockMetadataEvictorView) - Method in class alluxio.worker.block.evictor.GreedyEvictor
 
freeSpaceWithView(long, BlockStoreLocation, BlockMetadataEvictorView, Evictor.Mode) - Method in class alluxio.worker.block.evictor.GreedyEvictor
 
freeSpaceWithView(long, BlockStoreLocation, BlockMetadataEvictorView, Evictor.Mode) - Method in class alluxio.worker.block.evictor.LRFUEvictor
 
from(Status) - Static method in exception alluxio.exception.status.AlluxioStatusException
Converts an Alluxio exception from status and message representation to native representation.
from(String, double, MetricType) - Static method in class alluxio.metrics.Metric
Creates the metric from the full name and the value.
fromAlluxioException(AlluxioException) - Static method in exception alluxio.exception.status.AlluxioStatusException
Converts checked Alluxio exceptions to Alluxio status exceptions.
fromCheckedException(Throwable) - Static method in exception alluxio.exception.status.AlluxioStatusException
Converts checked throwables to Alluxio status exceptions.
fromCliString(String) - Static method in class alluxio.security.authorization.AclEntry
Creates an AclEntry from a string.
fromCliStringWithoutPermissions(String) - Static method in class alluxio.security.authorization.AclEntry
Creates an AclEntry from a string without permissions.
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.
fromLong(long) - Static method in enum alluxio.master.journal.checkpoint.CheckpointType
 
fromMountEntry(File.AddMountPointEntry) - Static method in class alluxio.grpc.GrpcUtils
Creates mount proto options from File.AddMountPointEntry.
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(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(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(TieredIdentity) - Static method in class alluxio.grpc.GrpcUtils
Converts a proto type to a wire type.
fromProto(LocalityTier) - Static method in class alluxio.grpc.GrpcUtils
Converts a proto type to a wire type.
fromProto(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(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(LayoutRegistry, Partition) - Static method in class alluxio.master.table.Partition
 
fromProto(Metric) - Static method in class alluxio.metrics.Metric
Constructs the metric object from the proto format.
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(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(SyncPointInfo) - Static method in class alluxio.wire.SyncPointInfo
Generate sync point information from the proto 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 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 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, AlluxioConfiguration) - Static method in class alluxio.network.TieredIdentityFactory
 
fromString(String) - Static method in enum alluxio.security.authorization.Mode.Bits
 
fromString(String) - Static method in interface alluxio.uri.Authority
Gets the Authority object from the input string.
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.
fromURIStatus(URIStatus) - Static method in class alluxio.proxy.s3.ListPartsResult.Part
 
FsCommonProto - Class 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
 
FUSE_CACHED_PATHS_MAX - Static variable in class alluxio.conf.PropertyKey
 
FUSE_CACHED_PATHS_MAX - Static variable in class alluxio.conf.PropertyKey.Name
 
FUSE_DEBUG_ENABLED - Static variable in class alluxio.conf.PropertyKey
 
FUSE_DEBUG_ENABLED - Static variable in class alluxio.conf.PropertyKey.Name
 
FUSE_FS_NAME - Static variable in class alluxio.conf.PropertyKey
 
FUSE_FS_NAME - Static variable in class alluxio.conf.PropertyKey.Name
 
FUSE_MAXWRITE_BYTES - Static variable in class alluxio.conf.PropertyKey
 
FUSE_MAXWRITE_BYTES - Static variable in class alluxio.conf.PropertyKey.Name
 
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
 

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 secondary to primary mode.
gainPrimacy() - Method in class alluxio.master.journal.ufs.UfsJournalSystem
 
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_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.
GCSUnderFileSystem - Class in alluxio.underfs.gcs
GCS FS 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
Factory for creating GCSUnderFileSystem.
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.
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.
generateCapacityReport(GetWorkerReportOptions) - Method in class alluxio.cli.fsadmin.report.CapacityCommand
Generates capacity report.
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
 
generateDbPath(String, String) - Static method in class alluxio.master.metastore.rocks.RocksUtils
Generates a path to use for a RocksDB database.
generateJobConfig(Layout, Layout) - Method in interface alluxio.table.common.transform.action.TransformAction
 
generateJobConfig(Layout, Layout) - Method in class alluxio.table.common.transform.action.WriteAction
 
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.
generatePartitionInfo(Layout) - Static method in class alluxio.table.common.transform.action.TransformActionUtils
 
generateQueryString(Map<String, String>) - Static method in class alluxio.util.URIUtils
Generates a query string from a of key/value pairs.
generateReport() - Method in class alluxio.worker.block.BlockHeartbeatReporter
Generates the report of the block store delta in the last heartbeat period.
generateThreadName(String, String) - Static method in class alluxio.heartbeat.HeartbeatThread
 
generateTransformedPath() - Method in class alluxio.table.common.transform.TransformContext
 
generateWorkerInfo(Set<GetWorkerReportOptions.WorkerInfoField>, boolean) - 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, int, byte[], int) - Method in class alluxio.client.file.cache.LocalCacheManager
 
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) - Method in interface alluxio.client.file.cache.PageStore
Wraps a page from the store as a channel to read.
get(PageId, int) - Method in interface alluxio.client.file.cache.PageStore
Gets part of a page from the store to the destination channel.
get(PageId, int) - Method in class alluxio.client.file.cache.store.LocalPageStore
 
get(PageId, int) - Method in class alluxio.client.file.cache.store.RocksPageStore
 
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(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(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() - 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() - 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(PropertyKey) - Method in class alluxio.conf.path.SpecificPathConfiguration
 
get(PropertyKey, ConfigurationValueOptions) - Method in class alluxio.conf.path.SpecificPathConfiguration
 
get(PropertyKey) - Static method in class alluxio.conf.ServerConfiguration
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.ServerConfiguration
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.DefaultSupplier
 
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.journal.raft.OnceSupplier
 
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(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(T) - Method in class alluxio.table.common.BaseConfiguration
Returns the value of this property, or the default value if the property is not defined.
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(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_BLOCK_INFO - Static variable in class alluxio.master.block.BlockMasterClientRestServiceHandler
Deprecated.
 
GET_CAPACITY_BYTES - Static variable in class alluxio.master.meta.AlluxioMasterRestServiceHandler
 
GET_CAPACITY_BYTES - Static variable in class alluxio.worker.AlluxioWorkerRestServiceHandler
 
GET_CAPACITY_BYTES_ON_TIERS - Static variable in class alluxio.master.meta.AlluxioMasterRestServiceHandler
 
GET_CAPACITY_BYTES_ON_TIERS - Static variable in class alluxio.worker.AlluxioWorkerRestServiceHandler
 
GET_CONFIGURATION - Static variable in class alluxio.master.meta.AlluxioMasterRestServiceHandler
 
GET_CONFIGURATION - Static variable in class alluxio.worker.AlluxioWorkerRestServiceHandler
 
GET_DIRECTORY_PATHS_ON_TIERS - Static variable in class alluxio.worker.AlluxioWorkerRestServiceHandler
 
GET_FREE_BYTES - Static variable in class alluxio.master.meta.AlluxioMasterRestServiceHandler
 
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_INFO - Static variable in class alluxio.worker.AlluxioWorkerRestServiceHandler
 
GET_METRICS - Static variable in class alluxio.master.meta.AlluxioMasterRestServiceHandler
 
GET_METRICS - Static variable in class alluxio.worker.AlluxioWorkerRestServiceHandler
 
GET_RPC_ADDRESS - Static variable in class alluxio.master.meta.AlluxioMasterRestServiceHandler
 
GET_RPC_ADDRESS - Static variable in class alluxio.worker.AlluxioWorkerRestServiceHandler
 
GET_START_TIME_MS - Static variable in class alluxio.master.meta.AlluxioMasterRestServiceHandler
 
GET_START_TIME_MS - Static variable in class alluxio.worker.AlluxioWorkerRestServiceHandler
 
GET_STATUS - Static variable in class alluxio.job.ServiceConstants
 
GET_STATUS - Static variable in class alluxio.proxy.PathsRestServiceHandler
 
GET_UFS_CAPACITY_BYTES - Static variable in class alluxio.master.meta.AlluxioMasterRestServiceHandler
 
GET_UFS_FREE_BYTES - Static variable in class alluxio.master.meta.AlluxioMasterRestServiceHandler
 
GET_UFS_USED_BYTES - Static variable in class alluxio.master.meta.AlluxioMasterRestServiceHandler
 
GET_UPTIME_MS - Static variable in class alluxio.master.meta.AlluxioMasterRestServiceHandler
 
GET_UPTIME_MS - Static variable in class alluxio.worker.AlluxioWorkerRestServiceHandler
 
GET_USED_BYTES - Static variable in class alluxio.master.meta.AlluxioMasterRestServiceHandler
 
GET_USED_BYTES - Static variable in class alluxio.worker.AlluxioWorkerRestServiceHandler
 
GET_USED_BYTES_ON_TIERS - Static variable in class alluxio.master.meta.AlluxioMasterRestServiceHandler
 
GET_USED_BYTES_ON_TIERS - Static variable in class alluxio.worker.AlluxioWorkerRestServiceHandler
 
GET_VERSION - Static variable in class alluxio.master.meta.AlluxioMasterRestServiceHandler
 
GET_VERSION - Static variable in class alluxio.worker.AlluxioWorkerRestServiceHandler
 
GET_WORKER_COUNT - Static variable in class alluxio.master.meta.AlluxioMasterRestServiceHandler
 
GET_WORKER_INFO_LIST - Static variable in class alluxio.master.meta.AlluxioMasterRestServiceHandler
 
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.
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;
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
 
getActions() - Method in class alluxio.table.common.transform.TransformDefinition
 
getActionsBuilder() - Method in class alluxio.proto.shared.Acl.NamedAclActions.Builder
optional .alluxio.proto.shared.AclActions actions = 2;
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;
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;
getActiveSyncInfo() - Method in class alluxio.concurrent.ManagedBlockingUfsForwarder
 
getActiveSyncInfo() - Method in class alluxio.underfs.BaseUnderFileSystem
 
getActiveSyncInfo() - Method in class alluxio.underfs.hdfs.HdfsUnderFileSystem
 
getActiveSyncInfo() - Method in interface alluxio.underfs.UnderFileSystem
Return the active sync info for the specified syncPoints.
getActiveSyncInfo() - Method in class alluxio.underfs.UnderFileSystemWithLogging
 
getActiveSyncTxId() - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
optional .alluxio.proto.journal.ActiveSyncTxIdEntry active_sync_tx_id = 34;
getActiveSyncTxId() - Method in class alluxio.proto.journal.Journal.JournalEntry
optional .alluxio.proto.journal.ActiveSyncTxIdEntry active_sync_tx_id = 34;
getActiveSyncTxId() - Method in interface alluxio.proto.journal.Journal.JournalEntryOrBuilder
optional .alluxio.proto.journal.ActiveSyncTxIdEntry active_sync_tx_id = 34;
getActiveSyncTxIdBuilder() - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
optional .alluxio.proto.journal.ActiveSyncTxIdEntry active_sync_tx_id = 34;
getActiveSyncTxIdOrBuilder() - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
optional .alluxio.proto.journal.ActiveSyncTxIdEntry active_sync_tx_id = 34;
getActiveSyncTxIdOrBuilder() - Method in class alluxio.proto.journal.Journal.JournalEntry
optional .alluxio.proto.journal.ActiveSyncTxIdEntry active_sync_tx_id = 34;
getActiveSyncTxIdOrBuilder() - Method in interface alluxio.proto.journal.Journal.JournalEntryOrBuilder
optional .alluxio.proto.journal.ActiveSyncTxIdEntry active_sync_tx_id = 34;
getActiveThreadCount() - Method in class alluxio.concurrent.jsr.ForkJoinPool
Returns an estimate of the number of threads that are currently stealing or executing tasks.
getActivitySyncInfo() - Method in class alluxio.underfs.hdfs.activesync.SupportedHdfsActiveSyncProvider
Get the activity sync info.
getActivitySyncInfo() - Method in interface alluxio.underfs.hdfs.HdfsActiveSyncProvider
Get Active SyncInfo from the sync provider.
getActivitySyncInfo() - Method in class alluxio.underfs.hdfs.NoopHdfsActiveSyncProvider
 
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;
getAddress() - Method in class alluxio.AbstractClient
 
getAddress() - Method in class alluxio.AbstractMasterClient
 
getAddress() - Method in class alluxio.client.block.stream.BlockInStream
 
getAddress() - Method in class alluxio.client.block.stream.BlockOutStream
 
getAddress() - Method in interface alluxio.Client
 
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.MasterInfo
 
getAddress() - Method in class alluxio.master.SingleMasterInquireClient.SingleMasterConnectDetails
 
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.JobWorkerProcess
 
getAddress() - Method in interface alluxio.worker.WorkerProcess
 
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.master.PollingMasterInquireClient.MultiMasterConnectDetails
 
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
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;
getAddTable() - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
optional .alluxio.proto.journal.AddTableEntry add_table = 43;
getAddTable() - Method in class alluxio.proto.journal.Journal.JournalEntry
optional .alluxio.proto.journal.AddTableEntry add_table = 43;
getAddTable() - Method in interface alluxio.proto.journal.Journal.JournalEntryOrBuilder
optional .alluxio.proto.journal.AddTableEntry add_table = 43;
getAddTableBuilder() - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
optional .alluxio.proto.journal.AddTableEntry add_table = 43;
getAddTableOrBuilder() - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
optional .alluxio.proto.journal.AddTableEntry add_table = 43;
getAddTableOrBuilder() - Method in class alluxio.proto.journal.Journal.JournalEntry
optional .alluxio.proto.journal.AddTableEntry add_table = 43;
getAddTableOrBuilder() - Method in interface alluxio.proto.journal.Journal.JournalEntryOrBuilder
optional .alluxio.proto.journal.AddTableEntry add_table = 43;
getAddTransformJobInfo() - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
optional .alluxio.proto.journal.AddTransformJobInfoEntry add_transform_job_info = 46;
getAddTransformJobInfo() - Method in class alluxio.proto.journal.Journal.JournalEntry
optional .alluxio.proto.journal.AddTransformJobInfoEntry add_transform_job_info = 46;
getAddTransformJobInfo() - Method in interface alluxio.proto.journal.Journal.JournalEntryOrBuilder
optional .alluxio.proto.journal.AddTransformJobInfoEntry add_transform_job_info = 46;
getAddTransformJobInfoBuilder() - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
optional .alluxio.proto.journal.AddTransformJobInfoEntry add_transform_job_info = 46;
getAddTransformJobInfoOrBuilder() - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
optional .alluxio.proto.journal.AddTransformJobInfoEntry add_transform_job_info = 46;
getAddTransformJobInfoOrBuilder() - Method in class alluxio.proto.journal.Journal.JournalEntry
optional .alluxio.proto.journal.AddTransformJobInfoEntry add_transform_job_info = 46;
getAddTransformJobInfoOrBuilder() - Method in interface alluxio.proto.journal.Journal.JournalEntryOrBuilder
optional .alluxio.proto.journal.AddTransformJobInfoEntry add_transform_job_info = 46;
getAlias(int) - Method in class 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) - 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.TableMasterClientServiceImplBase
Returns all databases in the catalog
getAllDatabases(GetAllDatabasesPRequest, StreamObserver<GetAllDatabasesPResponse>) - Method in class alluxio.grpc.table.TableMasterClientServiceGrpc.TableMasterClientServiceStub
Returns all databases in the catalog
getAllDatabases() - Method in class alluxio.master.table.AlluxioCatalog
Get all databases.
getAllDatabases() - Method in class alluxio.master.table.DefaultTableMaster
 
getAllDatabases() - Method in interface alluxio.master.table.TableMaster
Get a listing of all databases.
getAllDatabases(GetAllDatabasesPRequest, StreamObserver<GetAllDatabasesPResponse>) - Method in class alluxio.master.table.TableMasterClientServiceHandler
 
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
 
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.
getAllOrNone() - Method in class alluxio.grpc.table.Domain.Builder
optional .alluxio.grpc.table.AllOrNoneSet all_or_none = 3;
getAllOrNone() - Method in class alluxio.grpc.table.Domain
optional .alluxio.grpc.table.AllOrNoneSet all_or_none = 3;
getAllOrNone() - Method in interface alluxio.grpc.table.DomainOrBuilder
optional .alluxio.grpc.table.AllOrNoneSet all_or_none = 3;
getAllOrNoneBuilder() - Method in class alluxio.grpc.table.Domain.Builder
optional .alluxio.grpc.table.AllOrNoneSet all_or_none = 3;
getAllOrNoneOrBuilder() - Method in class alluxio.grpc.table.Domain.Builder
optional .alluxio.grpc.table.AllOrNoneSet all_or_none = 3;
getAllOrNoneOrBuilder() - Method in class alluxio.grpc.table.Domain
optional .alluxio.grpc.table.AllOrNoneSet all_or_none = 3;
getAllOrNoneOrBuilder() - Method in interface alluxio.grpc.table.DomainOrBuilder
optional .alluxio.grpc.table.AllOrNoneSet all_or_none = 3;
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;
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) - 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.TableMasterClientServiceImplBase
Returns all tables in the database
getAllTables(GetAllTablesPRequest, StreamObserver<GetAllTablesPResponse>) - Method in class alluxio.grpc.table.TableMasterClientServiceGrpc.TableMasterClientServiceStub
Returns all tables in the database
getAllTables(String) - Method in class alluxio.master.table.AlluxioCatalog
Get a list of tables in a database.
getAllTables(String) - Method in class alluxio.master.table.DefaultTableMaster
 
getAllTables(String) - Method in interface alluxio.master.table.TableMaster
Get a listing of all tables in a database.
getAllTables(GetAllTablesPRequest, StreamObserver<GetAllTablesPResponse>) - Method in class alluxio.master.table.TableMasterClientServiceHandler
 
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
 
getAllTransformJobInfo() - Method in class alluxio.client.table.RetryHandlingTableMasterClient
 
getAllTransformJobInfo() - Method in interface alluxio.client.table.TableMasterClient
 
getAllTransformJobInfo() - Method in class alluxio.master.table.DefaultTableMaster
 
getAllTransformJobInfo() - Method in interface alluxio.master.table.TableMaster
 
getAllTransformJobInfo() - Method in class alluxio.master.table.transform.TransformManager
 
getAlluxioFileName(String) - Static method in class alluxio.hadoop.HadoopUtils
Given a String path, returns an equivalent Alluxio path.
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.
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;
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;
getAlluxioRoot() - Method in class alluxio.fuse.AlluxioFuseOptions
 
getAlluxioSchema() - Method in class alluxio.job.plan.transform.format.csv.CsvSchema
 
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) - 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.JobMasterClientServiceImplBase
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
 
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
 
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
 
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;
getAttachDatabaseMethod() - Static method in class alluxio.grpc.table.TableMasterClientServiceGrpc
 
getAttachDb() - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
optional .alluxio.proto.journal.AttachDbEntry attach_db = 44;
getAttachDb() - Method in class alluxio.proto.journal.Journal.JournalEntry
optional .alluxio.proto.journal.AttachDbEntry attach_db = 44;
getAttachDb() - Method in interface alluxio.proto.journal.Journal.JournalEntryOrBuilder
optional .alluxio.proto.journal.AttachDbEntry attach_db = 44;
getAttachDbBuilder() - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
optional .alluxio.proto.journal.AttachDbEntry attach_db = 44;
getAttachDbOrBuilder() - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
optional .alluxio.proto.journal.AttachDbEntry attach_db = 44;
getAttachDbOrBuilder() - Method in class alluxio.proto.journal.Journal.JournalEntry
optional .alluxio.proto.journal.AttachDbEntry attach_db = 44;
getAttachDbOrBuilder() - Method in interface alluxio.proto.journal.Journal.JournalEntryOrBuilder
optional .alluxio.proto.journal.AttachDbEntry attach_db = 44;
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.AlluxioFuseFileSystem
Retrieves file attributes.
getAuthenticatedChannel() - Method in class alluxio.security.authentication.ChannelAuthenticator
 
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
 
getAuthenticationDriver() - Method in class alluxio.security.authentication.ChannelAuthenticator
 
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
 
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
 
getAuthName() - Method in enum alluxio.security.authentication.AuthType
 
getAuthority() - Method in class alluxio.AlluxioURI
 
getAuthority() - Method in class alluxio.uri.StandardURI
 
getAuthority() - Method in interface alluxio.uri.URI
 
getAuthorizationID() - Method in class alluxio.security.authentication.plain.PlainSaslServer
 
getAuthorizedUserName() - Method in class alluxio.security.authentication.AuthenticatedUserInfo
 
getAvailable() - Method in class alluxio.extensions.ExtensionFactoryRegistry
Returns a read-only view of the available base factories.
getAvailableBytes() - Method in class alluxio.master.block.meta.MasterWorkerInfo
 
getAvailableBytes(BlockStoreLocation) - Method in class alluxio.worker.block.BlockMetadataEvictorView
Gets available bytes given certain location BlockMetadataManager.getAvailableBytes(BlockStoreLocation).
getAvailableBytes(BlockStoreLocation) - Method in class alluxio.worker.block.BlockMetadataManager
Gets the amount of available space of given location in bytes.
getAvailableBytes() - Method in class alluxio.worker.block.meta.StorageDir
Gets the total available capacity of this StorageDir in bytes.
getAvailableBytes() - Method in class alluxio.worker.block.meta.StorageDirAllocatorView
 
getAvailableBytes() - Method in class alluxio.worker.block.meta.StorageDirEvictorView
 
getAvailableBytes() - Method in class alluxio.worker.block.meta.StorageDirView
Gets available bytes for this dir.
getAvailableBytes() - Method in class 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;
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) - 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.MetaMasterClientServiceImplBase
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
 
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;
getBaseLayout() - Method in class alluxio.master.table.Partition
 
getBaseLayout() - Method in class alluxio.table.common.transform.TransformPlan
 
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;
getBatchSize() - Method in class alluxio.underfs.ObjectUnderFileSystem.DeleteBuffer
 
getBatchSize() - Method in class alluxio.underfs.ObjectUnderFileSystem.OperationBuffer
Get the batch size.
getBatchSize() - Method in class alluxio.underfs.ObjectUnderFileSystem.RenameBuffer
 
getBinaryStats() - Method in class alluxio.grpc.table.ColumnStatisticsData.Builder
optional .alluxio.grpc.table.BinaryColumnStatsData binary_stats = 5;
getBinaryStats() - Method in class alluxio.grpc.table.ColumnStatisticsData
optional .alluxio.grpc.table.BinaryColumnStatsData binary_stats = 5;
getBinaryStats() - Method in interface alluxio.grpc.table.ColumnStatisticsDataOrBuilder
optional .alluxio.grpc.table.BinaryColumnStatsData binary_stats = 5;
getBinaryStatsBuilder() - Method in class alluxio.grpc.table.ColumnStatisticsData.Builder
optional .alluxio.grpc.table.BinaryColumnStatsData binary_stats = 5;
getBinaryStatsOrBuilder() - Method in class alluxio.grpc.table.ColumnStatisticsData.Builder
optional .alluxio.grpc.table.BinaryColumnStatsData binary_stats = 5;
getBinaryStatsOrBuilder() - Method in class alluxio.grpc.table.ColumnStatisticsData
optional .alluxio.grpc.table.BinaryColumnStatsData binary_stats = 5;
getBinaryStatsOrBuilder() - Method in interface alluxio.grpc.table.ColumnStatisticsDataOrBuilder
optional .alluxio.grpc.table.BinaryColumnStatsData binary_stats = 5;
getBindAddress(NetworkAddressUtils.ServiceType, 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
 
getBindHost(NetworkAddressUtils.ServiceType, 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 enum alluxio.util.network.NetworkAddressUtils.ServiceType
Gets the key of bind hostname.
getBindPort() - Method in class alluxio.grpc.GrpcServer
 
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(long) - Method in interface alluxio.master.metastore.BlockStore
 
getBlock(long) - Method in class alluxio.master.metastore.heap.HeapBlockStore
 
getBlock(long) - Method in class alluxio.master.metastore.rocks.RocksBlockStore
 
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;
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(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 class alluxio.grpc.CommitBlockInUfsPRequest.Builder
the id of the worker
getBlockId() - Method in class alluxio.grpc.CommitBlockInUfsPRequest
the id of the worker
getBlockId() - Method in interface alluxio.grpc.CommitBlockInUfsPRequestOrBuilder
the id of the worker
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.CreateLocalBlockRequest.Builder
optional int64 block_id = 1;
getBlockId() - Method in class alluxio.grpc.CreateLocalBlockRequest
optional int64 block_id = 1;
getBlockId() - Method in interface alluxio.grpc.CreateLocalBlockRequestOrBuilder
optional int64 block_id = 1;
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.OpenLocalBlockRequest.Builder
optional int64 block_id = 1;
getBlockId() - Method in class alluxio.grpc.OpenLocalBlockRequest
optional int64 block_id = 1;
getBlockId() - Method in interface alluxio.grpc.OpenLocalBlockRequestOrBuilder
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.load.LoadDefinition.LoadTask
 
getBlockId() - Method in class alluxio.job.plan.replicate.EvictConfig
 
getBlockId() - Method in class alluxio.job.plan.replicate.MoveConfig
 
getBlockId() - Method in class alluxio.job.plan.replicate.ReplicateConfig
 
getBlockId() - Method in class alluxio.master.block.meta.MasterBlockInfo
 
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 class alluxio.worker.block.evictor.BlockTransferInfo
 
getBlockId() - Method in class alluxio.worker.block.meta.AbstractBlockMeta
 
getBlockId() - Method in class alluxio.worker.block.meta.UnderFileSystemBlockMeta
 
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 class 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() - Method in class alluxio.client.block.policy.options.GetWorkerOptions
 
getBlockInfo(long) - Method in class alluxio.client.block.RetryHandlingBlockMasterClient
Returns the BlockInfo for a block id.
getBlockInfo(long) - Method in class alluxio.client.file.options.InStreamOptions
 
getBlockInfo(long) - Method in class alluxio.client.file.URIStatus
 
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.BlockMasterClientServiceImplBase
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(Long) - Method in class alluxio.master.block.BlockMasterClientRestServiceHandler
Deprecated.
 
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;
GetBlockInfoCommand - Class in alluxio.cli.fsadmin.command
Command for getting information from a block id.
GetBlockInfoCommand(Context, AlluxioConfiguration) - Constructor for class alluxio.cli.fsadmin.command.GetBlockInfoCommand
 
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
 
getBlockInUfsTier() - Method in class alluxio.proto.dataserver.Protocol.OpenUfsBlockOptions.Builder
If set to true, the block is possibly stored as a UFS block.
getBlockInUfsTier() - Method in class alluxio.proto.dataserver.Protocol.OpenUfsBlockOptions
If set to true, the block is possibly stored as a UFS block.
getBlockInUfsTier() - Method in interface alluxio.proto.dataserver.Protocol.OpenUfsBlockOptionsOrBuilder
If set to true, the block is possibly stored as a UFS block.
getBlockIterator() - Method in class alluxio.worker.block.evictor.AbstractEvictor
Returns an iterator for evictor cache blocks.
getBlockIterator() - Method in class alluxio.worker.block.evictor.LRFUEvictor
 
getBlockIterator() - Method in class alluxio.worker.block.evictor.LRUEvictor
 
getBlockLength() - Method in class alluxio.util.webui.UIFileBlockInfo
Gets block length.
getBlockList() - Method in interface alluxio.worker.block.BlockStoreMeta
getBlockList() - Method in class alluxio.worker.block.DefaultBlockStoreMeta
 
getBlockListByStorageLocation() - Method in interface alluxio.worker.block.BlockStoreMeta
getBlockListByStorageLocation() - Method in class alluxio.worker.block.DefaultBlockStoreMeta
 
getBlockLocation() - Method in class alluxio.worker.block.meta.AbstractBlockMeta
 
getBlockLocations(AlluxioURI) - Method in class alluxio.client.file.BaseFileSystem
 
getBlockLocations(AlluxioURI) - Method in class alluxio.client.file.DelegatingFileSystem
 
getBlockLocations(AlluxioURI) - 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(AlluxioURI) - Method in class alluxio.hadoop.AlluxioHdfsFileSystem
 
getBlockLocations() - Method in class alluxio.master.block.meta.MasterBlockInfo
Gets the net addresses for all workers which have the block's data in their tiered storage.
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) - 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.BlockMasterClientServiceImplBase
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) - Method in class alluxio.worker.block.BlockMetadataEvictorView
Returns null if block is pinned or currently being locked, otherwise returns BlockMetadataManager.getBlockMeta(long).
getBlockMeta(long) - Method in class alluxio.worker.block.BlockMetadataManager
Gets the metadata of a block given its block id.
getBlockMeta(long, long, long) - Method in interface alluxio.worker.block.BlockStore
Gets the metadata of a specific block from local storage.
getBlockMeta(long, long, long) - Method in interface alluxio.worker.block.BlockWorker
Gets the metadata of a specific block from local storage.
getBlockMeta(long, long, long) - Method in class alluxio.worker.block.DefaultBlockWorker
 
getBlockMeta(long) - Method in class alluxio.worker.block.meta.StorageDir
Gets the BlockMeta from this storage dir by its block id.
getBlockMeta(long, long, long) - Method in class alluxio.worker.block.TieredBlockStore
 
getBlockMetadataEvictorView() - Method in class alluxio.worker.block.meta.StorageTierEvictorView
 
getBlockPath(long, BlockStoreLocation) - Method in class alluxio.worker.block.BlockMetadataManager
Returns the path of a block given its location, or null if the location is not a specific StorageDir.
getBlockReader(long, long, long) - Method in interface alluxio.worker.block.BlockStore
Creates a reader of an existing block to read data from this block.
getBlockReader(long, long, long) - Method in class alluxio.worker.block.TieredBlockStore
 
getBlockReader(long, long, long, boolean) - Method in class alluxio.worker.block.UnderFileSystemBlockStore
Creates a block reader that reads from UFS and optionally caches the block to the Alluxio block store.
getBlockReader() - Method in class alluxio.worker.grpc.BlockReadRequestContext
 
getBlocks() - Method in class alluxio.master.block.meta.MasterWorkerInfo
 
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 class alluxio.worker.block.meta.StorageDir
Returns the list of blocks stored in this dir.
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.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 class alluxio.worker.block.meta.AbstractBlockMeta
 
getBlockSize() - Method in class alluxio.worker.block.meta.BlockMeta
 
getBlockSize() - Method in class alluxio.worker.block.meta.TempBlockMeta
 
getBlockSize() - Method in class alluxio.worker.block.meta.UnderFileSystemBlockMeta
 
getBlockSizeByte(String) - Method in class alluxio.concurrent.ManagedBlockingUfsForwarder
 
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
 
getBlockSizeByte(String) - Method in class alluxio.underfs.web.WebUnderFileSystem
 
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.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.
getBlockStore() - Method in interface alluxio.worker.block.BlockWorker
 
getBlockStore() - Method in class alluxio.worker.block.DefaultBlockWorker
 
getBlockStoreFactory() - Method in class alluxio.master.CoreMasterContext
 
getBlockStoreFactory(String) - Static method in class alluxio.master.MasterUtils
 
getBlockStoreMeta() - Method in class alluxio.worker.block.BlockMetadataManager
Gets a summary of the metadata.
getBlockStoreMeta() - Method in interface alluxio.worker.block.BlockStore
Gets the metadata of the entire store in a snapshot.
getBlockStoreMeta() - Method in class alluxio.worker.block.TieredBlockStore
 
getBlockStoreMetaFull() - Method in class alluxio.worker.block.BlockMetadataManager
Gets a full summary of block store metadata.
getBlockStoreMetaFull() - Method in interface alluxio.worker.block.BlockStore
Similar as BlockStore.getBlockStoreMeta() except that this includes more information about the block store (e.g.
getBlockStoreMetaFull() - Method in class alluxio.worker.block.TieredBlockStore
 
getBlockWorkerInfos() - Method in class alluxio.client.block.policy.options.GetWorkerOptions
 
getBlockWriter(long, long) - Method in interface alluxio.worker.block.BlockStore
Creates a writer to write data to a temp block.
getBlockWriter(long, long) - Method in class alluxio.worker.block.TieredBlockStore
 
getBlockWriter() - Method in class alluxio.worker.grpc.BlockWriteRequestContext
 
getBoolean(PropertyKey) - Method in interface alluxio.conf.AlluxioConfiguration
Gets the boolean representation of the value for the given key.
getBoolean(PropertyKey) - Method in class alluxio.conf.InstancedConfiguration
 
getBoolean(PropertyKey) - Method in class alluxio.conf.path.SpecificPathConfiguration
 
getBoolean(PropertyKey) - Static method in class alluxio.conf.ServerConfiguration
Gets the boolean representation of the value for the given key.
getBooleanStats() - Method in class alluxio.grpc.table.ColumnStatisticsData.Builder
optional .alluxio.grpc.table.BooleanColumnStatsData boolean_stats = 1;
getBooleanStats() - Method in class alluxio.grpc.table.ColumnStatisticsData
optional .alluxio.grpc.table.BooleanColumnStatsData boolean_stats = 1;
getBooleanStats() - Method in interface alluxio.grpc.table.ColumnStatisticsDataOrBuilder
optional .alluxio.grpc.table.BooleanColumnStatsData boolean_stats = 1;
getBooleanStatsBuilder() - Method in class alluxio.grpc.table.ColumnStatisticsData.Builder
optional .alluxio.grpc.table.BooleanColumnStatsData boolean_stats = 1;
getBooleanStatsOrBuilder() - Method in class alluxio.grpc.table.ColumnStatisticsData.Builder
optional .alluxio.grpc.table.BooleanColumnStatsData boolean_stats = 1;
getBooleanStatsOrBuilder() - Method in class alluxio.grpc.table.ColumnStatisticsData
optional .alluxio.grpc.table.BooleanColumnStatsData boolean_stats = 1;
getBooleanStatsOrBuilder() - Method in interface alluxio.grpc.table.ColumnStatisticsDataOrBuilder
optional .alluxio.grpc.table.BooleanColumnStatsData boolean_stats = 1;
getBooleanType() - Method in class alluxio.grpc.table.Value.Builder
optional bool boolean_type = 4;
getBooleanType() - Method in class alluxio.grpc.table.Value
optional bool boolean_type = 4;
getBooleanType() - Method in interface alluxio.grpc.table.ValueOrBuilder
optional 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.ListPartsResult
 
getBucket(String, String, String, String) - Method in class alluxio.proxy.s3.S3RestServiceHandler
 
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;
getBucketName() - Method in class alluxio.underfs.kodo.KodoClient
Gets bucketname for kodoclient.
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;
getBuffer() - Method in class alluxio.grpc.DataMessage
 
getBufferFromStream(InputStream) - Static method in class alluxio.grpc.GrpcSerializationUtils
Gets a buffer directly from a gRPC input stream.
getBufferPoolSize() - Method in class alluxio.client.file.cache.store.LocalPageStoreOptions
 
getBufferSize() - Method in class alluxio.client.file.cache.store.LocalPageStoreOptions
 
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
 
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) - Method in class alluxio.conf.InstancedConfiguration
 
getBytes(PropertyKey) - Method in class alluxio.conf.path.SpecificPathConfiguration
 
getBytes(PropertyKey) - Static method in class alluxio.conf.ServerConfiguration
Gets the bytes of the value for the given key.
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() - Method in class alluxio.job.plan.transform.format.csv.CsvWriter
 
getBytes() - Method in class alluxio.job.plan.transform.format.parquet.ParquetWriter
 
getBytes() - Method in class alluxio.job.plan.transform.format.tables.TablesWriter
 
getBytes() - Method in interface alluxio.job.plan.transform.format.TableWriter
Note that the bytes written should take compression and encoding into consideration.
getBytesInBlockStore() - Method in class alluxio.proto.dataserver.Protocol.CreateUfsBlockOptions.Builder
the number of bytes previously written to block store zero if no previous temp block created
getBytesInBlockStore() - Method in class alluxio.proto.dataserver.Protocol.CreateUfsBlockOptions
the number of bytes previously written to block store zero if no previous temp block created
getBytesInBlockStore() - Method in interface alluxio.proto.dataserver.Protocol.CreateUfsBlockOptionsOrBuilder
the number of bytes previously written to block store zero if no previous temp block created
getBytesReserved() - Method in class alluxio.worker.grpc.BlockWriteRequestContext
 
getBytesWritten() - Method in class alluxio.client.file.FileOutStream
Deprecated.
this method will not work if more than MAX_INT bytes are written; to get a count of bytes written, wrap this stream in a counting output stream such as org.apache.commons.io.output.CountingOutputStream
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;
getCachedWorkers() - Method in class alluxio.client.file.FileSystemContext
Gets the cached worker information list.
getCacheHitLocal() - Method in class alluxio.wire.MasterWebUIMetrics
Gets cache hit local.
getCacheHitRemote() - Method in class alluxio.wire.MasterWebUIMetrics
Gets cache hit remote.
getCacheMap() - Method in class alluxio.master.metastore.caching.Cache
 
getCacheMiss() - Method in class alluxio.wire.MasterWebUIMetrics
Gets cache miss.
getCacheSize() - Method in interface alluxio.client.file.cache.PageStore
 
getCacheSize() - Method in class alluxio.client.file.cache.store.LocalPageStore
 
getCacheSize() - Method in class alluxio.client.file.cache.store.PageStoreOptions
 
getCacheSize() - Method in class alluxio.client.file.cache.store.RocksPageStore
 
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;
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;
getCanonicalVersion() - Method in enum alluxio.underfs.hdfs.HdfsVersion
 
getCapacity() - Method in class alluxio.util.webui.NodeInfo
Gets capacity.
getCapacity() - Method in class alluxio.util.webui.StorageTierInfo
Gets capacity.
getCapacity() - Method in class alluxio.wire.AlluxioMasterInfo
 
getCapacity() - Method in class alluxio.wire.AlluxioWorkerInfo
 
getCapacity() - Method in class alluxio.wire.MasterWebUIOverview
Gets capacity.
getCapacityBytes() - Method in class alluxio.client.block.AlluxioBlockStore
Gets the total capacity of Alluxio's BlockStore.
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.BlockWorkerInfo
 
getCapacityBytes() - Method in class alluxio.client.block.RetryHandlingBlockMasterClient
Gets the total Alluxio capacity in bytes, on all the tiers of all the workers.
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.BlockMasterClientServiceImplBase
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.master.meta.AlluxioMasterRestServiceHandler
Deprecated.
since version 1.4 and will be removed in version 2.0
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 class alluxio.worker.AlluxioWorkerRestServiceHandler
Deprecated.
since version 1.4 and will be removed in version 2.0
getCapacityBytes() - Method in interface alluxio.worker.block.BlockStoreMeta
 
getCapacityBytes() - Method in class alluxio.worker.block.DefaultBlockStoreMeta
 
getCapacityBytes() - Method in class 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 class alluxio.worker.block.meta.StorageDirView
Gets capacity bytes for this dir.
getCapacityBytes() - Method in class alluxio.worker.block.meta.StorageTier
 
GetCapacityBytesCommand - Class in alluxio.cli.fs.command
Gets the capacity of the FileSystem.
GetCapacityBytesCommand(FileSystemContext) - Constructor for class alluxio.cli.fs.command.GetCapacityBytesCommand
Constructs a new instance to get the capacity of the FileSystem.
getCapacityBytesOnDirs() - Method in interface alluxio.worker.block.BlockStoreMeta
 
getCapacityBytesOnDirs() - Method in class alluxio.worker.block.DefaultBlockStoreMeta
 
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.master.meta.AlluxioMasterRestServiceHandler
Deprecated.
since version 1.4 and will be removed in version 2.0
getCapacityBytesOnTiers() - Method in class alluxio.wire.BlockMasterInfo
 
getCapacityBytesOnTiers() - Method in class alluxio.wire.WorkerInfo
 
getCapacityBytesOnTiers() - Method in class alluxio.worker.AlluxioWorkerRestServiceHandler
Deprecated.
since version 1.4 and will be removed in version 2.0
getCapacityBytesOnTiers() - Method in interface alluxio.worker.block.BlockStoreMeta
 
getCapacityBytesOnTiers() - Method in class alluxio.worker.block.DefaultBlockStoreMeta
 
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
 
getChangedFiles(AlluxioURI) - Method in class alluxio.SyncInfo
REturns a set of changed files.
getChannel() - Method in class alluxio.grpc.GrpcConnection
 
getChannel() - Method in interface alluxio.worker.block.io.BlockReader
Returns a readable byte channel of the block.
getChannel() - Method in interface alluxio.worker.block.io.BlockWriter
 
getChannel() - Method in class alluxio.worker.block.io.LocalFileBlockReader
 
getChannel() - Method in class alluxio.worker.block.io.LocalFileBlockWriter
 
getChannel() - Method in class alluxio.worker.block.RemoteBlockReader
 
getChannel() - Method in class alluxio.worker.block.UnderFileSystemBlockReader
 
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.GrpcConnection
 
getChannelKey() - Method in class alluxio.grpc.GrpcConnectionKey
 
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.
getCheckConsistencyMethod() - Static method in class alluxio.grpc.FileSystemMasterClientServiceGrpc
 
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.file.activesync.ActiveSyncManager
 
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.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.RocksInodeStore
 
getCheckpointName() - Method in class alluxio.master.table.AlluxioCatalog
 
getCheckpointName() - Method in class alluxio.master.table.Database
 
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
 
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(InodeDirectoryView, String) - 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(InodeDirectoryView) - Method in interface alluxio.master.metastore.ReadOnlyInodeStore
 
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
 
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;
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;
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.WriteRequest.Builder
optional .alluxio.grpc.block.Chunk chunk = 2;
getChunk() - Method in class alluxio.grpc.WriteRequest
optional .alluxio.grpc.block.Chunk chunk = 2;
getChunk() - Method in interface alluxio.grpc.WriteRequestOrBuilder
optional .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
optional .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
optional .alluxio.grpc.block.Chunk chunk = 2;
getChunkOrBuilder() - Method in class alluxio.grpc.WriteRequest
optional .alluxio.grpc.block.Chunk chunk = 2;
getChunkOrBuilder() - Method in interface alluxio.grpc.WriteRequestOrBuilder
optional .alluxio.grpc.block.Chunk chunk = 2;
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;
getClass(PropertyKey) - Method in interface alluxio.conf.AlluxioConfiguration
Gets the value for the given key as a class.
getClass(PropertyKey) - Method in class alluxio.conf.InstancedConfiguration
 
getClass(PropertyKey) - Method in class alluxio.conf.path.SpecificPathConfiguration
 
getClass(PropertyKey) - Static method in class alluxio.conf.ServerConfiguration
Gets the value for the given key as a class.
getClassName() - Method in enum alluxio.master.MasterHealthCheckClient.MasterType
 
getCleanupOnFailure() - Method in class alluxio.grpc.CreateLocalBlockRequest.Builder
optional bool cleanup_on_failure = 6;
getCleanupOnFailure() - Method in class alluxio.grpc.CreateLocalBlockRequest
optional bool cleanup_on_failure = 6;
getCleanupOnFailure() - Method in interface alluxio.grpc.CreateLocalBlockRequestOrBuilder
optional bool cleanup_on_failure = 6;
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.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.
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;
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
 
getClientUser(AlluxioConfiguration) - Static method in class alluxio.security.authentication.AuthenticatedClientUser
Gets the user name from the ThreadLocal variable.
getClock() - Method in class alluxio.time.TimeContext
 
getCloser() - Method in class alluxio.grpc.GrpcService
Gets the closer associated with this service.
getClusterAddresses() - Method in class alluxio.master.journal.raft.RaftJournalConfiguration
 
getClusterConf() - Method in class alluxio.client.file.FileSystemContext
 
getClusterConf() - Method in class alluxio.ClientContext
 
getClusterConf(GetConfigurationPResponse, AlluxioConfiguration, Scope) - Static method in class alluxio.util.ConfigurationUtils
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
 
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;
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;
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;
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;
getCmd() - Method in class alluxio.shell.CommandReturn
Gets the command run.
getCode() - Method in class alluxio.proxy.s3.S3Error
 
getCode() - Method in class alluxio.proxy.s3.S3ErrorCode
 
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.
getColumn(String) - Method in class alluxio.job.plan.transform.format.csv.CsvRow
 
getColumn(String) - Method in class alluxio.job.plan.transform.format.parquet.ParquetRow
 
getColumn(String) - Method in interface alluxio.job.plan.transform.format.TableRow
 
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
getColumnStatsData() - Method in interface alluxio.table.common.Layout
 
getColumnStatsData() - Method in class alluxio.table.common.layout.HiveLayout
 
getComfigCheckWarnNum() - Method in class alluxio.wire.MasterWebUIOverview
Gets comfig check warn num.
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.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
optional .alluxio.grpc.block.WriteRequestCommand command = 1;
getCommand() - Method in class alluxio.grpc.WriteRequest
optional .alluxio.grpc.block.WriteRequestCommand command = 1;
getCommand() - Method in interface alluxio.grpc.WriteRequestOrBuilder
optional .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
optional .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.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.CheckConsistencyCommand
 
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.CopyFromLocalCommand
 
getCommandName() - Method in class alluxio.cli.fs.command.CopyToLocalCommand
 
getCommandName() - Method in class alluxio.cli.fs.command.CountCommand
 
getCommandName() - Method in class alluxio.cli.fs.command.CpCommand
 
getCommandName() - Method in class alluxio.cli.fs.command.DistributedCpCommand
 
getCommandName() - Method in class alluxio.cli.fs.command.DistributedLoadCommand
 
getCommandName() - Method in class alluxio.cli.fs.command.DistributedMvCommand
 
getCommandName() - Method in class alluxio.cli.fs.command.DuCommand
 
getCommandName() - Method in class alluxio.cli.fs.command.FreeCommand
 
getCommandName() - Method in class alluxio.cli.fs.command.GetCapacityBytesCommand
 
getCommandName() - Method in class alluxio.cli.fs.command.GetFaclCommand
 
getCommandName() - Method in class alluxio.cli.fs.command.GetSyncPathListCommand
 
getCommandName() - Method in class alluxio.cli.fs.command.GetUsedBytesCommand
 
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.LeaderCommand
 
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.MasterInfoCommand
 
getCommandName() - Method in class alluxio.cli.fs.command.MkdirCommand
 
getCommandName() - Method in class alluxio.cli.fs.command.MountCommand
 
getCommandName() - Method in class alluxio.cli.fs.command.MvCommand
 
getCommandName() - Method in class alluxio.cli.fs.command.PersistCommand
 
getCommandName() - Method in class alluxio.cli.fs.command.PinCommand
 
getCommandName() - Method in class alluxio.cli.fs.command.RmCommand
 
getCommandName() - Method in class alluxio.cli.fs.command.SetFaclCommand
 
getCommandName() - Method in class alluxio.cli.fs.command.SetReplicationCommand
 
getCommandName() - Method in class alluxio.cli.fs.command.SetTtlCommand
 
getCommandName() - Method in class alluxio.cli.fs.command.StartSyncCommand
 
getCommandName() - Method in class alluxio.cli.fs.command.StatCommand
 
getCommandName() - Method in class alluxio.cli.fs.command.StopSyncCommand
 
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.fs.command.UnmountCommand
 
getCommandName() - Method in class alluxio.cli.fs.command.UnpinCommand
 
getCommandName() - Method in class alluxio.cli.fs.command.UnsetTtlCommand
 
getCommandName() - Method in class alluxio.cli.fs.command.UpdateMountCommand
 
getCommandName() - Method in class alluxio.cli.fsadmin.command.BackupCommand
 
getCommandName() - Method in class alluxio.cli.fsadmin.command.DoctorCommand
 
getCommandName() - Method in class alluxio.cli.fsadmin.command.GetBlockInfoCommand
 
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.PathConfCommand
 
getCommandName() - Method in class alluxio.cli.fsadmin.command.ReportCommand
 
getCommandName() - Method in class alluxio.cli.fsadmin.command.UfsCommand
 
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.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.pathconf.AddCommand
 
getCommandName() - Method in class alluxio.cli.fsadmin.pathconf.ListCommand
 
getCommandName() - Method in class alluxio.cli.fsadmin.pathconf.RemoveCommand
 
getCommandName() - Method in class alluxio.cli.fsadmin.pathconf.ShowCommand
 
getCommandName() - Method in class alluxio.cli.job.command.CancelCommand
 
getCommandName() - Method in class alluxio.cli.job.command.LeaderCommand
 
getCommandName() - Method in class alluxio.cli.job.command.ListCommand
 
getCommandName() - Method in class alluxio.cli.job.command.StatCommand
 
getCommandName() - Method in class alluxio.cli.table.command.AbstractTableCommand
 
getCommandName() - Method in class alluxio.cli.table.command.AttachDatabaseCommand
 
getCommandName() - Method in class alluxio.cli.table.command.DetachDatabaseCommand
 
getCommandName() - Method in class alluxio.cli.table.command.ListDatabasesCommand
 
getCommandName() - Method in class alluxio.cli.table.command.SyncDatabaseCommand
 
getCommandName() - Method in class alluxio.cli.table.command.TransformStatusCommand
 
getCommandName() - Method in class alluxio.cli.table.command.TransformTableCommand
 
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
optional .alluxio.grpc.block.WriteRequestCommand command = 1;
getCommandOrBuilder() - Method in class alluxio.grpc.WriteRequest
optional .alluxio.grpc.block.WriteRequestCommand command = 1;
getCommandOrBuilder() - Method in interface alluxio.grpc.WriteRequestOrBuilder
optional .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;
getComment() - Method in class alluxio.job.plan.transform.FieldSchema
 
getComment() - Method in class alluxio.master.table.DatabaseInfo
 
getComment() - Method in class alluxio.proto.journal.Table.UpdateDatabaseInfoEntry.Builder
optional string comment = 6;
getComment() - Method in class alluxio.proto.journal.Table.UpdateDatabaseInfoEntry
optional string comment = 6;
getComment() - Method in interface alluxio.proto.journal.Table.UpdateDatabaseInfoEntryOrBuilder
optional string comment = 6;
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;
getCommentBytes() - Method in class alluxio.proto.journal.Table.UpdateDatabaseInfoEntry.Builder
optional string comment = 6;
getCommentBytes() - Method in class alluxio.proto.journal.Table.UpdateDatabaseInfoEntry
optional string comment = 6;
getCommentBytes() - Method in interface alluxio.proto.journal.Table.UpdateDatabaseInfoEntryOrBuilder
optional string comment = 6;
getCommitBlockInUfsMethod() - Static method in class alluxio.grpc.BlockMasterWorkerServiceGrpc
 
getCommitBlockMethod() - Static method in class alluxio.grpc.BlockMasterWorkerServiceGrpc
 
getCommitPath() - Method in class alluxio.worker.block.meta.TempBlockMeta
 
getCommittedBytes() - Method in class alluxio.worker.block.meta.StorageDir
Gets the total size of committed blocks in this StorageDir in bytes.
getCommittedBytes() - Method in class alluxio.worker.block.meta.StorageDirView
Gets committed bytes for this dir.
getCommonOptions() - Method in class alluxio.client.file.options.OutStreamOptions
 
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.StartSyncPOptions.Builder
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 1;
getCommonOptions() - Method in class alluxio.grpc.StartSyncPOptions
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 1;
getCommonOptions() - Method in interface alluxio.grpc.StartSyncPOptionsOrBuilder
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 1;
getCommonOptions() - Method in class alluxio.grpc.StopSyncPOptions.Builder
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 1;
getCommonOptions() - Method in class alluxio.grpc.StopSyncPOptions
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 1;
getCommonOptions() - Method in interface alluxio.grpc.StopSyncPOptionsOrBuilder
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 1;
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.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.StartSyncPOptions.Builder
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 1;
getCommonOptionsBuilder() - Method in class alluxio.grpc.StopSyncPOptions.Builder
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 1;
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.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.StartSyncPOptions.Builder
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 1;
getCommonOptionsOrBuilder() - Method in class alluxio.grpc.StartSyncPOptions
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 1;
getCommonOptionsOrBuilder() - Method in interface alluxio.grpc.StartSyncPOptionsOrBuilder
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 1;
getCommonOptionsOrBuilder() - Method in class alluxio.grpc.StopSyncPOptions.Builder
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 1;
getCommonOptionsOrBuilder() - Method in class alluxio.grpc.StopSyncPOptions
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 1;
getCommonOptionsOrBuilder() - Method in interface alluxio.grpc.StopSyncPOptionsOrBuilder
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 1;
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 interface alluxio.underfs.ObjectUnderFileSystem.ObjectListingChunk
Use common prefixes to infer pseudo-directories in object store.
getCommonRoots() - Method in class alluxio.conf.path.TrieNode
 
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;
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.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.
getCompleteTransformTable() - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
optional .alluxio.proto.journal.CompleteTransformTableEntry complete_transform_table = 48;
getCompleteTransformTable() - Method in class alluxio.proto.journal.Journal.JournalEntry
optional .alluxio.proto.journal.CompleteTransformTableEntry complete_transform_table = 48;
getCompleteTransformTable() - Method in interface alluxio.proto.journal.Journal.JournalEntryOrBuilder
optional .alluxio.proto.journal.CompleteTransformTableEntry complete_transform_table = 48;
getCompleteTransformTableBuilder() - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
optional .alluxio.proto.journal.CompleteTransformTableEntry complete_transform_table = 48;
getCompleteTransformTableOrBuilder() - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
optional .alluxio.proto.journal.CompleteTransformTableEntry complete_transform_table = 48;
getCompleteTransformTableOrBuilder() - Method in class alluxio.proto.journal.Journal.JournalEntry
optional .alluxio.proto.journal.CompleteTransformTableEntry complete_transform_table = 48;
getCompleteTransformTableOrBuilder() - Method in interface alluxio.proto.journal.Journal.JournalEntryOrBuilder
optional .alluxio.proto.journal.CompleteTransformTableEntry complete_transform_table = 48;
getCompressionType() - Method in class alluxio.client.file.cache.store.RocksPageStoreOptions
 
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.BaseFileSystem
 
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.hadoop.AlluxioHdfsFileSystem
 
getConf() - Method in class alluxio.multi.process.Master
 
getConfAddress() - Method in class alluxio.AbstractClient
 
getConfAddress() - Method in class alluxio.AbstractMasterClient
 
getConfAddress() - Method in interface alluxio.Client
 
getConfig() - Method in class alluxio.master.table.Database
 
getConfig() - Method in class alluxio.proto.journal.Table.AttachDbEntry.Builder
Deprecated.
getConfig() - Method in class alluxio.proto.journal.Table.AttachDbEntry
Deprecated.
getConfig() - Method in interface alluxio.proto.journal.Table.AttachDbEntryOrBuilder
Deprecated.
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.ServerConfigurationChecker
 
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.
getConfigCheckWarns() - Method in class alluxio.wire.MasterWebUIOverview
Gets config check warns.
getConfigCount() - Method in class alluxio.proto.journal.Table.AttachDbEntry.Builder
 
getConfigCount() - Method in class alluxio.proto.journal.Table.AttachDbEntry
 
getConfigCount() - Method in interface alluxio.proto.journal.Table.AttachDbEntryOrBuilder
map<string, string> config = 5;
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) - 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.MetaMasterConfigurationServiceImplBase
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
 
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
 
getConfigMap() - Method in class alluxio.proto.journal.Table.AttachDbEntry.Builder
map<string, string> config = 5;
getConfigMap() - Method in class alluxio.proto.journal.Table.AttachDbEntry
map<string, string> config = 5;
getConfigMap() - Method in interface alluxio.proto.journal.Table.AttachDbEntryOrBuilder
map<string, string> config = 5;
getConfigOrDefault(String, String) - Method in class alluxio.proto.journal.Table.AttachDbEntry.Builder
map<string, string> config = 5;
getConfigOrDefault(String, String) - Method in class alluxio.proto.journal.Table.AttachDbEntry
map<string, string> config = 5;
getConfigOrDefault(String, String) - Method in interface alluxio.proto.journal.Table.AttachDbEntryOrBuilder
map<string, string> config = 5;
getConfigOrThrow(String) - Method in class alluxio.proto.journal.Table.AttachDbEntry.Builder
map<string, string> config = 5;
getConfigOrThrow(String) - Method in class alluxio.proto.journal.Table.AttachDbEntry
map<string, string> config = 5;
getConfigOrThrow(String) - Method in interface alluxio.proto.journal.Table.AttachDbEntryOrBuilder
map<string, string> config = 5;
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) - 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.MetaMasterClientServiceImplBase
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(AlluxioURI, PropertyKey) - Method in interface alluxio.conf.path.PathConfiguration
 
getConfiguration(AlluxioURI, PropertyKey) - Method in class alluxio.conf.path.PrefixPathConfiguration
 
getConfiguration() - Method in class alluxio.grpc.GrpcConnection
 
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.MetaMasterConfigurationServiceImplBase
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() - Method in class alluxio.master.meta.AlluxioMasterRestServiceHandler
Deprecated.
since version 1.4 and will be removed in version 2.0
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(AlluxioConfiguration, Scope) - Static method in class alluxio.util.ConfigurationUtils
Gets all configuration properties filtered by the specified scope.
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.worker.AlluxioWorkerRestServiceHandler
Deprecated.
since version 1.4 and will be removed in version 2.0
getConfigurationFromHadoop(Configuration) - Static method in class alluxio.hadoop.HadoopConfigurationUtils
Extracts relevant configuration from Hadoop Configuration.
getConfigurationFromUri(URI) - Method in class alluxio.hadoop.AbstractFileSystem
Gets the connection configuration from the input uri.
getConfigurationFromUri(URI) - 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.ServerConfigurationStore
 
getConfMasterInquireClient() - Method in class alluxio.master.MasterClientContext
 
getConfMasterInquireClient() - Method in class alluxio.worker.job.JobMasterClientContext
 
getConnectAddress(NetworkAddressUtils.ServiceType, AlluxioConfiguration) - Static method in class alluxio.util.network.NetworkAddressUtils
Helper method to get the InetSocketAddress address for client to communicate with the service.
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.ServiceType, 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
 
getConnectionUri() - Method in class alluxio.table.common.udb.UdbContext
 
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;
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.underfs.ObjectUnderFileSystem.ObjectStatus
 
getContentHash() - Method in class alluxio.underfs.UfsFileStatus
 
getContentLength() - Method in class alluxio.underfs.ObjectUnderFileSystem.ObjectStatus
Gets the size of object contents in bytes.
getContentLength() - Method in class alluxio.underfs.UfsFileStatus
Get the content size in bytes.
getContents() - Method in class alluxio.proxy.s3.ListBucketResult
 
getContext() - Method in class alluxio.master.table.Database
 
getContext(Class<?>) - Method in class alluxio.web.JacksonProtobufObjectMapperProvider
 
getContinuationToken() - Method in class alluxio.proxy.s3.ListBucketOptions
 
getContinuationToken() - Method in class alluxio.proxy.s3.ListBucketResult
 
getCoordinator(long) - Method in class alluxio.master.job.plan.PlanTracker
Gets a PlanCoordinator associated with the given job Id.
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.ReadRequestContext
 
getCounter() - Method in class alluxio.worker.grpc.WriteRequestContext
 
getCpuLoadAverage() - Method in class alluxio.worker.job.command.JobWorkerHealthReporter
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;
getCreateDirectoryMethod() - Static method in class alluxio.grpc.FileSystemMasterClientServiceGrpc
 
getCreateFileMethod() - Static method in class alluxio.grpc.FileSystemMasterClientServiceGrpc
 
getCreateLocalBlockMethod() - Static method in class alluxio.grpc.BlockWorkerGrpc
 
getCreateOptions() - Method in class alluxio.worker.grpc.UfsFileWriteRequestContext
 
getCreateParent() - Method in class alluxio.underfs.options.CreateOptions
 
getCreateParent() - Method in class alluxio.underfs.options.MkdirsOptions
 
getCreateUfsBlockOptions() - Method in class alluxio.grpc.WriteRequestCommand.Builder
optional .alluxio.proto.dataserver.CreateUfsBlockOptions create_ufs_block_options = 7;
getCreateUfsBlockOptions() - Method in class alluxio.grpc.WriteRequestCommand
optional .alluxio.proto.dataserver.CreateUfsBlockOptions create_ufs_block_options = 7;
getCreateUfsBlockOptions() - Method in interface alluxio.grpc.WriteRequestCommandOrBuilder
optional .alluxio.proto.dataserver.CreateUfsBlockOptions create_ufs_block_options = 7;
getCreateUfsBlockOptions() - Method in class alluxio.worker.grpc.BlockWriteRequest
 
getCreateUfsBlockOptionsBuilder() - Method in class alluxio.grpc.WriteRequestCommand.Builder
optional .alluxio.proto.dataserver.CreateUfsBlockOptions create_ufs_block_options = 7;
getCreateUfsBlockOptionsOrBuilder() - Method in class alluxio.grpc.WriteRequestCommand.Builder
optional .alluxio.proto.dataserver.CreateUfsBlockOptions create_ufs_block_options = 7;
getCreateUfsBlockOptionsOrBuilder() - Method in class alluxio.grpc.WriteRequestCommand
optional .alluxio.proto.dataserver.CreateUfsBlockOptions create_ufs_block_options = 7;
getCreateUfsBlockOptionsOrBuilder() - Method in interface alluxio.grpc.WriteRequestCommandOrBuilder
optional .alluxio.proto.dataserver.CreateUfsBlockOptions create_ufs_block_options = 7;
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.worker.grpc.UfsFileWriteRequest
 
getCreateUfsFileOptionsBuilder() - 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.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.
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
 
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.
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.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 interface alluxio.table.common.Layout
 
getData() - Method in class alluxio.table.common.layout.HiveLayout
 
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) - 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.TableMasterClientServiceImplBase
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
getDatabase(String) - Method in class alluxio.master.table.AlluxioCatalog
Get Database by its name.
getDatabase(String) - Method in class alluxio.master.table.DefaultTableMaster
 
getDatabase(String) - Method in interface alluxio.master.table.TableMaster
Gets a database object.
getDatabase(GetDatabasePRequest, StreamObserver<GetDatabasePResponse>) - Method in class alluxio.master.table.TableMasterClientServiceHandler
 
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;
getDatabaseInfo() - Method in class alluxio.master.table.Database
 
getDatabaseInfo() - Method in interface alluxio.table.common.udb.UnderDatabase
 
getDatabaseInfo() - Method in class alluxio.table.under.hive.HiveDatabase
 
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
 
getDatabaseType() - Method in class alluxio.job.plan.transform.CompactConfig
 
getDataBindHost() - Method in class alluxio.worker.AlluxioWorkerProcess
 
getDataBindHost() - Method in interface alluxio.worker.WorkerProcess
 
getDataBuffer(BlockReadRequestContext, long, int) - Method in class alluxio.worker.grpc.BlockReadHandler.BlockDataReader
 
getDataBuilder() - Method in class alluxio.grpc.table.ColumnStatisticsInfo.Builder
optional .alluxio.grpc.table.ColumnStatisticsData data = 3;
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
 
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.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;
getDataPoints() - Method in class alluxio.metrics.TimeSeries
 
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.
getDateStats() - Method in class alluxio.grpc.table.ColumnStatisticsData.Builder
optional .alluxio.grpc.table.DateColumnStatsData date_stats = 7;
getDateStats() - Method in class alluxio.grpc.table.ColumnStatisticsData
optional .alluxio.grpc.table.DateColumnStatsData date_stats = 7;
getDateStats() - Method in interface alluxio.grpc.table.ColumnStatisticsDataOrBuilder
optional .alluxio.grpc.table.DateColumnStatsData date_stats = 7;
getDateStatsBuilder() - Method in class alluxio.grpc.table.ColumnStatisticsData.Builder
optional .alluxio.grpc.table.DateColumnStatsData date_stats = 7;
getDateStatsOrBuilder() - Method in class alluxio.grpc.table.ColumnStatisticsData.Builder
optional .alluxio.grpc.table.DateColumnStatsData date_stats = 7;
getDateStatsOrBuilder() - Method in class alluxio.grpc.table.ColumnStatisticsData
optional .alluxio.grpc.table.DateColumnStatsData date_stats = 7;
getDateStatsOrBuilder() - Method in interface alluxio.grpc.table.ColumnStatisticsDataOrBuilder
optional .alluxio.grpc.table.DateColumnStatsData date_stats = 7;
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.master.metastore.rocks.RocksStore
 
getDb() - Method in class alluxio.master.table.transform.TransformJobInfo
 
getDbBuilder() - Method in class alluxio.grpc.table.GetDatabasePResponse.Builder
optional .alluxio.grpc.table.Database db = 1;
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;
getDbName() - Method in class alluxio.proto.journal.Table.AddTableEntry.Builder
optional string db_name = 1;
getDbName() - Method in class alluxio.proto.journal.Table.AddTableEntry
optional string db_name = 1;
getDbName() - Method in interface alluxio.proto.journal.Table.AddTableEntryOrBuilder
optional string db_name = 1;
getDbName() - Method in class alluxio.proto.journal.Table.AddTransformJobInfoEntry.Builder
optional string db_name = 1;
getDbName() - Method in class alluxio.proto.journal.Table.AddTransformJobInfoEntry
optional string db_name = 1;
getDbName() - Method in interface alluxio.proto.journal.Table.AddTransformJobInfoEntryOrBuilder
optional string db_name = 1;
getDbName() - Method in class alluxio.proto.journal.Table.AttachDbEntry.Builder
optional string db_name = 4;
getDbName() - Method in class alluxio.proto.journal.Table.AttachDbEntry
optional string db_name = 4;
getDbName() - Method in interface alluxio.proto.journal.Table.AttachDbEntryOrBuilder
optional string db_name = 4;
getDbName() - Method in class alluxio.proto.journal.Table.CompleteTransformTableEntry.Builder
optional string db_name = 1;
getDbName() - Method in class alluxio.proto.journal.Table.CompleteTransformTableEntry
optional string db_name = 1;
getDbName() - Method in interface alluxio.proto.journal.Table.CompleteTransformTableEntryOrBuilder
optional string db_name = 1;
getDbName() - Method in class alluxio.proto.journal.Table.DetachDbEntry.Builder
optional string db_name = 1;
getDbName() - Method in class alluxio.proto.journal.Table.DetachDbEntry
optional string db_name = 1;
getDbName() - Method in interface alluxio.proto.journal.Table.DetachDbEntryOrBuilder
optional string db_name = 1;
getDbName() - Method in class alluxio.proto.journal.Table.RemoveTableEntry.Builder
optional string db_name = 1;
getDbName() - Method in class alluxio.proto.journal.Table.RemoveTableEntry
optional string db_name = 1;
getDbName() - Method in interface alluxio.proto.journal.Table.RemoveTableEntryOrBuilder
optional string db_name = 1;
getDbName() - Method in class alluxio.proto.journal.Table.RemoveTransformJobInfoEntry.Builder
optional string db_name = 1;
getDbName() - Method in class alluxio.proto.journal.Table.RemoveTransformJobInfoEntry
optional string db_name = 1;
getDbName() - Method in interface alluxio.proto.journal.Table.RemoveTransformJobInfoEntryOrBuilder
optional string db_name = 1;
getDbName() - Method in class alluxio.proto.journal.Table.UpdateDatabaseInfoEntry.Builder
optional string db_name = 1;
getDbName() - Method in class alluxio.proto.journal.Table.UpdateDatabaseInfoEntry
optional string db_name = 1;
getDbName() - Method in interface alluxio.proto.journal.Table.UpdateDatabaseInfoEntryOrBuilder
optional string db_name = 1;
getDbName() - Method in class alluxio.table.common.udb.UdbContext
 
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;
getDbNameBytes() - Method in class alluxio.proto.journal.Table.AddTableEntry.Builder
optional string db_name = 1;
getDbNameBytes() - Method in class alluxio.proto.journal.Table.AddTableEntry
optional string db_name = 1;
getDbNameBytes() - Method in interface alluxio.proto.journal.Table.AddTableEntryOrBuilder
optional string db_name = 1;
getDbNameBytes() - Method in class alluxio.proto.journal.Table.AddTransformJobInfoEntry.Builder
optional string db_name = 1;
getDbNameBytes() - Method in class alluxio.proto.journal.Table.AddTransformJobInfoEntry
optional string db_name = 1;
getDbNameBytes() - Method in interface alluxio.proto.journal.Table.AddTransformJobInfoEntryOrBuilder
optional string db_name = 1;
getDbNameBytes() - Method in class alluxio.proto.journal.Table.AttachDbEntry.Builder
optional string db_name = 4;
getDbNameBytes() - Method in class alluxio.proto.journal.Table.AttachDbEntry
optional string db_name = 4;
getDbNameBytes() - Method in interface alluxio.proto.journal.Table.AttachDbEntryOrBuilder
optional string db_name = 4;
getDbNameBytes() - Method in class alluxio.proto.journal.Table.CompleteTransformTableEntry.Builder
optional string db_name = 1;
getDbNameBytes() - Method in class alluxio.proto.journal.Table.CompleteTransformTableEntry
optional string db_name = 1;
getDbNameBytes() - Method in interface alluxio.proto.journal.Table.CompleteTransformTableEntryOrBuilder
optional string db_name = 1;
getDbNameBytes() - Method in class alluxio.proto.journal.Table.DetachDbEntry.Builder
optional string db_name = 1;
getDbNameBytes() - Method in class alluxio.proto.journal.Table.DetachDbEntry
optional string db_name = 1;
getDbNameBytes() - Method in interface alluxio.proto.journal.Table.DetachDbEntryOrBuilder
optional string db_name = 1;
getDbNameBytes() - Method in class alluxio.proto.journal.Table.RemoveTableEntry.Builder
optional string db_name = 1;
getDbNameBytes() - Method in class alluxio.proto.journal.Table.RemoveTableEntry
optional string db_name = 1;
getDbNameBytes() - Method in interface alluxio.proto.journal.Table.RemoveTableEntryOrBuilder
optional string db_name = 1;
getDbNameBytes() - Method in class alluxio.proto.journal.Table.RemoveTransformJobInfoEntry.Builder
optional string db_name = 1;
getDbNameBytes() - Method in class alluxio.proto.journal.Table.RemoveTransformJobInfoEntry
optional string db_name = 1;
getDbNameBytes() - Method in interface alluxio.proto.journal.Table.RemoveTransformJobInfoEntryOrBuilder
optional string db_name = 1;
getDbNameBytes() - Method in class alluxio.proto.journal.Table.UpdateDatabaseInfoEntry.Builder
optional string db_name = 1;
getDbNameBytes() - Method in class alluxio.proto.journal.Table.UpdateDatabaseInfoEntry
optional string db_name = 1;
getDbNameBytes() - Method in interface alluxio.proto.journal.Table.UpdateDatabaseInfoEntryOrBuilder
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;
getDbTable() - Method in class alluxio.master.table.transform.TransformJobInfo
 
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.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
optional .alluxio.grpc.table.DecimalColumnStatsData decimal_stats = 6;
getDecimalStats() - Method in class alluxio.grpc.table.ColumnStatisticsData
optional .alluxio.grpc.table.DecimalColumnStatsData decimal_stats = 6;
getDecimalStats() - Method in interface alluxio.grpc.table.ColumnStatisticsDataOrBuilder
optional .alluxio.grpc.table.DecimalColumnStatsData decimal_stats = 6;
getDecimalStatsBuilder() - Method in class alluxio.grpc.table.ColumnStatisticsData.Builder
optional .alluxio.grpc.table.DecimalColumnStatsData decimal_stats = 6;
getDecimalStatsOrBuilder() - Method in class alluxio.grpc.table.ColumnStatisticsData.Builder
optional .alluxio.grpc.table.DecimalColumnStatsData decimal_stats = 6;
getDecimalStatsOrBuilder() - Method in class alluxio.grpc.table.ColumnStatisticsData
optional .alluxio.grpc.table.DecimalColumnStatsData decimal_stats = 6;
getDecimalStatsOrBuilder() - Method in interface alluxio.grpc.table.ColumnStatisticsDataOrBuilder
optional .alluxio.grpc.table.DecimalColumnStatsData decimal_stats = 6;
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.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.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.BlockStoreLocationProto
 
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.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.Command
 
getDefaultInstance() - Static method in class alluxio.grpc.CommitBlockInUfsPOptions
 
getDefaultInstance() - Static method in class alluxio.grpc.CommitBlockInUfsPRequest
 
getDefaultInstance() - Static method in class alluxio.grpc.CommitBlockInUfsPResponse
 
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.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.CreateLocalBlockRequest
 
getDefaultInstance() - Static method in class alluxio.grpc.CreateLocalBlockResponse
 
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.ExistsPOptions
 
getDefaultInstance() - Static method in class alluxio.grpc.FileBlockInfo
 
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.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.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.GetJobServiceSummaryPOptions
 
getDefaultInstance() - Static method in class alluxio.grpc.GetJobServiceSummaryPRequest
 
getDefaultInstance() - Static method in class alluxio.grpc.GetJobServiceSummaryPResponse
 
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.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.GetPinnedFileIdsPOptions
 
getDefaultInstance() - Static method in class alluxio.grpc.GetPinnedFileIdsPRequest
 
getDefaultInstance() - Static method in class alluxio.grpc.GetPinnedFileIdsPResponse
 
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.GetServiceVersionPRequest
 
getDefaultInstance() - Static method in class alluxio.grpc.GetServiceVersionPResponse
 
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.GetSyncPathListPRequest
 
getDefaultInstance() - Static method in class alluxio.grpc.GetSyncPathListPResponse
 
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.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.JobServiceSummary
 
getDefaultInstance() - Static method in class alluxio.grpc.JobUnused
 
getDefaultInstance() - Static method in class alluxio.grpc.JobWorkerHealth
 
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.ListStatusPOptions
 
getDefaultInstance() - Static method in class alluxio.grpc.ListStatusPRequest
 
getDefaultInstance() - Static method in class alluxio.grpc.ListStatusPResponse
 
getDefaultInstance() - Static method in class alluxio.grpc.LoadMetadataPOptions
 
getDefaultInstance() - Static method in class alluxio.grpc.LocalityTier
 
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.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.NetAddress
 
getDefaultInstance() - Static method in class alluxio.grpc.OpenFilePOptions
 
getDefaultInstance() - Static method in class alluxio.grpc.OpenLocalBlockRequest
 
getDefaultInstance() - Static method in class alluxio.grpc.OpenLocalBlockResponse
 
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.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.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.RemovePathConfigurationPOptions
 
getDefaultInstance() - Static method in class alluxio.grpc.RemovePathConfigurationPRequest
 
getDefaultInstance() - Static method in class alluxio.grpc.RemovePathConfigurationPResponse
 
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.ReverseResolvePRequest
 
getDefaultInstance() - Static method in class alluxio.grpc.ReverseResolvePResponse
 
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.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.StartSyncPOptions
 
getDefaultInstance() - Static method in class alluxio.grpc.StartSyncPRequest
 
getDefaultInstance() - Static method in class alluxio.grpc.StartSyncPResponse
 
getDefaultInstance() - Static method in class alluxio.grpc.StatusSummary
 
getDefaultInstance() - Static method in class alluxio.grpc.StopSyncPOptions
 
getDefaultInstance() - Static method in class alluxio.grpc.StopSyncPRequest
 
getDefaultInstance() - Static method in class alluxio.grpc.StopSyncPResponse
 
getDefaultInstance() - Static method in class alluxio.grpc.StorageList
 
getDefaultInstance() - Static method in class alluxio.grpc.SyncPointInfo
 
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.TieredIdentity
 
getDefaultInstance() - Static method in class alluxio.grpc.TierList
 
getDefaultInstance() - Static method in class alluxio.grpc.TransportMessage
 
getDefaultInstance() - Static method in class alluxio.grpc.UfsInfo
 
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.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.WorkerInfo
 
getDefaultInstance() - Static method in class alluxio.grpc.WorkerLostStorageInfo
 
getDefaultInstance() - Static method in class alluxio.grpc.WorkerNetAddress
 
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.CreateUfsBlockOptions
 
getDefaultInstance() - Static method in class alluxio.proto.dataserver.Protocol.CreateUfsFileOptions
 
getDefaultInstance() - Static method in class alluxio.proto.dataserver.Protocol.OpenUfsBlockOptions
 
getDefaultInstance() - Static method in class alluxio.proto.dataserver.Protocol.Response
 
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.Journal.JournalEntry
 
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.Table.AddTableEntry
 
getDefaultInstance() - Static method in class alluxio.proto.journal.Table.AddTransformJobInfoEntry
 
getDefaultInstance() - Static method in class alluxio.proto.journal.Table.AttachDbEntry
 
getDefaultInstance() - Static method in class alluxio.proto.journal.Table.CompleteTransformTableEntry
 
getDefaultInstance() - Static method in class alluxio.proto.journal.Table.DetachDbEntry
 
getDefaultInstance() - Static method in class alluxio.proto.journal.Table.RemoveTableEntry
 
getDefaultInstance() - Static method in class alluxio.proto.journal.Table.RemoveTransformJobInfoEntry
 
getDefaultInstance() - Static method in class alluxio.proto.journal.Table.UpdateDatabaseInfoEntry
 
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.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.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.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.BlockStoreLocationProto.Builder
 
getDefaultInstanceForType() - Method in class alluxio.grpc.BlockStoreLocationProto
 
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.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.Command.Builder
 
getDefaultInstanceForType() - Method in class alluxio.grpc.Command
 
getDefaultInstanceForType() - Method in class alluxio.grpc.CommitBlockInUfsPOptions.Builder
 
getDefaultInstanceForType() - Method in class alluxio.grpc.CommitBlockInUfsPOptions
 
getDefaultInstanceForType() - Method in class alluxio.grpc.CommitBlockInUfsPRequest.Builder
 
getDefaultInstanceForType() - Method in class alluxio.grpc.CommitBlockInUfsPRequest
 
getDefaultInstanceForType() - Method in class alluxio.grpc.CommitBlockInUfsPResponse.Builder
 
getDefaultInstanceForType() - Method in class alluxio.grpc.CommitBlockInUfsPResponse
 
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.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.CreateLocalBlockRequest.Builder
 
getDefaultInstanceForType() - Method in class alluxio.grpc.CreateLocalBlockRequest
 
getDefaultInstanceForType() - Method in class alluxio.grpc.CreateLocalBlockResponse.Builder
 
getDefaultInstanceForType() - Method in class alluxio.grpc.CreateLocalBlockResponse
 
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.ExistsPOptions.Builder
 
getDefaultInstanceForType() - Method in class alluxio.grpc.ExistsPOptions
 
getDefaultInstanceForType() - Method in class alluxio.grpc.FileBlockInfo.Builder
 
getDefaultInstanceForType() - Method in class alluxio.grpc.FileBlockInfo
 
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.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.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.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.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.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.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.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.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.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.GetSyncPathListPRequest.Builder
 
getDefaultInstanceForType() - Method in class alluxio.grpc.GetSyncPathListPRequest
 
getDefaultInstanceForType() - Method in class alluxio.grpc.GetSyncPathListPResponse.Builder
 
getDefaultInstanceForType() - Method in class alluxio.grpc.GetSyncPathListPResponse
 
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.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.JobServiceSummary.Builder
 
getDefaultInstanceForType() - Method in class alluxio.grpc.JobServiceSummary
 
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.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.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.LoadMetadataPOptions.Builder
 
getDefaultInstanceForType() - Method in class alluxio.grpc.LoadMetadataPOptions
 
getDefaultInstanceForType() - Method in class alluxio.grpc.LocalityTier.Builder
 
getDefaultInstanceForType() - Method in class alluxio.grpc.LocalityTier
 
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.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.NetAddress.Builder
 
getDefaultInstanceForType() - Method in class alluxio.grpc.NetAddress
 
getDefaultInstanceForType() - Method in class alluxio.grpc.OpenFilePOptions.Builder
 
getDefaultInstanceForType() - Method in class alluxio.grpc.OpenFilePOptions
 
getDefaultInstanceForType() - Method in class alluxio.grpc.OpenLocalBlockRequest.Builder
 
getDefaultInstanceForType() - Method in class alluxio.grpc.OpenLocalBlockRequest
 
getDefaultInstanceForType() - Method in class alluxio.grpc.OpenLocalBlockResponse.Builder
 
getDefaultInstanceForType() - Method in class alluxio.grpc.OpenLocalBlockResponse
 
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.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.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.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.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.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.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.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.StartSyncPOptions.Builder
 
getDefaultInstanceForType() - Method in class alluxio.grpc.StartSyncPOptions
 
getDefaultInstanceForType() - Method in class alluxio.grpc.StartSyncPRequest.Builder
 
getDefaultInstanceForType() - Method in class alluxio.grpc.StartSyncPRequest
 
getDefaultInstanceForType() - Method in class alluxio.grpc.StartSyncPResponse.Builder
 
getDefaultInstanceForType() - Method in class alluxio.grpc.StartSyncPResponse
 
getDefaultInstanceForType() - Method in class alluxio.grpc.StatusSummary.Builder
 
getDefaultInstanceForType() - Method in class alluxio.grpc.StatusSummary
 
getDefaultInstanceForType() - Method in class alluxio.grpc.StopSyncPOptions.Builder
 
getDefaultInstanceForType() - Method in class alluxio.grpc.StopSyncPOptions
 
getDefaultInstanceForType() - Method in class alluxio.grpc.StopSyncPRequest.Builder
 
getDefaultInstanceForType() - Method in class alluxio.grpc.StopSyncPRequest
 
getDefaultInstanceForType() - Method in class alluxio.grpc.StopSyncPResponse.Builder
 
getDefaultInstanceForType() - Method in class alluxio.grpc.StopSyncPResponse
 
getDefaultInstanceForType() - Method in class alluxio.grpc.StorageList.Builder
 
getDefaultInstanceForType() - Method in class alluxio.grpc.StorageList
 
getDefaultInstanceForType() - Method in class alluxio.grpc.SyncPointInfo.Builder
 
getDefaultInstanceForType() - Method in class alluxio.grpc.SyncPointInfo
 
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.TieredIdentity.Builder
 
getDefaultInstanceForType() - Method in class alluxio.grpc.TieredIdentity
 
getDefaultInstanceForType() - Method in class alluxio.grpc.TierList.Builder
 
getDefaultInstanceForType() - Method in class alluxio.grpc.TierList
 
getDefaultInstanceForType() - Method in class alluxio.grpc.TransportMessage.Builder
 
getDefaultInstanceForType() - Method in class alluxio.grpc.TransportMessage
 
getDefaultInstanceForType() - Method in class alluxio.grpc.UfsInfo.Builder
 
getDefaultInstanceForType() - Method in class alluxio.grpc.UfsInfo
 
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.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.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.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.CreateUfsBlockOptions.Builder
 
getDefaultInstanceForType() - Method in class alluxio.proto.dataserver.Protocol.CreateUfsBlockOptions
 
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.OpenUfsBlockOptions.Builder
 
getDefaultInstanceForType() - Method in class alluxio.proto.dataserver.Protocol.OpenUfsBlockOptions
 
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.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.Journal.JournalEntry.Builder
 
getDefaultInstanceForType() - Method in class alluxio.proto.journal.Journal.JournalEntry
 
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.Table.AddTableEntry.Builder
 
getDefaultInstanceForType() - Method in class alluxio.proto.journal.Table.AddTableEntry
 
getDefaultInstanceForType() - Method in class alluxio.proto.journal.Table.AddTransformJobInfoEntry.Builder
 
getDefaultInstanceForType() - Method in class alluxio.proto.journal.Table.AddTransformJobInfoEntry
 
getDefaultInstanceForType() - Method in class alluxio.proto.journal.Table.AttachDbEntry.Builder
 
getDefaultInstanceForType() - Method in class alluxio.proto.journal.Table.AttachDbEntry
 
getDefaultInstanceForType() - Method in class alluxio.proto.journal.Table.CompleteTransformTableEntry.Builder
 
getDefaultInstanceForType() - Method in class alluxio.proto.journal.Table.CompleteTransformTableEntry
 
getDefaultInstanceForType() - Method in class alluxio.proto.journal.Table.DetachDbEntry.Builder
 
getDefaultInstanceForType() - Method in class alluxio.proto.journal.Table.DetachDbEntry
 
getDefaultInstanceForType() - Method in class alluxio.proto.journal.Table.RemoveTableEntry.Builder
 
getDefaultInstanceForType() - Method in class alluxio.proto.journal.Table.RemoveTableEntry
 
getDefaultInstanceForType() - Method in class alluxio.proto.journal.Table.RemoveTransformJobInfoEntry.Builder
 
getDefaultInstanceForType() - Method in class alluxio.proto.journal.Table.RemoveTransformJobInfoEntry
 
getDefaultInstanceForType() - Method in class alluxio.proto.journal.Table.UpdateDatabaseInfoEntry.Builder
 
getDefaultInstanceForType() - Method in class alluxio.proto.journal.Table.UpdateDatabaseInfoEntry
 
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.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 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
 
getDefaultValue() - Method in class alluxio.table.common.BaseProperty
 
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;
getDefinition() - Method in class alluxio.master.table.transform.TransformJobInfo
 
getDefinition() - Method in class alluxio.proto.journal.Table.AddTransformJobInfoEntry.Builder
optional string definition = 3;
getDefinition() - Method in class alluxio.proto.journal.Table.AddTransformJobInfoEntry
optional string definition = 3;
getDefinition() - Method in interface alluxio.proto.journal.Table.AddTransformJobInfoEntryOrBuilder
optional string definition = 3;
getDefinition() - Method in class alluxio.proto.journal.Table.CompleteTransformTableEntry.Builder
optional string definition = 3;
getDefinition() - Method in class alluxio.proto.journal.Table.CompleteTransformTableEntry
optional string definition = 3;
getDefinition() - Method in interface alluxio.proto.journal.Table.CompleteTransformTableEntryOrBuilder
optional string definition = 3;
getDefinition() - Method in class alluxio.table.common.transform.TransformDefinition
 
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;
getDefinitionBytes() - Method in class alluxio.proto.journal.Table.AddTransformJobInfoEntry.Builder
optional string definition = 3;
getDefinitionBytes() - Method in class alluxio.proto.journal.Table.AddTransformJobInfoEntry
optional string definition = 3;
getDefinitionBytes() - Method in interface alluxio.proto.journal.Table.AddTransformJobInfoEntryOrBuilder
optional string definition = 3;
getDefinitionBytes() - Method in class alluxio.proto.journal.Table.CompleteTransformTableEntry.Builder
optional string definition = 3;
getDefinitionBytes() - Method in class alluxio.proto.journal.Table.CompleteTransformTableEntry
optional string definition = 3;
getDefinitionBytes() - Method in interface alluxio.proto.journal.Table.CompleteTransformTableEntryOrBuilder
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.master.table.DefaultTableMaster
 
getDelegate() - Method in class alluxio.master.table.transform.TransformManager
 
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;
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;
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;
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 class alluxio.master.table.DefaultTableMaster
 
getDependencies() - Method in interface alluxio.Server
 
getDependencies() - Method in class alluxio.worker.block.DefaultBlockWorker
 
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.
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.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.CheckConsistencyCommand
 
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.CopyFromLocalCommand
 
getDescription() - Method in class alluxio.cli.fs.command.CopyToLocalCommand
 
getDescription() - Method in class alluxio.cli.fs.command.CountCommand
 
getDescription() - Method in class alluxio.cli.fs.command.CpCommand
 
getDescription() - Method in class alluxio.cli.fs.command.DistributedCpCommand
 
getDescription() - Method in class alluxio.cli.fs.command.DistributedLoadCommand
 
getDescription() - Method in class alluxio.cli.fs.command.DistributedMvCommand
 
getDescription() - Method in class alluxio.cli.fs.command.DuCommand
 
getDescription() - Method in class alluxio.cli.fs.command.FreeCommand
 
getDescription() - Method in class alluxio.cli.fs.command.GetCapacityBytesCommand
 
getDescription() - Method in class alluxio.cli.fs.command.GetFaclCommand
 
getDescription() - Method in class alluxio.cli.fs.command.GetSyncPathListCommand
 
getDescription() - Method in class alluxio.cli.fs.command.GetUsedBytesCommand
 
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.LeaderCommand
 
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.MasterInfoCommand
 
getDescription() - Method in class alluxio.cli.fs.command.MkdirCommand
 
getDescription() - Method in class alluxio.cli.fs.command.MountCommand
 
getDescription() - Method in class alluxio.cli.fs.command.MvCommand
 
getDescription() - Method in class alluxio.cli.fs.command.PersistCommand
 
getDescription() - Method in class alluxio.cli.fs.command.PinCommand
 
getDescription() - Method in class alluxio.cli.fs.command.RmCommand
 
getDescription() - Method in class alluxio.cli.fs.command.SetFaclCommand
 
getDescription() - Method in class alluxio.cli.fs.command.SetReplicationCommand
 
getDescription() - Method in class alluxio.cli.fs.command.SetTtlCommand
 
getDescription() - Method in class alluxio.cli.fs.command.StartSyncCommand
 
getDescription() - Method in class alluxio.cli.fs.command.StatCommand
 
getDescription() - Method in class alluxio.cli.fs.command.StopSyncCommand
 
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.fs.command.UnmountCommand
 
getDescription() - Method in class alluxio.cli.fs.command.UnpinCommand
 
getDescription() - Method in class alluxio.cli.fs.command.UnsetTtlCommand
 
getDescription() - Method in class alluxio.cli.fs.command.UpdateMountCommand
 
getDescription() - Method in class alluxio.cli.fsadmin.command.BackupCommand
 
getDescription() - Method in class alluxio.cli.fsadmin.command.DoctorCommand
 
getDescription() - Method in class alluxio.cli.fsadmin.command.GetBlockInfoCommand
 
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.PathConfCommand
 
getDescription() - Method in class alluxio.cli.fsadmin.command.ReportCommand
 
getDescription() - Method in class alluxio.cli.fsadmin.command.UfsCommand
 
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.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.pathconf.AddCommand
 
getDescription() - Method in class alluxio.cli.fsadmin.pathconf.ListCommand
 
getDescription() - Method in class alluxio.cli.fsadmin.pathconf.RemoveCommand
 
getDescription() - Method in class alluxio.cli.fsadmin.pathconf.ShowCommand
 
getDescription() - Method in class alluxio.cli.job.command.CancelCommand
 
getDescription() - Method in class alluxio.cli.job.command.LeaderCommand
 
getDescription() - Method in class alluxio.cli.job.command.ListCommand
 
getDescription() - Method in class alluxio.cli.job.command.StatCommand
 
getDescription() - Method in class alluxio.cli.table.command.AttachDatabaseCommand
 
getDescription() - Method in class alluxio.cli.table.command.DetachDatabaseCommand
 
getDescription() - Method in class alluxio.cli.table.command.ListDatabasesCommand
 
getDescription() - Method in class alluxio.cli.table.command.SyncDatabaseCommand
 
getDescription() - Method in class alluxio.cli.table.command.TransformStatusCommand
 
getDescription() - Method in class alluxio.cli.table.command.TransformTableCommand
 
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.metrics.MetricKey
 
getDescription() - Method in class alluxio.proxy.s3.S3ErrorCode
 
getDescription() - Method in class alluxio.table.common.BaseProperty
 
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.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.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.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.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.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.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.CommitBlockInUfsPOptions.Builder
 
getDescriptor() - Static method in class alluxio.grpc.CommitBlockInUfsPOptions
 
getDescriptor() - Static method in class alluxio.grpc.CommitBlockInUfsPRequest.Builder
 
getDescriptor() - Static method in class alluxio.grpc.CommitBlockInUfsPRequest
 
getDescriptor() - Static method in class alluxio.grpc.CommitBlockInUfsPResponse.Builder
 
getDescriptor() - Static method in class alluxio.grpc.CommitBlockInUfsPResponse
 
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.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.CreateLocalBlockRequest.Builder
 
getDescriptor() - Static method in class alluxio.grpc.CreateLocalBlockRequest
 
getDescriptor() - Static method in class alluxio.grpc.CreateLocalBlockResponse.Builder
 
getDescriptor() - Static method in class alluxio.grpc.CreateLocalBlockResponse
 
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.ExistsPOptions.Builder
 
getDescriptor() - Static method in class alluxio.grpc.ExistsPOptions
 
getDescriptor() - Static method in class alluxio.grpc.FileBlockInfo.Builder
 
getDescriptor() - Static method in class alluxio.grpc.FileBlockInfo
 
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.FsCommonProto
 
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.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.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.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.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.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.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.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.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.GetSyncPathListPRequest.Builder
 
getDescriptor() - Static method in class alluxio.grpc.GetSyncPathListPRequest
 
getDescriptor() - Static method in class alluxio.grpc.GetSyncPathListPResponse.Builder
 
getDescriptor() - Static method in class alluxio.grpc.GetSyncPathListPResponse
 
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.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.JobMasterProto
 
getDescriptor() - Static method in class alluxio.grpc.JobServiceSummary.Builder
 
getDescriptor() - Static method in class alluxio.grpc.JobServiceSummary
 
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.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.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.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.LocalityTier.Builder
 
getDescriptor() - Static method in class alluxio.grpc.LocalityTier
 
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.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.NetAddress.Builder
 
getDescriptor() - Static method in class alluxio.grpc.NetAddress
 
getDescriptor() - Static method in class alluxio.grpc.OpenFilePOptions.Builder
 
getDescriptor() - Static method in class alluxio.grpc.OpenFilePOptions
 
getDescriptor() - Static method in class alluxio.grpc.OpenLocalBlockRequest.Builder
 
getDescriptor() - Static method in class alluxio.grpc.OpenLocalBlockRequest
 
getDescriptor() - Static method in class alluxio.grpc.OpenLocalBlockResponse.Builder
 
getDescriptor() - Static method in class alluxio.grpc.OpenLocalBlockResponse
 
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.QuorumServerInfo.Builder
 
getDescriptor() - Static method in class alluxio.grpc.QuorumServerInfo
 
getDescriptor() - Static method in enum alluxio.grpc.QuorumServerState
 
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.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.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.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.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.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.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.StartSyncPOptions.Builder
 
getDescriptor() - Static method in class alluxio.grpc.StartSyncPOptions
 
getDescriptor() - Static method in class alluxio.grpc.StartSyncPRequest.Builder
 
getDescriptor() - Static method in class alluxio.grpc.StartSyncPRequest
 
getDescriptor() - Static method in class alluxio.grpc.StartSyncPResponse.Builder
 
getDescriptor() - Static method in class alluxio.grpc.StartSyncPResponse
 
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.StopSyncPOptions.Builder
 
getDescriptor() - Static method in class alluxio.grpc.StopSyncPOptions
 
getDescriptor() - Static method in class alluxio.grpc.StopSyncPRequest.Builder
 
getDescriptor() - Static method in class alluxio.grpc.StopSyncPRequest
 
getDescriptor() - Static method in class alluxio.grpc.StopSyncPResponse.Builder
 
getDescriptor() - Static method in class alluxio.grpc.StopSyncPResponse
 
getDescriptor() - Static method in class alluxio.grpc.StorageList.Builder
 
getDescriptor() - Static method in class alluxio.grpc.StorageList
 
getDescriptor() - Static method in class alluxio.grpc.SyncPointInfo.Builder
 
getDescriptor() - Static method in class alluxio.grpc.SyncPointInfo
 
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 class alluxio.grpc.TieredIdentity.Builder
 
getDescriptor() - Static method in class alluxio.grpc.TieredIdentity
 
getDescriptor() - Static method in class alluxio.grpc.TierList.Builder
 
getDescriptor() - Static method in class alluxio.grpc.TierList
 
getDescriptor() - Static method in class alluxio.grpc.TransportMessage.Builder
 
getDescriptor() - Static method in class alluxio.grpc.TransportMessage
 
getDescriptor() - Static method in enum alluxio.grpc.TtlAction
 
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.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.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.VersionProto
 
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 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 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.CreateUfsBlockOptions.Builder
 
getDescriptor() - Static method in class alluxio.proto.dataserver.Protocol.CreateUfsBlockOptions
 
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.OpenUfsBlockOptions.Builder
 
getDescriptor() - Static method in class alluxio.proto.dataserver.Protocol.OpenUfsBlockOptions
 
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.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 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.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.Table.AddTableEntry.Builder
 
getDescriptor() - Static method in class alluxio.proto.journal.Table.AddTableEntry
 
getDescriptor() - Static method in class alluxio.proto.journal.Table.AddTransformJobInfoEntry.Builder
 
getDescriptor() - Static method in class alluxio.proto.journal.Table.AddTransformJobInfoEntry
 
getDescriptor() - Static method in class alluxio.proto.journal.Table.AttachDbEntry.Builder
 
getDescriptor() - Static method in class alluxio.proto.journal.Table.AttachDbEntry
 
getDescriptor() - Static method in class alluxio.proto.journal.Table.CompleteTransformTableEntry.Builder
 
getDescriptor() - Static method in class alluxio.proto.journal.Table.CompleteTransformTableEntry
 
getDescriptor() - Static method in class alluxio.proto.journal.Table.DetachDbEntry.Builder
 
getDescriptor() - Static method in class alluxio.proto.journal.Table.DetachDbEntry
 
getDescriptor() - Static method in class alluxio.proto.journal.Table
 
getDescriptor() - Static method in class alluxio.proto.journal.Table.RemoveTableEntry.Builder
 
getDescriptor() - Static method in class alluxio.proto.journal.Table.RemoveTableEntry
 
getDescriptor() - Static method in class alluxio.proto.journal.Table.RemoveTransformJobInfoEntry.Builder
 
getDescriptor() - Static method in class alluxio.proto.journal.Table.RemoveTransformJobInfoEntry
 
getDescriptor() - Static method in class alluxio.proto.journal.Table.UpdateDatabaseInfoEntry.Builder
 
getDescriptor() - Static method in class alluxio.proto.journal.Table.UpdateDatabaseInfoEntry
 
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.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.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.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.BlockStoreLocationProto.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.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.Command.Builder
 
getDescriptorForType() - Method in enum alluxio.grpc.CommandType
 
getDescriptorForType() - Method in class alluxio.grpc.CommitBlockInUfsPOptions.Builder
 
getDescriptorForType() - Method in class alluxio.grpc.CommitBlockInUfsPRequest.Builder
 
getDescriptorForType() - Method in class alluxio.grpc.CommitBlockInUfsPResponse.Builder
 
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.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.CreateLocalBlockRequest.Builder
 
getDescriptorForType() - Method in class alluxio.grpc.CreateLocalBlockResponse.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.ExistsPOptions.Builder
 
getDescriptorForType() - Method in class alluxio.grpc.FileBlockInfo.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.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.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.GetJobServiceSummaryPOptions.Builder
 
getDescriptorForType() - Method in class alluxio.grpc.GetJobServiceSummaryPRequest.Builder
 
getDescriptorForType() - Method in class alluxio.grpc.GetJobServiceSummaryPResponse.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.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.GetPinnedFileIdsPOptions.Builder
 
getDescriptorForType() - Method in class alluxio.grpc.GetPinnedFileIdsPRequest.Builder
 
getDescriptorForType() - Method in class alluxio.grpc.GetPinnedFileIdsPResponse.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.GetServiceVersionPRequest.Builder
 
getDescriptorForType() - Method in class alluxio.grpc.GetServiceVersionPResponse.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.GetSyncPathListPRequest.Builder
 
getDescriptorForType() - Method in class alluxio.grpc.GetSyncPathListPResponse.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.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.JobServiceSummary.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.ListAllPOptions.Builder
 
getDescriptorForType() - Method in class alluxio.grpc.ListAllPRequest.Builder
 
getDescriptorForType() - Method in class alluxio.grpc.ListAllPResponse.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.LoadMetadataPOptions.Builder
 
getDescriptorForType() - Method in enum alluxio.grpc.LoadMetadataPType
 
getDescriptorForType() - Method in class alluxio.grpc.LocalityTier.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.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.NetAddress.Builder
 
getDescriptorForType() - Method in class alluxio.grpc.OpenFilePOptions.Builder
 
getDescriptorForType() - Method in class alluxio.grpc.OpenLocalBlockRequest.Builder
 
getDescriptorForType() - Method in class alluxio.grpc.OpenLocalBlockResponse.Builder
 
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.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.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.RemovePathConfigurationPOptions.Builder
 
getDescriptorForType() - Method in class alluxio.grpc.RemovePathConfigurationPRequest.Builder
 
getDescriptorForType() - Method in class alluxio.grpc.RemovePathConfigurationPResponse.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.ReverseResolvePRequest.Builder
 
getDescriptorForType() - Method in class alluxio.grpc.ReverseResolvePResponse.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.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.StartSyncPOptions.Builder
 
getDescriptorForType() - Method in class alluxio.grpc.StartSyncPRequest.Builder
 
getDescriptorForType() - Method in class alluxio.grpc.StartSyncPResponse.Builder
 
getDescriptorForType() - Method in enum alluxio.grpc.Status
 
getDescriptorForType() - Method in class alluxio.grpc.StatusSummary.Builder
 
getDescriptorForType() - Method in class alluxio.grpc.StopSyncPOptions.Builder
 
getDescriptorForType() - Method in class alluxio.grpc.StopSyncPRequest.Builder
 
getDescriptorForType() - Method in class alluxio.grpc.StopSyncPResponse.Builder
 
getDescriptorForType() - Method in class alluxio.grpc.StorageList.Builder
 
getDescriptorForType() - Method in class alluxio.grpc.SyncPointInfo.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 class alluxio.grpc.TieredIdentity.Builder
 
getDescriptorForType() - Method in class alluxio.grpc.TierList.Builder
 
getDescriptorForType() - Method in class alluxio.grpc.TransportMessage.Builder
 
getDescriptorForType() - Method in enum alluxio.grpc.TtlAction
 
getDescriptorForType() - Method in class alluxio.grpc.UfsInfo.Builder
 
getDescriptorForType() - Method in enum alluxio.grpc.UfsPMode
 
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.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.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 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 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.CreateUfsBlockOptions.Builder
 
getDescriptorForType() - Method in class alluxio.proto.dataserver.Protocol.CreateUfsFileOptions.Builder
 
getDescriptorForType() - Method in class alluxio.proto.dataserver.Protocol.OpenUfsBlockOptions.Builder
 
getDescriptorForType() - Method in class alluxio.proto.dataserver.Protocol.Response.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 class alluxio.proto.journal.Journal.JournalEntry.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.Table.AddTableEntry.Builder
 
getDescriptorForType() - Method in class alluxio.proto.journal.Table.AddTransformJobInfoEntry.Builder
 
getDescriptorForType() - Method in class alluxio.proto.journal.Table.AttachDbEntry.Builder
 
getDescriptorForType() - Method in class alluxio.proto.journal.Table.CompleteTransformTableEntry.Builder
 
getDescriptorForType() - Method in class alluxio.proto.journal.Table.DetachDbEntry.Builder
 
getDescriptorForType() - Method in class alluxio.proto.journal.Table.RemoveTableEntry.Builder
 
getDescriptorForType() - Method in class alluxio.proto.journal.Table.RemoveTransformJobInfoEntry.Builder
 
getDescriptorForType() - Method in class alluxio.proto.journal.Table.UpdateDatabaseInfoEntry.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.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.plan.migrate.MigrateCommand
 
getDestination() - Method in class alluxio.job.plan.migrate.MigrateConfig
 
getDetachDatabaseMethod() - Static method in class alluxio.grpc.table.TableMasterClientServiceGrpc
 
getDetachDb() - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
optional .alluxio.proto.journal.DetachDbEntry detach_db = 45;
getDetachDb() - Method in class alluxio.proto.journal.Journal.JournalEntry
optional .alluxio.proto.journal.DetachDbEntry detach_db = 45;
getDetachDb() - Method in interface alluxio.proto.journal.Journal.JournalEntryOrBuilder
optional .alluxio.proto.journal.DetachDbEntry detach_db = 45;
getDetachDbBuilder() - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
optional .alluxio.proto.journal.DetachDbEntry detach_db = 45;
getDetachDbOrBuilder() - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
optional .alluxio.proto.journal.DetachDbEntry detach_db = 45;
getDetachDbOrBuilder() - Method in class alluxio.proto.journal.Journal.JournalEntry
optional .alluxio.proto.journal.DetachDbEntry detach_db = 45;
getDetachDbOrBuilder() - Method in interface alluxio.proto.journal.Journal.JournalEntryOrBuilder
optional .alluxio.proto.journal.DetachDbEntry detach_db = 45;
getDeviceSpec() - Method in class alluxio.util.UnixMountInfo
 
getDir() - Method in class alluxio.master.backcompat.Journal
 
getDir(BlockStoreLocation) - Method in class alluxio.worker.block.BlockMetadataManager
Gets the StorageDir given its location in the store.
getDir(int) - Method in class alluxio.worker.block.meta.StorageTier
Returns a directory for the given index.
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;
getDirectoryPathsOnTiers() - Method in class alluxio.worker.AlluxioWorkerRestServiceHandler
Deprecated.
since version 1.4 and will be removed in version 2.0
getDirectoryPathsOnTiers() - Method in interface alluxio.worker.block.BlockStoreMeta
 
getDirectoryPathsOnTiers() - Method in class alluxio.worker.block.DefaultBlockStoreMeta
 
getDirectoryStatus(String) - Method in class alluxio.concurrent.ManagedBlockingUfsForwarder
 
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
 
getDirectoryStatus(String) - Method in class alluxio.underfs.web.WebUnderFileSystem
 
getDirectoryStatusTest() - Method in class alluxio.examples.UnderFileSystemCommonOperations
Test for getting directory status.
getDirIndex() - Method in class alluxio.worker.block.meta.StorageDir
Returns the zero-based index of this dir in its parent StorageTier.
getDirMedium() - Method in class alluxio.worker.block.meta.StorageDir
 
getDirPath() - Method in class alluxio.util.webui.UIStorageDir
Gets dir path.
getDirPath() - Method in class alluxio.worker.block.meta.StorageDir
 
getDirView(int) - Method in class alluxio.worker.block.meta.StorageTierView
Returns a directory view for the given index.
getDirViewIndex() - Method in class alluxio.worker.block.meta.StorageDirView
Gets the index of this Dir.
getDirViews() - Method in class alluxio.worker.block.meta.StorageTierView
 
getDirWithMaxFreeSpace(long, BlockStoreLocation, BlockMetadataEvictorView) - Static method in class alluxio.worker.block.evictor.EvictorUtils
Gets StorageDirView with max free space.
getDiskCapacity() - Method in class alluxio.wire.MasterWebUIOverview
Gets disk capacity.
getDiskFreeCapacity() - Method in class alluxio.wire.MasterWebUIOverview
Gets disk free capacity.
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;
getDouble(PropertyKey) - Method in interface alluxio.conf.AlluxioConfiguration
Gets the double representation of the value for the given key.
getDouble(PropertyKey) - Method in class alluxio.conf.InstancedConfiguration
 
getDouble(PropertyKey) - Method in class alluxio.conf.path.SpecificPathConfiguration
 
getDouble(PropertyKey) - Static method in class alluxio.conf.ServerConfiguration
Gets the double representation of the value for the given key.
getDoubleStats() - Method in class alluxio.grpc.table.ColumnStatisticsData.Builder
optional .alluxio.grpc.table.DoubleColumnStatsData double_stats = 3;
getDoubleStats() - Method in class alluxio.grpc.table.ColumnStatisticsData
optional .alluxio.grpc.table.DoubleColumnStatsData double_stats = 3;
getDoubleStats() - Method in interface alluxio.grpc.table.ColumnStatisticsDataOrBuilder
optional .alluxio.grpc.table.DoubleColumnStatsData double_stats = 3;
getDoubleStatsBuilder() - Method in class alluxio.grpc.table.ColumnStatisticsData.Builder
optional .alluxio.grpc.table.DoubleColumnStatsData double_stats = 3;
getDoubleStatsOrBuilder() - Method in class alluxio.grpc.table.ColumnStatisticsData.Builder
optional .alluxio.grpc.table.DoubleColumnStatsData double_stats = 3;
getDoubleStatsOrBuilder() - Method in class alluxio.grpc.table.ColumnStatisticsData
optional .alluxio.grpc.table.DoubleColumnStatsData double_stats = 3;
getDoubleStatsOrBuilder() - Method in interface alluxio.grpc.table.ColumnStatisticsDataOrBuilder
optional .alluxio.grpc.table.DoubleColumnStatsData double_stats = 3;
getDoubleType() - Method in class alluxio.grpc.table.Value.Builder
optional double double_type = 2;
getDoubleType() - Method in class alluxio.grpc.table.Value
optional double double_type = 2;
getDoubleType() - Method in interface alluxio.grpc.table.ValueOrBuilder
optional 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;
getDstLocation() - Method in class alluxio.worker.block.evictor.BlockTransferInfo
 
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.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) - Method in class alluxio.conf.InstancedConfiguration
 
getDuration(PropertyKey) - Method in class alluxio.conf.path.SpecificPathConfiguration
 
getDuration(PropertyKey) - Static method in class alluxio.conf.ServerConfiguration
Gets the time of the key as a duration.
getEC2ProductCode() - Static method in class alluxio.util.EnvironmentUtils
Gets the EC2 product code if any.
getElectionTimeoutMs() - Method in class alluxio.master.journal.raft.RaftJournalConfiguration
 
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
 
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.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>) - Method in class alluxio.conf.InstancedConfiguration
 
getEnum(PropertyKey, Class<T>) - Method in class alluxio.conf.path.SpecificPathConfiguration
 
getEnum(PropertyKey, Class<T>) - Static method in class alluxio.conf.ServerConfiguration
Gets the value for the given key as an enum value.
getEquatable() - Method in class alluxio.grpc.table.Domain.Builder
optional .alluxio.grpc.table.EquatableValueSet equatable = 2;
getEquatable() - Method in class alluxio.grpc.table.Domain
optional .alluxio.grpc.table.EquatableValueSet equatable = 2;
getEquatable() - Method in interface alluxio.grpc.table.DomainOrBuilder
optional .alluxio.grpc.table.EquatableValueSet equatable = 2;
getEquatableBuilder() - Method in class alluxio.grpc.table.Domain.Builder
optional .alluxio.grpc.table.EquatableValueSet equatable = 2;
getEquatableOrBuilder() - Method in class alluxio.grpc.table.Domain.Builder
optional .alluxio.grpc.table.EquatableValueSet equatable = 2;
getEquatableOrBuilder() - Method in class alluxio.grpc.table.Domain
optional .alluxio.grpc.table.EquatableValueSet equatable = 2;
getEquatableOrBuilder() - Method in interface alluxio.grpc.table.DomainOrBuilder
optional .alluxio.grpc.table.EquatableValueSet equatable = 2;
getError() - Method in class alluxio.wire.BackupStatus
 
getError() - Method in class alluxio.worker.grpc.ReadRequestContext
 
getError() - Method in class alluxio.worker.grpc.WriteRequestContext
 
getErrorCode(Throwable) - Static method in class alluxio.fuse.AlluxioFuseUtils
Gets the corresponding error code of a throwable.
getErrorCode() - Method in exception alluxio.proxy.s3.S3Exception
 
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.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;
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.
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
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
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
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
getETag() - Method in class alluxio.proxy.s3.CompleteMultipartUploadResult
 
getETag() - Method in class alluxio.proxy.s3.ListBucketResult.Content
 
getETag() - Method in class alluxio.proxy.s3.ListPartsResult.Part
 
getEvictableBlocks() - Method in class alluxio.worker.block.meta.StorageDirEvictorView
Gets a filtered list of block metadata, for blocks that are neither pinned or being blocked.
getEvictBatchSize() - Method in class alluxio.master.metastore.caching.CacheConfiguration
 
getEvitableBytes() - Method in class alluxio.worker.block.meta.StorageDirEvictorView
Gets evictable bytes for this dir, i.e., the total bytes of total evictable blocks.
getException() - Method in class alluxio.client.file.ConfigHashSync
 
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.
getExecution(WorkflowConfig) - Method in enum alluxio.job.workflow.WorkflowExecutionRegistry
Gets the WorkflowExecution from workflow config.
getExecutor() - Method in class alluxio.master.file.activesync.ActiveSyncManager
Get SyncManager Executor.
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
 
getExitCode() - Method in class alluxio.shell.CommandReturn
Gets the exit code.
getExitCode() - Method in exception alluxio.util.ShellUtils.ExitCodeException
Gets the exit code.
getExpiredBuckets(long) - Method in class alluxio.master.file.meta.TtlBucketList
Retrieves 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).
getExtendedEntries() - Method in class alluxio.security.authorization.AccessControlList
 
GetFaclCommand - Class in alluxio.cli.fs.command
Displays ACL info of a path.
GetFaclCommand(FileSystemContext) - Constructor for class alluxio.cli.fs.command.GetFaclCommand
 
getFactory() - Method in class alluxio.concurrent.jsr.ForkJoinPool
Returns the factory used for constructing new workers.
getFailedNodeInfos() - Method in class alluxio.wire.MasterWebUIWorkers
Get failed node infos node info [ ].
getFallback() - Method in class alluxio.proto.dataserver.Protocol.CreateUfsBlockOptions.Builder
true if the write request is already a fallback from a failed short-circuit write.
getFallback() - Method in class alluxio.proto.dataserver.Protocol.CreateUfsBlockOptions
true if the write request is already a fallback from a failed short-circuit write.
getFallback() - Method in interface alluxio.proto.dataserver.Protocol.CreateUfsBlockOptionsOrBuilder
true if the write request is already a fallback from a failed short-circuit write.
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;
getFields() - Method in class alluxio.job.plan.transform.PartitionInfo
 
getFieldValue(T) - Method in class alluxio.collections.IndexDefinition
Gets the value of the field that serves as index.
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.
getFileBuckets() - Method in class alluxio.client.file.cache.store.LocalPageStoreOptions
 
getFileData() - Method in class alluxio.wire.MasterWebUIBrowse
Gets file data.
getFileData() - Method in class alluxio.wire.MasterWebUILogs
Gets file data.
getFileData() - Method in class alluxio.wire.WorkerWebUILogs
Gets file data.
getFileDoesNotExistException() - Method in class alluxio.wire.MasterWebUIBrowse
Gets file does not exist exception.
getFileId() - Method in class alluxio.client.file.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
 
getFileIdentifier() - Method in class alluxio.client.file.URIStatus
 
getFileIdentifier() - Method in class alluxio.wire.FileInfo
Similar to FileInfo.getFileId(), but returns in a string form, allowing for the use of non-long based ids.
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) - 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.FileSystemMasterJobServiceImplBase
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) - 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.FileSystemMasterWorkerServiceImplBase
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(String) - Method in class alluxio.underfs.kodo.KodoClient
Gets file from for Qiniu kodo.
getFileInfo(long) - Method in interface alluxio.worker.block.BlockWorker
Gets the file information.
getFileInfo(long) - Method in class alluxio.worker.block.DefaultBlockWorker
 
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;
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;
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.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.ListStatusPResponse.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.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.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.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.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;
getFileLocations(String) - Method in class alluxio.concurrent.ManagedBlockingUfsForwarder
 
getFileLocations(String, FileLocationOptions) - Method in class alluxio.concurrent.ManagedBlockingUfsForwarder
 
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(String) - Method in class alluxio.underfs.web.WebUnderFileSystem
 
getFileLocations(String, FileLocationOptions) - Method in class alluxio.underfs.web.WebUnderFileSystem
 
getFileLocations() - Method in class alluxio.util.webui.UIFileInfo
Gets file locations.
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(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.FileSystemMasterClientServiceImplBase
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.job.plan.load.LoadConfig
 
getFilePath() - Method in class alluxio.job.plan.persist.PersistConfig
 
getFilePath(GetFilePathPRequest, StreamObserver<GetFilePathPResponse>) - Method in class alluxio.master.file.FileSystemMasterClientServiceHandler
 
getFilePath() - Method in class alluxio.worker.block.io.LocalFileBlockReader
 
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
 
getFilePersistenceState(long) - Method in class alluxio.master.file.meta.FileSystemMasterView
Returns the persistence state of a given file.
getFiles(String) - Static method in class alluxio.cli.fs.FileSystemShellUtils
Gets the files (on the local filesystem) that match the given input path.
getFileSizeTest() - Method in class alluxio.examples.UnderFileSystemCommonOperations
Test for getting file size.
getFileStatus(String) - Method in class alluxio.concurrent.ManagedBlockingUfsForwarder
 
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) - Method in class alluxio.underfs.hdfs.HdfsUnderFileSystem
 
getFileStatus(String) - Method in class alluxio.underfs.local.LocalUnderFileSystem
 
getFileStatus(String) - Method in class alluxio.underfs.ObjectUnderFileSystem
 
getFileStatus(String) - Method in interface alluxio.underfs.UnderFileSystem
Gets the file status.
getFileStatus(String) - Method in class alluxio.underfs.UnderFileSystemWithLogging
 
getFileStatus(String) - Method in class alluxio.underfs.web.WebUnderFileSystem
 
getFileStatusTest() - Method in class alluxio.examples.UnderFileSystemCommonOperations
Test for getting file status.
getFilesToPersist() - Method in class alluxio.wire.PersistCommandOptions
 
getFileSystem() - Method in class alluxio.job.JobServerContext
 
getFileSystem(Configuration) - Method in class alluxio.job.plan.transform.format.JobPath
 
getFileSystem() - Method in class alluxio.table.common.udb.UdbContext
 
getFileSystemClient() - Method in class alluxio.multi.process.Clients
 
getFileSystemClient() - Method in class alluxio.multi.process.MultiProcessCluster
 
getFilesystemContext() - Method in class alluxio.multi.process.MultiProcessCluster
 
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
 
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;
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;
getFilterList(long) - Method in class alluxio.master.file.activesync.ActiveSyncManager
Get the filter list associated with mount Id.
getFilterMetricName() - Method in class alluxio.metrics.aggregator.SingleTagValueAggregator
 
getFilterMetricName() - Method in interface alluxio.metrics.MultiValueMetricsAggregator
 
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
Computes and returns a fingerprint for the path.
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.
getFloat(PropertyKey) - Method in interface alluxio.conf.AlluxioConfiguration
Gets the float representation of the value for the given key.
getFloat(PropertyKey) - Method in class alluxio.conf.InstancedConfiguration
 
getFloat(PropertyKey) - Method in class alluxio.conf.path.SpecificPathConfiguration
 
getFloat(PropertyKey) - Static method in class alluxio.conf.ServerConfiguration
Gets the float representation of the value for the given key.
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.kodo.KodoUnderFileSystem
 
getFolderSuffix() - Method in class alluxio.underfs.ObjectUnderFileSystem
Get suffix used to encode a directory.
getFolderSuffix() - Method in class alluxio.underfs.oss.OSSUnderFileSystem
 
getFolderSuffix() - Method in class alluxio.underfs.s3a.S3AUnderFileSystem
 
getFolderSuffix() - Method in class alluxio.underfs.swift.SwiftUnderFileSystem
 
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(String) - Method in class alluxio.job.plan.transform.PartitionInfo
 
getFormattedOutput() - Method in class alluxio.shell.CommandReturn
Formats the object to more readable format.
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.master.meta.AlluxioMasterRestServiceHandler
Deprecated.
since version 1.4 and will be removed in version 2.0
getFreeBytes() - Method in class alluxio.wire.BlockMasterInfo
 
getFreeBytesOnTiers() - Method in class alluxio.master.block.meta.MasterWorkerInfo
 
getFreeCapacity() - Method in class alluxio.util.webui.StorageTierInfo
Gets free capacity.
getFreeCapacity() - Method in class alluxio.wire.MasterWebUIOverview
Gets free capacity.
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.
getFrom(int) - Method in class alluxio.underfs.swift.MidPartLongRange
 
getFsClient() - Method in class alluxio.cli.fsadmin.command.Context
 
getFsContext() - Method in class alluxio.job.JobServerContext
 
getFSName() - Method in class alluxio.fuse.AlluxioFuseFileSystem
 
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
 
getFullName(String) - Method in class alluxio.table.common.udb.UdbProperty
 
getFuseOpts() - Method in class alluxio.fuse.AlluxioFuseOptions
 
getGcExecutor() - Method in class alluxio.resource.DynamicResourcePool.Options
 
getGcIntervalMs() - Method in class alluxio.resource.DynamicResourcePool.Options
 
getGetAllDatabasesMethod() - Static method in class alluxio.grpc.table.TableMasterClientServiceGrpc
 
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
 
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
 
getGetJobServiceSummaryMethod() - Static method in class alluxio.grpc.JobMasterClientServiceGrpc
 
getGetJobStatusMethod() - Static method in class alluxio.grpc.JobMasterClientServiceGrpc
 
getGetMasterIdMethod() - Static method in class alluxio.grpc.MetaMasterMasterServiceGrpc
 
getGetMasterInfoMethod() - Static method in class alluxio.grpc.MetaMasterClientServiceGrpc
 
getGetMetricsMethod() - Static method in class alluxio.grpc.MetricsMasterClientServiceGrpc
 
getGetMountTableMethod() - Static method in class alluxio.grpc.FileSystemMasterClientServiceGrpc
 
getGetNewBlockIdForFileMethod() - Static method in class alluxio.grpc.FileSystemMasterClientServiceGrpc
 
getGetPartitionColumnStatisticsMethod() - Static method in class alluxio.grpc.table.TableMasterClientServiceGrpc
 
getGetPinnedFileIdsMethod() - Static method in class alluxio.grpc.FileSystemMasterWorkerServiceGrpc
 
getGetQuorumInfoMethod() - Static method in class alluxio.grpc.JournalMasterClientServiceGrpc
 
getGetServiceVersionMethod() - Static method in class alluxio.grpc.ServiceVersionClientServiceGrpc
 
getGetStatusMethod() - Static method in class alluxio.grpc.FileSystemMasterClientServiceGrpc
 
getGetSyncPathListMethod() - 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
 
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(String) - Static method in class alluxio.fuse.AlluxioFuseUtils
Retrieves the primary gid of the given user.
getGidFromGroupName(String) - Static method in class alluxio.fuse.AlluxioFuseUtils
Retrieves the gid of the given group.
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.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.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
 
getGroupIndex() - Method in class alluxio.grpc.GrpcConnectionKey
 
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
Gets a list of groups for the given user.
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.
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
 
getHeadDelay() - Method in class alluxio.util.executor.ControllableQueue
 
getHeadValue() - Method in class alluxio.util.executor.ControllableQueue
 
getHeartbeatIntervalMs() - Method in class alluxio.master.journal.raft.RaftJournalConfiguration
 
getHeartbeatMethod() - Static method in class alluxio.grpc.JobMasterWorkerServiceGrpc
 
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
 
getHiveConstantType(String) - Static method in class alluxio.job.plan.transform.HiveConstants.Types
Filters out parts of type information to match the types constant for type checking.
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
 
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 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.
getId() - Method in class alluxio.client.block.stream.BlockInStream
 
getId() - Method in class alluxio.client.file.FileSystemContext
 
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.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 class alluxio.job.plan.transform.FieldSchema
 
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
 
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.MasterInfo
 
getId(Address) - Method in class alluxio.master.meta.RetryHandlingMetaMasterMasterClient
Returns a master id for a master address.
getId() - Method in class alluxio.master.metastore.BlockStore.Block
 
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.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.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
 
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;
getImpersonationUser(Subject, AlluxioConfiguration) - Static method in class alluxio.security.authentication.AuthenticationUserUtils
 
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
 
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.
getInfo(long) - Method in class alluxio.client.block.AlluxioBlockStore
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(Boolean) - Method in class alluxio.worker.AlluxioWorkerRestServiceHandler
 
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;
getInfoTimeExceeded() - Method in class alluxio.util.JvmPauseMonitor
 
getInitialDelayMs() - Method in class alluxio.resource.DynamicResourcePool.Options
 
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
 
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;
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;
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.
getInodes() - Method in class alluxio.master.file.meta.TtlBucket
 
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
 
getInput() - Method in class alluxio.job.plan.transform.CompactConfig
 
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;
getInputFormatClass() - Method in class alluxio.job.plan.transform.PartitionInfo
 
getInputs() - Method in class alluxio.job.plan.transform.CompactTask
 
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;
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(long, InStreamOptions) - Method in class alluxio.client.block.AlluxioBlockStore
Gets a stream to read the data of a block.
getInStream(long, InStreamOptions, Map<WorkerNetAddress, Long>) - Method in class alluxio.client.block.AlluxioBlockStore
Gets a stream to read the data of a block.
getInStream(BlockInfo, InStreamOptions, Map<WorkerNetAddress, Long>) - Method in class alluxio.client.block.AlluxioBlockStore
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) - Method in class alluxio.conf.InstancedConfiguration
 
getInt(PropertyKey) - Method in class alluxio.conf.path.SpecificPathConfiguration
 
getInt(PropertyKey) - Static method in class alluxio.conf.ServerConfiguration
Gets the integer representation of the value for the given key.
getIntArg(CommandLine, Option, int) - Static method in class alluxio.cli.fs.FileSystemShellUtils
Gets the value of an option from the command line.
getInternalURL() - Method in class alluxio.underfs.swift.KeystoneV3Access
 
getInterval() - Method in class alluxio.util.WaitForOptions
 
getInvalidPathError() - Method in class alluxio.wire.MasterWebUIBrowse
Gets invalid path error.
getInvalidPathError() - Method in class alluxio.wire.MasterWebUILogs
Gets invalid path error.
getInvalidPathError() - Method in class alluxio.wire.WorkerWebUIBlockInfo
Gets invalid path error.
getInvalidPathError() - Method in class alluxio.wire.WorkerWebUILogs
Gets invalid path error.
getInvalidPathException() - Method in class alluxio.wire.MasterWebUIBrowse
Gets invalid path exception.
getIpAddress() - Static method in class alluxio.security.authentication.ClientIpAddressInjector
 
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.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;
getIsInHighestTier() - Method in class alluxio.util.webui.UIFileBlockInfo
Gets whether the block is in the highest tier alias.
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
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;
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;
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.meta.PlanInfo
 
getJobConfigClass() - Method in class alluxio.job.plan.load.LoadDefinition
 
getJobConfigClass() - Method in class alluxio.job.plan.migrate.MigrateDefinition
 
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.EvictDefinition
 
getJobConfigClass() - Method in class alluxio.job.plan.replicate.MoveDefinition
 
getJobConfigClass() - Method in class alluxio.job.plan.replicate.ReplicateDefinition
 
getJobConfigClass() - Method in class alluxio.job.plan.transform.CompactDefinition
 
getJobConfigs() - Method in class alluxio.table.common.transform.TransformPlan
 
getJobDefinition(T) - Method in enum alluxio.job.plan.PlanDefinitionRegistry
Gets the job definition from the job configuration.
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;
getJobErrorMessage() - Method in class alluxio.master.table.transform.TransformJobInfo
 
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.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.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.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.TaskInfo
 
getJobId() - Method in class alluxio.master.job.plan.PlanCoordinator
 
getJobId() - Method in class alluxio.master.table.transform.TransformJobInfo
 
getJobId() - Method in class alluxio.proto.journal.Table.AddTransformJobInfoEntry.Builder
optional int64 job_id = 4;
getJobId() - Method in class alluxio.proto.journal.Table.AddTransformJobInfoEntry
optional int64 job_id = 4;
getJobId() - Method in interface alluxio.proto.journal.Table.AddTransformJobInfoEntryOrBuilder
optional int64 job_id = 4;
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.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.GetJobStatusPResponse.Builder
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.
getJobMasterRpcAddresses(AlluxioConfiguration) - Static method in class alluxio.util.ConfigurationUtils
Gets the RPC addresses of all job masters based on the configuration.
getJobs() - Method in class alluxio.job.workflow.composite.CompositeConfig
 
getJobServiceSummary() - Method in interface alluxio.client.job.JobMasterClient
Gets the job service summary.
getJobServiceSummary() - Method in class alluxio.client.job.RetryHandlingJobMasterClient
 
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.JobMasterClientServiceImplBase
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
 
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) - 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.JobMasterClientServiceImplBase
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.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
 
getJobStatus() - Method in class alluxio.master.table.transform.TransformJobInfo
 
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
 
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;
getJobWorkerMetricName(String) - Static method in class alluxio.metrics.MetricsSystem
Builds metric registry name for job worker instance.
getJournalContext() - Method in class alluxio.master.file.RpcContext
 
getJournalDir() - Method in class alluxio.multi.process.MultiProcessCluster
 
getJournaled() - Method in class alluxio.master.journal.JournaledGroup
 
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.
getJournalEntryIterator() - Method in class alluxio.master.block.DefaultBlockMaster
 
getJournalEntryIterator() - Method in class alluxio.master.file.activesync.ActiveSyncManager
 
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.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.table.AlluxioCatalog
 
getJournalEntryIterator() - Method in class alluxio.master.table.Database
 
getJournalEntryIterator() - Method in class alluxio.underfs.MasterUfsManager
 
getJournalFolder() - Method in class alluxio.master.LocalAlluxioMaster
 
getJournalFormatter() - Method in class alluxio.master.journalv0.ufs.UfsJournal
 
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
 
getJournalSequences() - Method in class alluxio.master.backup.BackupRequestMessage
 
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
 
getJournalSystem() - Method in class alluxio.master.CoreMasterContext
 
getJournalSystem() - Method in class alluxio.master.MasterContext
 
getJournalUfsConf() - Static method in class alluxio.master.journal.ufs.UfsJournal
 
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.ListBucketResult.Content
 
getKey() - Method in class alluxio.proxy.s3.ListPartsResult
 
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.proxy.s3.ListBucketResult
 
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
 
getLastAppliedSequenceNumber() - Method in class alluxio.master.journal.raft.JournalStateMachine
 
getLastClearTime() - Method in class alluxio.master.metrics.MetricsStore
 
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.
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.ListBucketResult.Content
 
getLastModified() - Method in class alluxio.proxy.s3.ListPartsResult.Part
 
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.underfs.ObjectUnderFileSystem.ObjectStatus
Gets the last modified epoch time in ms.
getLastPrimaryStartSequenceNumber() - Method in class alluxio.master.journal.raft.JournalStateMachine
 
getLastSnapshotStartTime() - Method in class alluxio.master.journal.raft.JournalStateMachine
 
getLastStatusChangeMs() - Method in class alluxio.job.plan.meta.PlanInfo
 
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
 
getLastUpdatedTimeMs() - Method in class alluxio.job.MasterWorkerInfo
 
getLastUpdatedTimeMs() - Method in class alluxio.master.block.meta.MasterWorkerInfo
 
getLastUpdatedTimeMs() - Method in class alluxio.master.meta.MasterInfo
 
getLatestCheckpoint() - Method in class alluxio.master.journal.ufs.UfsJournalSnapshot
 
getLatestSequenceNumber() - Method in interface alluxio.master.journalv0.JournalInputStream
 
getLatestVersion(String, long, long, long) - Static method in class alluxio.master.meta.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;
getLayout() - Method in class alluxio.master.table.Partition
 
getLayout() - Method in class alluxio.proto.journal.Table.AddTableEntry.Builder
optional .alluxio.grpc.table.Layout layout = 5;
getLayout() - Method in class alluxio.proto.journal.Table.AddTableEntry
optional .alluxio.grpc.table.Layout layout = 5;
getLayout() - Method in interface alluxio.proto.journal.Table.AddTableEntryOrBuilder
optional .alluxio.grpc.table.Layout layout = 5;
getLayout() - Method in interface alluxio.table.common.udb.UdbTable
 
getLayout() - Method in interface alluxio.table.common.UdbPartition
 
getLayout() - Method in class alluxio.table.under.hive.HivePartition
 
getLayout() - Method in class alluxio.table.under.hive.HiveTable
 
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;
getLayoutBuilder() - Method in class alluxio.proto.journal.Table.AddTableEntry.Builder
optional .alluxio.grpc.table.Layout layout = 5;
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;
getLayoutOrBuilder() - Method in class alluxio.proto.journal.Table.AddTableEntry.Builder
optional .alluxio.grpc.table.Layout layout = 5;
getLayoutOrBuilder() - Method in class alluxio.proto.journal.Table.AddTableEntry
optional .alluxio.grpc.table.Layout layout = 5;
getLayoutOrBuilder() - Method in interface alluxio.proto.journal.Table.AddTableEntryOrBuilder
optional .alluxio.grpc.table.Layout layout = 5;
getLayoutRegistry() - Method in class alluxio.master.table.AlluxioCatalog
 
getLayoutRegistry() - Method in class alluxio.master.table.CatalogContext
 
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;
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.
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.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 class alluxio.grpc.CommitBlockInUfsPRequest.Builder
the space used in bytes on the target tier
getLength() - Method in class alluxio.grpc.CommitBlockInUfsPRequest
the space used in bytes on the target tier
getLength() - Method in interface alluxio.grpc.CommitBlockInUfsPRequestOrBuilder
the space used in bytes on the target tier
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.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 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.master.block.meta.MasterBlockInfo
 
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 interface alluxio.network.protocol.databuffer.DataBuffer
Returns the length of the data.
getLength() - Method in class alluxio.network.protocol.databuffer.NettyDataBuffer
 
getLength() - Method in class alluxio.network.protocol.databuffer.NioDataBuffer
 
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() - Method in class alluxio.underfs.options.OpenOptions
 
getLength() - Method in class alluxio.wire.BlockInfo
 
getLength() - Method in class alluxio.wire.FileInfo
 
getLength() - Method in interface alluxio.worker.block.io.BlockReader
Gets the length of the block in bytes.
getLength() - Method in class alluxio.worker.block.io.LocalFileBlockReader
 
getLength() - Method in class alluxio.worker.block.RemoteBlockReader
 
getLength() - Method in class alluxio.worker.block.UnderFileSystemBlockReader
 
getLevel() - Method in class alluxio.wire.LogInfo
 
getList() - Method in class alluxio.collections.PrefixList
Gets the list of prefixes.
getList(PropertyKey, String) - Method in interface alluxio.conf.AlluxioConfiguration
Gets the value for the given key as a list.
getList(PropertyKey, String) - Method in class alluxio.conf.InstancedConfiguration
 
getList(PropertyKey, String) - Method in class alluxio.conf.path.SpecificPathConfiguration
 
getList(PropertyKey, String) - Static method in class alluxio.conf.ServerConfiguration
Gets the value for the given key as a list.
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.
getListStatusMethod() - Static method in class alluxio.grpc.FileSystemMasterClientServiceGrpc
 
getLiveNodeAddresses() - Method in class alluxio.master.meta.checkconf.ServerConfigurationStore
 
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
 
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.
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;
getLocalAddress() - Static method in class alluxio.checker.CheckerUtils
 
getLocalAddress() - Method in class alluxio.master.journal.raft.RaftJournalConfiguration
 
getLocalAlluxioMaster() - Method in class alluxio.master.AbstractLocalAlluxioCluster
 
getLocalAlluxioMaster() - Method in class alluxio.master.LocalAlluxioCluster
 
getLocalAlluxioMaster() - Method in class alluxio.master.MultiMasterLocalAlluxioCluster
 
getLocalFileGroup(String) - Static method in class alluxio.util.io.FileUtils
Gets local file's group.
getLocalFileMode(String) - Static method in class alluxio.util.io.FileUtils
Gets local file's permission mode.
getLocalFileOwner(String) - Static method in class alluxio.util.io.FileUtils
Gets local file's owner.
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.
getLocalNodeName(AlluxioConfiguration) - Static method in class alluxio.util.network.NetworkAddressUtils
Gets a local node name from configuration if it is available, falling back on localhost lookup.
getLocalPort() - Method in class alluxio.web.WebServer
Gets the actual port that the web server is listening on.
getLocalWorker() - Method in class alluxio.client.file.FileSystemContext
 
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.master.table.DatabaseInfo
 
getLocation() - Method in class alluxio.proto.journal.Table.UpdateDatabaseInfoEntry.Builder
optional string location = 2;
getLocation() - Method in class alluxio.proto.journal.Table.UpdateDatabaseInfoEntry
optional string location = 2;
getLocation() - Method in interface alluxio.proto.journal.Table.UpdateDatabaseInfoEntryOrBuilder
optional string location = 2;
getLocation() - Method in class alluxio.proxy.s3.CompleteMultipartUploadResult
 
getLocation() - Method in interface alluxio.table.common.Layout
 
getLocation() - Method in class alluxio.table.common.layout.HiveLayout
 
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;
getLocationBytes() - Method in class alluxio.proto.journal.Table.UpdateDatabaseInfoEntry.Builder
optional string location = 2;
getLocationBytes() - Method in class alluxio.proto.journal.Table.UpdateDatabaseInfoEntry
optional string location = 2;
getLocationBytes() - Method in interface alluxio.proto.journal.Table.UpdateDatabaseInfoEntryOrBuilder
optional string location = 2;
getLocationPolicy() - Method in class alluxio.client.file.options.OutStreamOptions
 
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.BlockStore
Gets locations for a block.
getLocations(long) - Method in class alluxio.master.metastore.heap.HeapBlockStore
 
getLocations(long) - Method in class alluxio.master.metastore.rocks.RocksBlockStore
 
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.master.file.activesync.ActiveSyncManager
Gets the lock protecting the syncManager.
getLockedBlocks() - Method in class alluxio.worker.block.BlockLockManager
Gets a set of currently locked blocks.
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
 
getLogDir() - Method in class alluxio.master.journal.ufs.UfsJournal
 
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 representation of the value for the given key.
getLong(PropertyKey) - Method in class alluxio.conf.InstancedConfiguration
 
getLong(PropertyKey) - Method in class alluxio.conf.path.SpecificPathConfiguration
 
getLong(PropertyKey) - Static method in class alluxio.conf.ServerConfiguration
Gets the long representation of the value for the given key.
getLong() - Method in class alluxio.master.journal.checkpoint.LongCheckpointFormat.LongCheckpointReader
 
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;
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
optional .alluxio.grpc.table.LongColumnStatsData long_stats = 2;
getLongStats() - Method in class alluxio.grpc.table.ColumnStatisticsData
optional .alluxio.grpc.table.LongColumnStatsData long_stats = 2;
getLongStats() - Method in interface alluxio.grpc.table.ColumnStatisticsDataOrBuilder
optional .alluxio.grpc.table.LongColumnStatsData long_stats = 2;
getLongStatsBuilder() - Method in class alluxio.grpc.table.ColumnStatisticsData.Builder
optional .alluxio.grpc.table.LongColumnStatsData long_stats = 2;
getLongStatsOrBuilder() - Method in class alluxio.grpc.table.ColumnStatisticsData.Builder
optional .alluxio.grpc.table.LongColumnStatsData long_stats = 2;
getLongStatsOrBuilder() - Method in class alluxio.grpc.table.ColumnStatisticsData
optional .alluxio.grpc.table.LongColumnStatsData long_stats = 2;
getLongStatsOrBuilder() - Method in interface alluxio.grpc.table.ColumnStatisticsDataOrBuilder
optional .alluxio.grpc.table.LongColumnStatsData long_stats = 2;
getLongType() - Method in class alluxio.grpc.table.Value.Builder
optional int64 long_type = 1;
getLongType() - Method in class alluxio.grpc.table.Value
optional int64 long_type = 1;
getLongType() - Method in interface alluxio.grpc.table.ValueOrBuilder
optional int64 long_type = 1;
getLostBlocks() - Method in interface alluxio.master.block.BlockMaster
 
getLostBlocks() - Method in class alluxio.master.block.DefaultBlockMaster
 
getLostFiles() - Method in class alluxio.master.file.DefaultFileSystemMaster
 
getLostFiles() - Method in interface alluxio.master.file.FileSystemMaster
 
getLostFiles() - Method in class alluxio.master.file.meta.FileSystemMasterView
 
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 class alluxio.worker.block.DefaultBlockStoreMeta
 
getLostStorage() - Method in class 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
 
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.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
 
getMap() - Method in class alluxio.table.common.BaseConfiguration
 
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(Class<T>) - Method in class alluxio.master.AlluxioJobMasterProcess
 
getMaster(Class<T>) - Method in class alluxio.master.AlluxioMasterProcess
 
getMaster() - Method in class alluxio.master.LocalAlluxioJobCluster
 
getMaster(Class<T>) - Method in class alluxio.master.MasterProcess
Gets the registered class from the master registry.
getMasterAddress() - Method in class alluxio.client.file.FileSystemContext
 
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;
getMasterAddressBuilder() - Method in class alluxio.grpc.GetMasterIdPRequest.Builder
optional .alluxio.grpc.NetAddress masterAddress = 1;
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.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.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;
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
 
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.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() - Static method in class alluxio.cli.extensions.ExtensionsShellUtils
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.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.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) - 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.MetaMasterMasterServiceImplBase
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.meta.DefaultMetaMaster
 
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) - 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.MetaMasterClientServiceImplBase
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
 
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
 
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
 
getMaxBufferPoolSize() - Method in class alluxio.client.file.cache.store.RocksPageStoreOptions
 
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;
getMaxKeys() - Method in class alluxio.proxy.s3.ListBucketOptions
 
getMaxKeys() - Method in class alluxio.proxy.s3.ListBucketResult
 
getMaxLogSize() - Method in class alluxio.master.journal.raft.RaftJournalConfiguration
 
getMaxNumFiles() - Method in class alluxio.job.plan.transform.CompactConfig
 
getMaxPageSize() - Method in class alluxio.client.file.cache.store.RocksPageStoreOptions
 
getMaxSequenceNumber() - Static method in class alluxio.master.block.BlockId
 
getMaxSize() - Method in class alluxio.master.metastore.caching.CacheConfiguration
 
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
 
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() - Method in class alluxio.grpc.CreateLocalBlockRequest.Builder
optional string medium_type = 7;
getMediumType() - Method in class alluxio.grpc.CreateLocalBlockRequest
optional string medium_type = 7;
getMediumType() - Method in interface alluxio.grpc.CreateLocalBlockRequestOrBuilder
optional string medium_type = 7;
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
 
getMediumType() - Method in class alluxio.worker.block.meta.StorageDirView
Get medium type of the dir view, which is derived from the dir.
getMediumType() - Method in class alluxio.worker.grpc.BlockWriteRequest
 
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() - Method in class alluxio.grpc.CreateLocalBlockRequest.Builder
optional string medium_type = 7;
getMediumTypeBytes() - Method in class alluxio.grpc.CreateLocalBlockRequest
optional string medium_type = 7;
getMediumTypeBytes() - Method in interface alluxio.grpc.CreateLocalBlockRequestOrBuilder
optional string medium_type = 7;
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.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.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
 
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 class alluxio.grpc.DataMessage
 
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.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.S3Error
 
getMessage() - Method in class alluxio.RestUtils.ErrorResponse
Gets message.
getMessage() - Method in class alluxio.wire.LogInfo
 
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 a url to consult.
getMeta() - Method in class alluxio.master.metastore.BlockStore.Block
 
getMetaClient() - Method in class alluxio.cli.fsadmin.command.Context
 
getMetaConfigClient() - Method in class alluxio.cli.fsadmin.command.Context
 
getMetaMasterClient() - Method in class alluxio.multi.process.Clients
 
getMetaMasterClient() - Method in class alluxio.multi.process.MultiProcessCluster
 
getMeter() - Method in class alluxio.worker.grpc.ReadRequestContext
 
getMeter() - Method in class alluxio.worker.grpc.WriteRequestContext
 
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) - 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.MetricsMasterClientServiceImplBase
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.meta.AlluxioMasterRestServiceHandler
Deprecated.
since version 1.4 and will be removed in version 2.0
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.wire.AlluxioMasterInfo
 
getMetrics() - Method in class alluxio.wire.AlluxioWorkerInfo
 
getMetrics() - Method in class alluxio.worker.AlluxioWorkerRestServiceHandler
Deprecated.
since version 1.4 and will be removed in version 2.0
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
 
getMetricsJson(String) - 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
 
getMinFileSize() - Method in class alluxio.job.plan.transform.CompactConfig
 
getMode() - Method in class alluxio.client.file.options.OutStreamOptions
 
getMode() - Method in class alluxio.client.file.URIStatus
 
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.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.examples.UnderFileSystemCommonOperations
Test for getting modification time.
getMountId() - Method in class alluxio.client.file.options.OutStreamOptions
 
getMountId() - Method in class alluxio.client.file.URIStatus
 
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 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.job.plan.persist.PersistConfig
 
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.CreateUfsBlockOptions.Builder
mount ID of the UFS to write to
getMountId() - Method in class alluxio.proto.dataserver.Protocol.CreateUfsBlockOptions
mount ID of the UFS to write to
getMountId() - Method in interface alluxio.proto.dataserver.Protocol.CreateUfsBlockOptionsOrBuilder
mount ID of the UFS to write to
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.worker.block.meta.UnderFileSystemBlockMeta
 
getMountInfo(long) - Method in class alluxio.master.file.meta.MountTable
 
getMountInfo() - Method in class alluxio.master.file.meta.MountTable.ReverseResolution
 
getMountMethod() - Static method in class alluxio.grpc.FileSystemMasterClientServiceGrpc
 
getMountOption(String) - Method in class alluxio.table.common.udb.UdbConfiguration
Returns the mount option for a particular scheme and authority URL.
getMountOptions() - Method in class alluxio.wire.UfsInfo
 
getMountPoint() - Method in class alluxio.fuse.AlluxioFuseOptions
 
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
 
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() - Method in class alluxio.client.file.BaseFileSystem
 
getMountTable() - 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() - 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() - Method in class alluxio.client.file.RetryHandlingFileSystemMasterClient
 
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.FileSystemMasterClientServiceImplBase
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.hadoop.AlluxioHdfsFileSystem
 
getMountTable() - Method in class alluxio.master.file.DefaultFileSystemMaster
 
getMountTable() - Method in interface alluxio.master.file.FileSystemMaster
 
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
 
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) - Method in class alluxio.conf.InstancedConfiguration
 
getMs(PropertyKey) - Method in class alluxio.conf.path.SpecificPathConfiguration
 
getMs(PropertyKey) - Static method in class alluxio.conf.ServerConfiguration
Gets the time of key in millisecond unit.
getMsArg(CommandLine, Option, long) - Static method in class alluxio.cli.fs.FileSystemShellUtils
Gets the value of an option from the command line.
getMultipartTemporaryDirForObject(String, String) - Static method in class alluxio.proxy.s3.S3RestUtils
 
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.
getMutableConfig() - Method in class alluxio.proto.journal.Table.AttachDbEntry.Builder
Deprecated.
getMutableCurrentBlocksOnTiers() - Method in class alluxio.grpc.RegisterWorkerPRequest.Builder
Deprecated.
getMutableErrors() - Method in class alluxio.grpc.ConfigCheckReport.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.
getMutableParameter() - Method in class alluxio.proto.journal.Table.UpdateDatabaseInfoEntry.Builder
Deprecated.
getMutableParameters() - Method in class alluxio.grpc.table.layout.hive.PartitionInfo.Builder
Deprecated.
getMutableParameters() - Method in class alluxio.grpc.table.TableInfo.Builder
Deprecated.
getMutableParameters() - Method in class alluxio.proto.journal.Table.AddTableEntry.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.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.
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.
getMutableTransformedLayouts() - Method in class alluxio.proto.journal.Table.AddTransformJobInfoEntry.Builder
Deprecated.
getMutableTransformedLayouts() - Method in class alluxio.proto.journal.Table.CompleteTransformTableEntry.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.FileInfo.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.
getName() - Method in class alluxio.AlluxioURI
Gets the final component of the AlluxioURI.
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 do not have these
getName() - Method in class alluxio.grpc.JobInfo
Some jobs don't have these do not have these
getName() - Method in interface alluxio.grpc.JobInfoOrBuilder
Some jobs don't have these do not have these
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.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 interface alluxio.job.JobConfig
 
getName() - Method in class alluxio.job.plan.load.LoadConfig
 
getName() - Method in class alluxio.job.plan.migrate.MigrateConfig
 
getName() - Method in class alluxio.job.plan.persist.PersistConfig
 
getName() - Method in class alluxio.job.plan.replicate.EvictConfig
 
getName() - Method in class alluxio.job.plan.replicate.MoveConfig
 
getName() - Method in class alluxio.job.plan.replicate.ReplicateConfig
 
getName() - Method in class alluxio.job.plan.transform.CompactConfig
 
getName() - Method in class alluxio.job.plan.transform.FieldSchema
 
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 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.master.PrimarySelectorClient
 
getName() - Method in class alluxio.master.table.Database
 
getName() - Method in class alluxio.master.table.DefaultTableMaster
 
getName() - Method in class alluxio.master.table.Table
 
getName() - Method in class alluxio.master.table.TableMasterFactory
 
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.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.proxy.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.table.common.BaseProperty
 
getName() - Method in interface alluxio.table.common.transform.action.TransformActionFactory
 
getName() - Method in class alluxio.table.common.transform.action.WriteAction.WriteActionFactory
 
getName() - Method in interface alluxio.table.common.udb.UdbTable
 
getName() - Method in interface alluxio.table.common.udb.UnderDatabase
 
getName() - Method in class alluxio.table.under.hive.HiveDatabase
 
getName() - Method in class alluxio.table.under.hive.HiveTable
 
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.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.block.DefaultBlockWorker
 
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 do not have these
getNameBytes() - Method in class alluxio.grpc.JobInfo
Some jobs don't have these do not have these
getNameBytes() - Method in interface alluxio.grpc.JobInfoOrBuilder
Some jobs don't have these do not have these
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.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.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.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
 
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) - Method in class alluxio.conf.InstancedConfiguration
 
getNestedProperties(PropertyKey) - Method in class alluxio.conf.path.SpecificPathConfiguration
 
getNestedProperties(PropertyKey) - Static method in class alluxio.conf.ServerConfiguration
Gets a set of properties that share a given common prefix key as a map.
getNetAddress() - Method in class alluxio.client.block.BlockWorkerInfo
 
getNettyOutput() - Method in class alluxio.grpc.ReadableDataBuffer
 
getNettyOutput() - Method in interface alluxio.network.protocol.databuffer.DataBuffer
Returns an object for writing to a netty channel.
getNettyOutput() - Method in class alluxio.network.protocol.databuffer.NettyDataBuffer
 
getNettyOutput() - Method in class alluxio.network.protocol.databuffer.NioDataBuffer
 
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) - 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.FileSystemMasterClientServiceImplBase
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;
getNextChunk() - Method in interface alluxio.underfs.ObjectUnderFileSystem.ObjectListingChunk
Gets next chunk of object listings.
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.proxy.s3.ListBucketResult
 
getNextInputStream() - Method in interface alluxio.master.journalv0.JournalReader
 
getNextInputStream() - Method in class alluxio.master.journalv0.ufs.UfsJournalReader
 
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.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
 
getNextTier(StorageTierView) - Method in class alluxio.worker.block.BlockMetadataView
Gets the next storage tier view.
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.
getNonExistingDirectoryStatusTest() - Method in class alluxio.examples.UnderFileSystemCommonOperations
Test for getting status of non-existent directory.
getNonExistingFileStatusTest() - Method in class alluxio.examples.UnderFileSystemCommonOperations
Test for getting status of non-existent file.
getNonExistingPathStatusTest() - Method in class alluxio.examples.UnderFileSystemCommonOperations
Test for getting status of non-existent path.
getNormalNodeInfos() - Method in class alluxio.wire.MasterWebUIWorkers
Get normal node infos node info [ ].
getNow(T) - Method in class alluxio.concurrent.jsr.CompletableFuture
Returns the result value (or throws any encountered exception) if completed, else returns the given valueIfAbsent.
getNTotalFile() - Method in class alluxio.wire.MasterWebUIBrowse
Gets n total file.
getNTotalFile() - Method in class alluxio.wire.MasterWebUILogs
Gets n total file.
getNTotalFile() - Method in class alluxio.wire.WorkerWebUIBlockInfo
Gets n total file.
getNTotalFile() - Method in class alluxio.wire.WorkerWebUILogs
Gets n total file.
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.JobType
 
getNumber() - Method in enum alluxio.grpc.JournalDomain
 
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.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.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.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.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
getNumberOfBlocks() - Method in class alluxio.worker.block.DefaultBlockStoreMeta
 
getNumberOfDependents() - Method in class alluxio.concurrent.jsr.CompletableFuture
Returns the estimated number of CompletableFutures whose completions are awaiting completion of this CompletableFuture.
getNumberOfPinnedFiles() - Method in class alluxio.master.file.DefaultFileSystemMaster
 
getNumberOfPinnedFiles() - Method in interface alluxio.master.file.FileSystemMaster
 
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;
getNumLocations() - Method in class alluxio.master.block.meta.MasterBlockInfo
 
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
 
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(String, long, long, long) - Method in class alluxio.underfs.kodo.KodoClient
Gets object from Qiniu kodo.
getObjectListingChunk(String, boolean) - Method in class alluxio.underfs.cos.COSUnderFileSystem
 
getObjectListingChunk(String, boolean) - Method in class alluxio.underfs.gcs.GCSUnderFileSystem
 
getObjectListingChunk(String, boolean) - Method in class alluxio.underfs.kodo.KodoUnderFileSystem
 
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.oss.OSSUnderFileSystem
 
getObjectListingChunk(String, boolean) - Method in class alluxio.underfs.s3a.S3AUnderFileSystem
 
getObjectListingChunk(String, boolean) - Method in class alluxio.underfs.swift.SwiftUnderFileSystem
 
getObjectListingChunkForPath(String, boolean) - 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
 
getObjectOrListParts(String, String, Long) - Method in class alluxio.proxy.s3.S3RestServiceHandler
 
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.kodo.KodoUnderFileSystem
Gets metadata information about object.
getObjectStatus(String) - Method in class alluxio.underfs.ObjectUnderFileSystem
Get metadata information about object.
getObjectStatus(String) - Method in class alluxio.underfs.oss.OSSUnderFileSystem
 
getObjectStatus(String) - Method in class alluxio.underfs.s3a.S3AUnderFileSystem
 
getObjectStatus(String) - Method in class alluxio.underfs.swift.SwiftUnderFileSystem
 
getObjectStatuses() - Method in interface alluxio.underfs.ObjectUnderFileSystem.ObjectListingChunk
Returns objects in a pseudo-directory which may be a file or a directory.
getOffset() - Method in class alluxio.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.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
Errors will be handled by standard gRPC stream APIs.
getOffset() - Method in class alluxio.grpc.WriteResponse
Errors will be handled by standard gRPC stream APIs.
getOffset() - Method in interface alluxio.grpc.WriteResponseOrBuilder
Errors will be handled by standard gRPC stream APIs.
getOffset() - Method in class alluxio.underfs.options.FileLocationOptions
 
getOffset() - Method in class alluxio.underfs.options.OpenOptions
 
getOffset() - Method in class alluxio.wire.FileBlockInfo
 
getOffset() - Method in class alluxio.worker.block.meta.UnderFileSystemBlockMeta
 
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.ReadRequest.Builder
Read receipt
getOffsetReceived() - Method in class alluxio.grpc.ReadRequest
Read receipt
getOffsetReceived() - Method in interface alluxio.grpc.ReadRequestOrBuilder
Read receipt
getOnlyReserveSpace() - Method in class alluxio.grpc.CreateLocalBlockRequest.Builder
If set, only reserve space for the block.
getOnlyReserveSpace() - Method in class alluxio.grpc.CreateLocalBlockRequest
If set, only reserve space for the block.
getOnlyReserveSpace() - Method in interface alluxio.grpc.CreateLocalBlockRequestOrBuilder
If set, only reserve space for the block.
getOnTierPercentages() - Method in class alluxio.util.webui.UIFileInfo
Gets on-tier percentages.
getOpenLocalBlockMethod() - Static method in class alluxio.grpc.BlockWorkerGrpc
 
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.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.worker.grpc.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.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.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.
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
 
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.validation.AbstractValidationTask
 
getOptionList() - Method in class alluxio.cli.validation.HdfsValidationTask
 
getOptionList() - Method in interface alluxio.cli.validation.ValidationTask
 
getOptions() - Method in interface alluxio.cli.Command
 
getOptions() - Method in class alluxio.cli.fs.command.CheckConsistencyCommand
 
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.CopyFromLocalCommand
 
getOptions() - Method in class alluxio.cli.fs.command.CopyToLocalCommand
 
getOptions() - Method in class alluxio.cli.fs.command.CountCommand
 
getOptions() - Method in class alluxio.cli.fs.command.CpCommand
 
getOptions() - Method in class alluxio.cli.fs.command.DistributedLoadCommand
 
getOptions() - Method in class alluxio.cli.fs.command.DuCommand
 
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.MountCommand
 
getOptions() - Method in class alluxio.cli.fs.command.PersistCommand
 
getOptions() - Method in class alluxio.cli.fs.command.RmCommand
 
getOptions() - Method in class alluxio.cli.fs.command.SetFaclCommand
 
getOptions() - Method in class alluxio.cli.fs.command.SetReplicationCommand
 
getOptions() - Method in class alluxio.cli.fs.command.SetTtlCommand
 
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.fs.command.UpdateMountCommand
 
getOptions() - Method in class alluxio.cli.fsadmin.command.BackupCommand
 
getOptions() - Method in class alluxio.cli.fsadmin.command.DoctorCommand
 
getOptions() - Method in class alluxio.cli.fsadmin.command.GetBlockInfoCommand
 
getOptions() - Method in class alluxio.cli.fsadmin.command.ReportCommand
 
getOptions() - Method in class alluxio.cli.fsadmin.command.UfsCommand
 
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.cli.fsadmin.pathconf.AddCommand
 
getOptions() - Method in class alluxio.cli.fsadmin.pathconf.RemoveCommand
 
getOptions() - Method in class alluxio.cli.fsadmin.pathconf.ShowCommand
 
getOptions() - Method in class alluxio.cli.job.command.StatCommand
 
getOptions() - Method in class alluxio.cli.table.command.AttachDatabaseCommand
 
getOptions() - Method in class alluxio.cli.table.command.TransformTableCommand
 
getOptions() - Method in class alluxio.client.file.options.InStreamOptions
 
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.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.CommitBlockInUfsPRequest.Builder
optional .alluxio.grpc.block.CommitBlockInUfsPOptions options = 3;
getOptions() - Method in class alluxio.grpc.CommitBlockInUfsPRequest
optional .alluxio.grpc.block.CommitBlockInUfsPOptions options = 3;
getOptions() - Method in interface alluxio.grpc.CommitBlockInUfsPRequestOrBuilder
optional .alluxio.grpc.block.CommitBlockInUfsPOptions options = 3;
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.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.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.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.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.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.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.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.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.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.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.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.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.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.StartSyncPRequest.Builder
optional .alluxio.grpc.file.StartSyncPOptions options = 2;
getOptions() - Method in class alluxio.grpc.StartSyncPRequest
optional .alluxio.grpc.file.StartSyncPOptions options = 2;
getOptions() - Method in interface alluxio.grpc.StartSyncPRequestOrBuilder
optional .alluxio.grpc.file.StartSyncPOptions options = 2;
getOptions() - Method in class alluxio.grpc.StopSyncPRequest.Builder
optional .alluxio.grpc.file.StopSyncPOptions options = 2;
getOptions() - Method in class alluxio.grpc.StopSyncPRequest
optional .alluxio.grpc.file.StopSyncPOptions options = 2;
getOptions() - Method in interface alluxio.grpc.StopSyncPRequestOrBuilder
optional .alluxio.grpc.file.StopSyncPOptions 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.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.master.file.contexts.OperationContext
 
getOptions() - Method in class alluxio.master.file.meta.options.MountInfo
 
getOptions() - Method in class alluxio.util.UnixMountInfo
 
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.CheckConsistencyPRequest.Builder
optional .alluxio.grpc.file.CheckConsistencyPOptions options = 2;
getOptionsBuilder() - Method in class alluxio.grpc.CommitBlockInUfsPRequest.Builder
optional .alluxio.grpc.block.CommitBlockInUfsPOptions options = 3;
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.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.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.GetFileInfoPRequest.Builder
optional .alluxio.grpc.file.GetFileInfoPOptions options = 2;
getOptionsBuilder() - Method in class alluxio.grpc.GetJobServiceSummaryPRequest.Builder
optional .alluxio.grpc.job.GetJobServiceSummaryPOptions options = 1;
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.GetQuorumInfoPRequest.Builder
optional .alluxio.grpc.journal.GetQuorumInfoPOptions 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.ListAllPRequest.Builder
optional .alluxio.grpc.job.ListAllPOptions options = 1;
getOptionsBuilder() - Method in class alluxio.grpc.ListStatusPRequest.Builder
optional .alluxio.grpc.file.ListStatusPOptions 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.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.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.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.StartSyncPRequest.Builder
optional .alluxio.grpc.file.StartSyncPOptions options = 2;
getOptionsBuilder() - Method in class alluxio.grpc.StopSyncPRequest.Builder
optional .alluxio.grpc.file.StopSyncPOptions options = 2;
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;
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.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.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.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.CommitBlockInUfsPRequest.Builder
optional .alluxio.grpc.block.CommitBlockInUfsPOptions options = 3;
getOptionsOrBuilder() - Method in class alluxio.grpc.CommitBlockInUfsPRequest
optional .alluxio.grpc.block.CommitBlockInUfsPOptions options = 3;
getOptionsOrBuilder() - Method in interface alluxio.grpc.CommitBlockInUfsPRequestOrBuilder
optional .alluxio.grpc.block.CommitBlockInUfsPOptions options = 3;
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.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.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.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.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.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.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.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.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.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.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.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.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.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.StartSyncPRequest.Builder
optional .alluxio.grpc.file.StartSyncPOptions options = 2;
getOptionsOrBuilder() - Method in class alluxio.grpc.StartSyncPRequest
optional .alluxio.grpc.file.StartSyncPOptions options = 2;
getOptionsOrBuilder() - Method in interface alluxio.grpc.StartSyncPRequestOrBuilder
optional .alluxio.grpc.file.StartSyncPOptions options = 2;
getOptionsOrBuilder() - Method in class alluxio.grpc.StopSyncPRequest.Builder
optional .alluxio.grpc.file.StopSyncPOptions options = 2;
getOptionsOrBuilder() - Method in class alluxio.grpc.StopSyncPRequest
optional .alluxio.grpc.file.StopSyncPOptions options = 2;
getOptionsOrBuilder() - Method in interface alluxio.grpc.StopSyncPRequestOrBuilder
optional .alluxio.grpc.file.StopSyncPOptions options = 2;
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;
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;
getOptionStrings() - Method in class alluxio.AlluxioRemoteLogFilter
Deprecated.
Gets the option strings.
getOrBuildCustom(String) - Static method in class alluxio.conf.PropertyKey
 
getOrDefault(PropertyKey, String) - Method in interface alluxio.conf.AlluxioConfiguration
 
getOrDefault(PropertyKey, String, ConfigurationValueOptions) - Method in interface alluxio.conf.AlluxioConfiguration
 
getOrDefault(PropertyKey, String) - Static method in class alluxio.conf.ServerConfiguration
 
getOrDefault(PropertyKey, String, ConfigurationValueOptions) - Static method in class alluxio.conf.ServerConfiguration
 
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.StorageTierAssoc
 
getOrderedTierAliases() - Method in class alluxio.wire.WorkerWebUIBlockInfo
Gets ordered tier aliases.
getOrdinal(String) - Method in class alluxio.StorageTierAssoc
 
getOrNull() - Static method in class alluxio.security.authentication.AuthenticatedClientUser
 
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
 
getOutput() - Method in class alluxio.job.plan.transform.CompactConfig
 
getOutput() - Method in class alluxio.job.plan.transform.CompactTask
 
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.BlockWriteRequestContext
 
getOutputStream() - Method in class alluxio.worker.grpc.UfsFileWriteRequestContext
 
getOutStream(long, long, WorkerNetAddress, OutStreamOptions) - Method in class alluxio.client.block.AlluxioBlockStore
Gets a stream to write data to a block.
getOutStream(long, long, OutStreamOptions) - Method in class alluxio.client.block.AlluxioBlockStore
Gets a stream to write data to a block based on the options.
getOutStream(Integer) - Method in class alluxio.StreamCache
 
getOverriddenMethodDescriptors() - Method in class alluxio.worker.grpc.BlockWorkerImpl
 
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.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.proto.journal.Table.AddTableEntry.Builder
optional string owner = 3;
getOwner() - Method in class alluxio.proto.journal.Table.AddTableEntry
optional string owner = 3;
getOwner() - Method in interface alluxio.proto.journal.Table.AddTableEntryOrBuilder
optional string owner = 3;
getOwner() - Method in interface alluxio.table.common.udb.UdbTable
 
getOwner() - Method in class alluxio.table.under.hive.HiveTable
 
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.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;
getOwnerBytes() - Method in class alluxio.proto.journal.Table.AddTableEntry.Builder
optional string owner = 3;
getOwnerBytes() - Method in class alluxio.proto.journal.Table.AddTableEntry
optional string owner = 3;
getOwnerBytes() - Method in interface alluxio.proto.journal.Table.AddTableEntryOrBuilder
optional string owner = 3;
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;
getOwnerName() - Method in class alluxio.master.table.DatabaseInfo
 
getOwnerName() - Method in class alluxio.proto.journal.Table.UpdateDatabaseInfoEntry.Builder
optional string owner_name = 4;
getOwnerName() - Method in class alluxio.proto.journal.Table.UpdateDatabaseInfoEntry
optional string owner_name = 4;
getOwnerName() - Method in interface alluxio.proto.journal.Table.UpdateDatabaseInfoEntryOrBuilder
optional string owner_name = 4;
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;
getOwnerNameBytes() - Method in class alluxio.proto.journal.Table.UpdateDatabaseInfoEntry.Builder
optional string owner_name = 4;
getOwnerNameBytes() - Method in class alluxio.proto.journal.Table.UpdateDatabaseInfoEntry
optional string owner_name = 4;
getOwnerNameBytes() - Method in interface alluxio.proto.journal.Table.UpdateDatabaseInfoEntryOrBuilder
optional string owner_name = 4;
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;
getOwnerType() - Method in class alluxio.master.table.DatabaseInfo
 
getOwnerType() - Method in class alluxio.proto.journal.Table.UpdateDatabaseInfoEntry.Builder
optional .alluxio.grpc.table.PrincipalType owner_type = 5;
getOwnerType() - Method in class alluxio.proto.journal.Table.UpdateDatabaseInfoEntry
optional .alluxio.grpc.table.PrincipalType owner_type = 5;
getOwnerType() - Method in interface alluxio.proto.journal.Table.UpdateDatabaseInfoEntryOrBuilder
optional .alluxio.grpc.table.PrincipalType owner_type = 5;
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;
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.DefaultMetaStore
 
getPageInfo(PageId) - Method in interface alluxio.client.file.cache.MetaStore
 
getPages() - Method in interface alluxio.client.file.cache.PageStore
Gets a stream of all pages from the page store.
getPages() - Method in class alluxio.client.file.cache.store.LocalPageStore
 
getPages() - Method in class alluxio.client.file.cache.store.RocksPageStore
 
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;
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.
getParameter() - Method in class alluxio.proto.journal.Table.UpdateDatabaseInfoEntry.Builder
Deprecated.
getParameter() - Method in class alluxio.proto.journal.Table.UpdateDatabaseInfoEntry
Deprecated.
getParameter() - Method in interface alluxio.proto.journal.Table.UpdateDatabaseInfoEntryOrBuilder
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;
getParameterCount() - Method in class alluxio.proto.journal.Table.UpdateDatabaseInfoEntry.Builder
 
getParameterCount() - Method in class alluxio.proto.journal.Table.UpdateDatabaseInfoEntry
 
getParameterCount() - Method in interface alluxio.proto.journal.Table.UpdateDatabaseInfoEntryOrBuilder
map<string, string> parameter = 3;
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;
getParameterMap() - Method in class alluxio.proto.journal.Table.UpdateDatabaseInfoEntry.Builder
map<string, string> parameter = 3;
getParameterMap() - Method in class alluxio.proto.journal.Table.UpdateDatabaseInfoEntry
map<string, string> parameter = 3;
getParameterMap() - Method in interface alluxio.proto.journal.Table.UpdateDatabaseInfoEntryOrBuilder
map<string, string> parameter = 3;
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;
getParameterOrDefault(String, String) - Method in class alluxio.proto.journal.Table.UpdateDatabaseInfoEntry.Builder
map<string, string> parameter = 3;
getParameterOrDefault(String, String) - Method in class alluxio.proto.journal.Table.UpdateDatabaseInfoEntry
map<string, string> parameter = 3;
getParameterOrDefault(String, String) - Method in interface alluxio.proto.journal.Table.UpdateDatabaseInfoEntryOrBuilder
map<string, string> parameter = 3;
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;
getParameterOrThrow(String) - Method in class alluxio.proto.journal.Table.UpdateDatabaseInfoEntry.Builder
map<string, string> parameter = 3;
getParameterOrThrow(String) - Method in class alluxio.proto.journal.Table.UpdateDatabaseInfoEntry
map<string, string> parameter = 3;
getParameterOrThrow(String) - Method in interface alluxio.proto.journal.Table.UpdateDatabaseInfoEntryOrBuilder
map<string, string> parameter = 3;
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.master.table.DatabaseInfo
 
getParameters() - Method in class alluxio.proto.journal.Table.AddTableEntry.Builder
Deprecated.
getParameters() - Method in class alluxio.proto.journal.Table.AddTableEntry
Deprecated.
getParameters() - Method in interface alluxio.proto.journal.Table.AddTableEntryOrBuilder
Deprecated.
getParameters() - Method in interface alluxio.table.common.udb.UdbTable
 
getParameters() - Method in class alluxio.table.under.hive.HiveTable
 
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;
getParametersCount() - Method in class alluxio.proto.journal.Table.AddTableEntry.Builder
 
getParametersCount() - Method in class alluxio.proto.journal.Table.AddTableEntry
 
getParametersCount() - Method in interface alluxio.proto.journal.Table.AddTableEntryOrBuilder
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;
getParametersMap() - Method in class alluxio.proto.journal.Table.AddTableEntry.Builder
map<string, string> parameters = 7;
getParametersMap() - Method in class alluxio.proto.journal.Table.AddTableEntry
map<string, string> parameters = 7;
getParametersMap() - Method in interface alluxio.proto.journal.Table.AddTableEntryOrBuilder
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;
getParametersOrDefault(String, String) - Method in class alluxio.proto.journal.Table.AddTableEntry.Builder
map<string, string> parameters = 7;
getParametersOrDefault(String, String) - Method in class alluxio.proto.journal.Table.AddTableEntry
map<string, string> parameters = 7;
getParametersOrDefault(String, String) - Method in interface alluxio.proto.journal.Table.AddTableEntryOrBuilder
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;
getParametersOrThrow(String) - Method in class alluxio.proto.journal.Table.AddTableEntry.Builder
map<string, string> parameters = 7;
getParametersOrThrow(String) - Method in class alluxio.proto.journal.Table.AddTableEntry
map<string, string> parameters = 7;
getParametersOrThrow(String) - Method in interface alluxio.proto.journal.Table.AddTableEntryOrBuilder
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.
getParentDir() - Method in class alluxio.worker.block.meta.AbstractBlockMeta
 
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.
getParentTier() - Method in class alluxio.worker.block.meta.StorageDir
Returns the StorageTier containing this StorageDir.
getParentTierView() - Method in class alluxio.worker.block.meta.StorageDirView
 
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.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.BlockStoreLocationProto
 
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.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.Command
 
getParserForType() - Method in class alluxio.grpc.CommitBlockInUfsPOptions
 
getParserForType() - Method in class alluxio.grpc.CommitBlockInUfsPRequest
 
getParserForType() - Method in class alluxio.grpc.CommitBlockInUfsPResponse
 
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.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.CreateLocalBlockRequest
 
getParserForType() - Method in class alluxio.grpc.CreateLocalBlockResponse
 
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.ExistsPOptions
 
getParserForType() - Method in class alluxio.grpc.FileBlockInfo
 
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.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.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.GetJobServiceSummaryPOptions
 
getParserForType() - Method in class alluxio.grpc.GetJobServiceSummaryPRequest
 
getParserForType() - Method in class alluxio.grpc.GetJobServiceSummaryPResponse
 
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.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.GetPinnedFileIdsPOptions
 
getParserForType() - Method in class alluxio.grpc.GetPinnedFileIdsPRequest
 
getParserForType() - Method in class alluxio.grpc.GetPinnedFileIdsPResponse
 
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.GetServiceVersionPRequest
 
getParserForType() - Method in class alluxio.grpc.GetServiceVersionPResponse
 
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.GetSyncPathListPRequest
 
getParserForType() - Method in class alluxio.grpc.GetSyncPathListPResponse
 
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.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.JobServiceSummary
 
getParserForType() - Method in class alluxio.grpc.JobUnused
 
getParserForType() - Method in class alluxio.grpc.JobWorkerHealth
 
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.ListStatusPOptions
 
getParserForType() - Method in class alluxio.grpc.ListStatusPRequest
 
getParserForType() - Method in class alluxio.grpc.ListStatusPResponse
 
getParserForType() - Method in class alluxio.grpc.LoadMetadataPOptions
 
getParserForType() - Method in class alluxio.grpc.LocalityTier
 
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.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.NetAddress
 
getParserForType() - Method in class alluxio.grpc.OpenFilePOptions
 
getParserForType() - Method in class alluxio.grpc.OpenLocalBlockRequest
 
getParserForType() - Method in class alluxio.grpc.OpenLocalBlockResponse
 
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.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.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.RemovePathConfigurationPOptions
 
getParserForType() - Method in class alluxio.grpc.RemovePathConfigurationPRequest
 
getParserForType() - Method in class alluxio.grpc.RemovePathConfigurationPResponse
 
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.ReverseResolvePRequest
 
getParserForType() - Method in class alluxio.grpc.ReverseResolvePResponse
 
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.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.StartSyncPOptions
 
getParserForType() - Method in class alluxio.grpc.StartSyncPRequest
 
getParserForType() - Method in class alluxio.grpc.StartSyncPResponse
 
getParserForType() - Method in class alluxio.grpc.StatusSummary
 
getParserForType() - Method in class alluxio.grpc.StopSyncPOptions
 
getParserForType() - Method in class alluxio.grpc.StopSyncPRequest
 
getParserForType() - Method in class alluxio.grpc.StopSyncPResponse
 
getParserForType() - Method in class alluxio.grpc.StorageList
 
getParserForType() - Method in class alluxio.grpc.SyncPointInfo
 
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.TieredIdentity
 
getParserForType() - Method in class alluxio.grpc.TierList
 
getParserForType() - Method in class alluxio.grpc.TransportMessage
 
getParserForType() - Method in class alluxio.grpc.UfsInfo
 
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.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.WorkerInfo
 
getParserForType() - Method in class alluxio.grpc.WorkerLostStorageInfo
 
getParserForType() - Method in class alluxio.grpc.WorkerNetAddress
 
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.CreateUfsBlockOptions
 
getParserForType() - Method in class alluxio.proto.dataserver.Protocol.CreateUfsFileOptions
 
getParserForType() - Method in class alluxio.proto.dataserver.Protocol.OpenUfsBlockOptions
 
getParserForType() - Method in class alluxio.proto.dataserver.Protocol.Response
 
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.Journal.JournalEntry
 
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.Table.AddTableEntry
 
getParserForType() - Method in class alluxio.proto.journal.Table.AddTransformJobInfoEntry
 
getParserForType() - Method in class alluxio.proto.journal.Table.AttachDbEntry
 
getParserForType() - Method in class alluxio.proto.journal.Table.CompleteTransformTableEntry
 
getParserForType() - Method in class alluxio.proto.journal.Table.DetachDbEntry
 
getParserForType() - Method in class alluxio.proto.journal.Table.RemoveTableEntry
 
getParserForType() - Method in class alluxio.proto.journal.Table.RemoveTransformJobInfoEntry
 
getParserForType() - Method in class alluxio.proto.journal.Table.UpdateDatabaseInfoEntry
 
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.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
 
getParticipants() - Method in class alluxio.master.PrimarySelectorClient
 
getPartition(String) - Method in class alluxio.master.table.BasePartitionScheme
 
getPartition(String) - Method in interface alluxio.master.table.PartitionScheme
 
getPartition(String) - Method in class alluxio.master.table.Table
 
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
getPartitionCols() - Method in class alluxio.master.table.PartitionedTableScheme
 
getPartitionCols() - Method in interface alluxio.master.table.PartitionScheme
Get partition columns.
getPartitionCols() - Method in class alluxio.master.table.UnpartitionedTableScheme
 
getPartitionCols(int) - Method in class alluxio.proto.journal.Table.AddTableEntry.Builder
partitioning scheme
getPartitionCols(int) - Method in class alluxio.proto.journal.Table.AddTableEntry
partitioning scheme
getPartitionCols(int) - Method in interface alluxio.proto.journal.Table.AddTableEntryOrBuilder
partitioning scheme
getPartitionCols() - Method in interface alluxio.table.common.udb.UdbTable
 
getPartitionCols() - Method in class alluxio.table.under.hive.HiveTable
 
getPartitionColsBuilder(int) - Method in class alluxio.grpc.table.TableInfo.Builder
partitioning scheme
getPartitionColsBuilder(int) - Method in class alluxio.proto.journal.Table.AddTableEntry.Builder
partitioning scheme
getPartitionColsBuilderList() - Method in class alluxio.grpc.table.TableInfo.Builder
partitioning scheme
getPartitionColsBuilderList() - Method in class alluxio.proto.journal.Table.AddTableEntry.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
getPartitionColsCount() - Method in class alluxio.proto.journal.Table.AddTableEntry.Builder
partitioning scheme
getPartitionColsCount() - Method in class alluxio.proto.journal.Table.AddTableEntry
partitioning scheme
getPartitionColsCount() - Method in interface alluxio.proto.journal.Table.AddTableEntryOrBuilder
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
getPartitionColsList() - Method in class alluxio.proto.journal.Table.AddTableEntry.Builder
partitioning scheme
getPartitionColsList() - Method in class alluxio.proto.journal.Table.AddTableEntry
partitioning scheme
getPartitionColsList() - Method in interface alluxio.proto.journal.Table.AddTableEntryOrBuilder
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
getPartitionColsOrBuilder(int) - Method in class alluxio.proto.journal.Table.AddTableEntry.Builder
partitioning scheme
getPartitionColsOrBuilder(int) - Method in class alluxio.proto.journal.Table.AddTableEntry
partitioning scheme
getPartitionColsOrBuilder(int) - Method in interface alluxio.proto.journal.Table.AddTableEntryOrBuilder
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
getPartitionColsOrBuilderList() - Method in class alluxio.proto.journal.Table.AddTableEntry.Builder
partitioning scheme
getPartitionColsOrBuilderList() - Method in class alluxio.proto.journal.Table.AddTableEntry
partitioning scheme
getPartitionColsOrBuilderList() - Method in interface alluxio.proto.journal.Table.AddTableEntryOrBuilder
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) - 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.TableMasterClientServiceImplBase
 
getPartitionColumnStatistics(GetPartitionColumnStatisticsPRequest, StreamObserver<GetPartitionColumnStatisticsPResponse>) - Method in class alluxio.grpc.table.TableMasterClientServiceGrpc.TableMasterClientServiceStub
 
getPartitionColumnStatistics(String, String, List<String>, List<String>) - Method in class alluxio.master.table.AlluxioCatalog
Returns the statistics for the specified table.
getPartitionColumnStatistics(String, String, List<String>, List<String>) - Method in class alluxio.master.table.DefaultTableMaster
 
getPartitionColumnStatistics(String, String, List<String>, List<String>) - Method in interface alluxio.master.table.TableMaster
Get statistics on the partitions.
getPartitionColumnStatistics(GetPartitionColumnStatisticsPRequest, StreamObserver<GetPartitionColumnStatisticsPResponse>) - Method in class alluxio.master.table.TableMasterClientServiceHandler
 
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
 
getPartitionInfo() - Method in class alluxio.job.plan.transform.CompactConfig
 
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;
getPartitions() - Method in class alluxio.master.table.BasePartitionScheme
 
getPartitions() - Method in interface alluxio.master.table.PartitionScheme
Get a list of partitions.
getPartitions() - Method in class alluxio.master.table.Table
 
getPartitions(int) - Method in class alluxio.proto.journal.Table.AddTableEntry.Builder
repeated .alluxio.grpc.table.Partition partitions = 9;
getPartitions(int) - Method in class alluxio.proto.journal.Table.AddTableEntry
repeated .alluxio.grpc.table.Partition partitions = 9;
getPartitions(int) - Method in interface alluxio.proto.journal.Table.AddTableEntryOrBuilder
repeated .alluxio.grpc.table.Partition partitions = 9;
getPartitions() - Method in interface alluxio.table.common.udb.UdbTable
 
getPartitions() - Method in class alluxio.table.under.hive.HiveTable
 
getPartitionsBuilder(int) - Method in class alluxio.grpc.table.ReadTablePResponse.Builder
repeated .alluxio.grpc.table.Partition partitions = 1;
getPartitionsBuilder(int) - Method in class alluxio.proto.journal.Table.AddTableEntry.Builder
repeated .alluxio.grpc.table.Partition partitions = 9;
getPartitionsBuilderList() - Method in class alluxio.grpc.table.ReadTablePResponse.Builder
repeated .alluxio.grpc.table.Partition partitions = 1;
getPartitionsBuilderList() - Method in class alluxio.proto.journal.Table.AddTableEntry.Builder
repeated .alluxio.grpc.table.Partition partitions = 9;
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;
getPartitionsCount() - Method in class alluxio.proto.journal.Table.AddTableEntry.Builder
repeated .alluxio.grpc.table.Partition partitions = 9;
getPartitionsCount() - Method in class alluxio.proto.journal.Table.AddTableEntry
repeated .alluxio.grpc.table.Partition partitions = 9;
getPartitionsCount() - Method in interface alluxio.proto.journal.Table.AddTableEntryOrBuilder
repeated .alluxio.grpc.table.Partition partitions = 9;
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;
getPartitionsList() - Method in class alluxio.proto.journal.Table.AddTableEntry.Builder
repeated .alluxio.grpc.table.Partition partitions = 9;
getPartitionsList() - Method in class alluxio.proto.journal.Table.AddTableEntry
repeated .alluxio.grpc.table.Partition partitions = 9;
getPartitionsList() - Method in interface alluxio.proto.journal.Table.AddTableEntryOrBuilder
repeated .alluxio.grpc.table.Partition partitions = 9;
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;
getPartitionsOrBuilder(int) - Method in class alluxio.proto.journal.Table.AddTableEntry.Builder
repeated .alluxio.grpc.table.Partition partitions = 9;
getPartitionsOrBuilder(int) - Method in class alluxio.proto.journal.Table.AddTableEntry
repeated .alluxio.grpc.table.Partition partitions = 9;
getPartitionsOrBuilder(int) - Method in interface alluxio.proto.journal.Table.AddTableEntryOrBuilder
repeated .alluxio.grpc.table.Partition partitions = 9;
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;
getPartitionsOrBuilderList() - Method in class alluxio.proto.journal.Table.AddTableEntry.Builder
repeated .alluxio.grpc.table.Partition partitions = 9;
getPartitionsOrBuilderList() - Method in class alluxio.proto.journal.Table.AddTableEntry
repeated .alluxio.grpc.table.Partition partitions = 9;
getPartitionsOrBuilderList() - Method in interface alluxio.proto.journal.Table.AddTableEntryOrBuilder
repeated .alluxio.grpc.table.Partition partitions = 9;
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.ListPartsResult.Part
 
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.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.CreateLocalBlockResponse.Builder
optional string path = 1;
getPath() - Method in class alluxio.grpc.CreateLocalBlockResponse
optional string path = 1;
getPath() - Method in interface alluxio.grpc.CreateLocalBlockResponseOrBuilder
optional string path = 1;
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.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.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.OpenLocalBlockResponse.Builder
optional string path = 1;
getPath() - Method in class alluxio.grpc.OpenLocalBlockResponse
optional string path = 1;
getPath() - Method in interface alluxio.grpc.OpenLocalBlockResponseOrBuilder
optional 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.grpc.StartSyncPRequest.Builder
optional string path = 1;
getPath() - Method in class alluxio.grpc.StartSyncPRequest
optional string path = 1;
getPath() - Method in interface alluxio.grpc.StartSyncPRequestOrBuilder
optional string path = 1;
getPath() - Method in class alluxio.grpc.StopSyncPRequest.Builder
optional string path = 1;
getPath() - Method in class alluxio.grpc.StopSyncPRequest
optional string path = 1;
getPath() - Method in interface alluxio.grpc.StopSyncPRequestOrBuilder
optional string path = 1;
getPath() - Method in class alluxio.job.plan.replicate.ReplicateConfig
 
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(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.journal.raft.RaftJournalConfiguration
 
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 class alluxio.worker.block.meta.AbstractBlockMeta
 
getPath() - Method in class alluxio.worker.block.meta.BlockMeta
 
getPath() - Method in class alluxio.worker.block.meta.TempBlockMeta
 
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.CreateLocalBlockResponse.Builder
optional string path = 1;
getPathBytes() - Method in class alluxio.grpc.CreateLocalBlockResponse
optional string path = 1;
getPathBytes() - Method in interface alluxio.grpc.CreateLocalBlockResponseOrBuilder
optional string path = 1;
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.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.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.OpenLocalBlockResponse.Builder
optional string path = 1;
getPathBytes() - Method in class alluxio.grpc.OpenLocalBlockResponse
optional string path = 1;
getPathBytes() - Method in interface alluxio.grpc.OpenLocalBlockResponseOrBuilder
optional 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.grpc.StartSyncPRequest.Builder
optional string path = 1;
getPathBytes() - Method in class alluxio.grpc.StartSyncPRequest
optional string path = 1;
getPathBytes() - Method in interface alluxio.grpc.StartSyncPRequestOrBuilder
optional string path = 1;
getPathBytes() - Method in class alluxio.grpc.StopSyncPRequest.Builder
optional string path = 1;
getPathBytes() - Method in class alluxio.grpc.StopSyncPRequest
optional string path = 1;
getPathBytes() - Method in interface alluxio.grpc.StopSyncPRequestOrBuilder
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(AlluxioURI) - Method in class alluxio.client.file.FileSystemContext
The path level configuration is a SpecificPathConfiguration.
getPathConf() - Method in class alluxio.ClientContext
 
getPathConf(GetConfigurationPResponse, AlluxioConfiguration) - Static method in class alluxio.util.ConfigurationUtils
Loads the path level configuration from the get configuration response.
getPathConf() - Method in class alluxio.wire.Configuration
 
getPathConfHash() - Method in class alluxio.ClientContext
 
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
 
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;
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;
getPathInfos() - Method in class alluxio.wire.MasterWebUIBrowse
Get path infos ui file info [ ].
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;
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
 
getPayload() - Method in class alluxio.collections.DirectedAcyclicGraphNode
Gets the payload of the node.
getPendingCount() - Method in class alluxio.concurrent.jsr.CountedCompleter
Returns the current pending count.
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.kodo.KodoUnderFileSystem
 
getPermissions() - Method in class alluxio.underfs.ObjectUnderFileSystem
Permissions for the mounted bucket.
getPermissions() - Method in class alluxio.underfs.oss.OSSUnderFileSystem
 
getPermissions() - Method in class alluxio.underfs.s3a.S3AUnderFileSystem
 
getPermissions() - Method in class alluxio.underfs.swift.SwiftUnderFileSystem
 
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
 
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) - 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.FileSystemMasterWorkerServiceImplBase
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.CreateLocalBlockRequest.Builder
optional bool pin_on_create = 8;
getPinOnCreate() - Method in class alluxio.grpc.CreateLocalBlockRequest
optional bool pin_on_create = 8;
getPinOnCreate() - Method in interface alluxio.grpc.CreateLocalBlockRequestOrBuilder
optional bool pin_on_create = 8;
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;
getPinOnCreate() - Method in class alluxio.worker.grpc.WriteRequest
 
getPlanInfoWire(boolean) - Method in class alluxio.master.job.plan.PlanCoordinator
 
getPool() - Static method in class alluxio.concurrent.jsr.ForkJoinTask
Returns the pool hosting the current thread, or null if the current thread is executing outside of any ForkJoinPool.
getPool() - Method in class alluxio.concurrent.jsr.ForkJoinWorkerThread
Returns the pool hosting this thread.
getPoolIndex() - Method in class alluxio.concurrent.jsr.ForkJoinWorkerThread
Returns the unique index number of this thread in its pool.
getPoolSize() - Method in class alluxio.concurrent.jsr.ForkJoinPool
Returns the number of worker threads that have started but not yet terminated.
getPort() - Method in class alluxio.master.CoreMasterContext
 
getPort() - Method in class alluxio.multi.process.PortCoordination.ReservedPort
 
getPort() - Method in class alluxio.uri.SingleMasterAuthority
 
getPort(NetworkAddressUtils.ServiceType, AlluxioConfiguration) - Static method in class alluxio.util.network.NetworkAddressUtils
Gets the port number on a given service type.
getPortKey() - Method in enum alluxio.util.network.NetworkAddressUtils.ServiceType
Gets the key of service port.
getPos() - Method in class alluxio.client.block.stream.BlockInStream
 
getPos() - Method in class alluxio.client.file.AlluxioFileInStream
 
getPos() - Method in class alluxio.client.file.cache.LocalCacheFileInStream
 
getPos() - Method in class alluxio.hadoop.AlluxioHdfsInputStream
 
getPos() - Method in class alluxio.hadoop.HdfsFileInputStream
 
getPos() - Method in interface alluxio.Positioned
 
getPos() - Method in class alluxio.underfs.hdfs.HdfsPositionedUnderFileInputStream
 
getPos() - Method in class alluxio.underfs.hdfs.HdfsUnderFileInputStream
 
getPos() - Method in class alluxio.worker.grpc.WriteRequestContext
 
getPosition() - Method in interface alluxio.worker.block.io.BlockWriter
 
getPosition() - Method in class alluxio.worker.block.io.LocalFileBlockWriter
 
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.underfs.options.OpenOptions
 
getPosReceived() - Method in class alluxio.worker.grpc.ReadRequestContext
 
getPosToQueue() - Method in class alluxio.worker.grpc.ReadRequestContext
 
getPrecision() - Method in class alluxio.job.plan.transform.format.csv.Decimal
 
getPrecisionAndScale(String) - Static method in class alluxio.job.plan.transform.format.csv.Decimal
Returns the decimal's precision and scale from the type definition.
getPrefix() - Method in class alluxio.proxy.s3.ListBucketOptions
 
getPrefix() - Method in class alluxio.proxy.s3.ListBucketResult
 
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;
getPreviousVersion() - Method in class alluxio.master.table.Table
 
getPreviousVersion() - Method in class alluxio.proto.journal.Table.AddTableEntry.Builder
optional int64 previous_version = 10;
getPreviousVersion() - Method in class alluxio.proto.journal.Table.AddTableEntry
optional int64 previous_version = 10;
getPreviousVersion() - Method in interface alluxio.proto.journal.Table.AddTableEntryOrBuilder
optional int64 previous_version = 10;
getPrimaryGroupName(String, AlluxioConfiguration) - Static method in class alluxio.util.CommonUtils
Gets the primary group name of a user.
getPrimaryMasterIndex(int) - Method in class alluxio.multi.process.MultiProcessCluster
Gets the index of the primary master.
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.journal.raft.RaftJournalSystem
 
getPrintStream() - Method in class alluxio.cli.fsadmin.command.Context
 
getProcessType() - Method in class alluxio.AlluxioRemoteLogFilter
Retrieves the string representation of process type.
getPromote() - Method in class alluxio.grpc.OpenLocalBlockRequest.Builder
optional bool promote = 2;
getPromote() - Method in class alluxio.grpc.OpenLocalBlockRequest
optional bool promote = 2;
getPromote() - Method in interface alluxio.grpc.OpenLocalBlockRequestOrBuilder
optional bool promote = 2;
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
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.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.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.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.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.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.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
 
getPropertyKeys(AlluxioURI) - Method in interface alluxio.conf.path.PathConfiguration
 
getPropertyKeys(AlluxioURI) - Method in class alluxio.conf.path.PrefixPathConfiguration
 
getProxyAddress() - Method in class alluxio.master.journal.raft.RaftJournalConfiguration
 
getProxyDownloadFileApiUrl() - Method in class alluxio.wire.MasterWebUIInit
Gets proxy download file api url.
getProxyFor(Address) - Method in class alluxio.master.transport.GrpcMessagingProxy
 
getProxyProcess() - Method in class alluxio.master.AbstractLocalAlluxioCluster
Gets the proxy process.
getPublicURL() - Method in class alluxio.underfs.swift.KeystoneV3Access
 
getQuery() - Method in class alluxio.uri.StandardURI
 
getQuery() - Method in interface alluxio.uri.URI
 
getQueryMap() - Method in class alluxio.AlluxioURI
Gets the map of query parameters.
getQueuedSubmissionCount() - Method in class alluxio.concurrent.jsr.ForkJoinPool
Returns an estimate of the number of tasks submitted to this pool that have not yet begun executing.
getQueuedTaskCount() - Method in class alluxio.concurrent.jsr.ForkJoinPool
Returns an estimate of the total number of tasks currently held in queues by worker threads (but not including tasks submitted to the pool that have not begun executing).
getQueuedTaskCount() - Static method in class alluxio.concurrent.jsr.ForkJoinTask
Returns an estimate of the number of tasks that have been forked by the current worker thread but not yet executed.
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) - 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.JournalMasterClientServiceImplBase
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.
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
optional .alluxio.grpc.table.RangeSet range = 1;
getRange() - Method in class alluxio.grpc.table.Domain
optional .alluxio.grpc.table.RangeSet range = 1;
getRange() - Method in interface alluxio.grpc.table.DomainOrBuilder
optional .alluxio.grpc.table.RangeSet range = 1;
getRangeBuilder() - Method in class alluxio.grpc.table.Domain.Builder
optional .alluxio.grpc.table.RangeSet range = 1;
getRangeOrBuilder() - Method in class alluxio.grpc.table.Domain.Builder
optional .alluxio.grpc.table.RangeSet range = 1;
getRangeOrBuilder() - Method in class alluxio.grpc.table.Domain
optional .alluxio.grpc.table.RangeSet range = 1;
getRangeOrBuilder() - Method in interface alluxio.grpc.table.DomainOrBuilder
optional .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
 
getReadHoldCount() - Method in class alluxio.concurrent.WeakSafeReentrantReadWriteLock
Queries the number of reentrant read holds on this lock by the current thread.
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 interface alluxio.network.protocol.databuffer.DataBuffer
Returns a ByteBuffer for read-only access to the data.
getReadOnlyByteBuffer() - Method in class alluxio.network.protocol.databuffer.NettyDataBuffer
 
getReadOnlyByteBuffer() - Method in class alluxio.network.protocol.databuffer.NioDataBuffer
 
getReadSchema() - Method in class alluxio.job.plan.transform.format.csv.CsvSchema
 
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;
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;
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;
getRecord() - Method in class alluxio.job.plan.transform.format.parquet.ParquetRow
 
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;
getReferenceCount() - Method in class alluxio.worker.block.ClientRWLock
 
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;
getRegisterJobWorkerMethod() - Static method in class alluxio.grpc.JobMasterWorkerServiceGrpc
 
getRegisterMasterMethod() - Static method in class alluxio.grpc.MetaMasterMasterServiceGrpc
 
getRegisterWorkerMethod() - Static method in class alluxio.grpc.BlockMasterWorkerServiceGrpc
 
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.meta.RetryHandlingMetaMasterMasterClient
 
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
 
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.
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;
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;
getRemoveTable() - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
optional .alluxio.proto.journal.RemoveTableEntry remove_table = 50;
getRemoveTable() - Method in class alluxio.proto.journal.Journal.JournalEntry
optional .alluxio.proto.journal.RemoveTableEntry remove_table = 50;
getRemoveTable() - Method in interface alluxio.proto.journal.Journal.JournalEntryOrBuilder
optional .alluxio.proto.journal.RemoveTableEntry remove_table = 50;
getRemoveTableBuilder() - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
optional .alluxio.proto.journal.RemoveTableEntry remove_table = 50;
getRemoveTableOrBuilder() - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
optional .alluxio.proto.journal.RemoveTableEntry remove_table = 50;
getRemoveTableOrBuilder() - Method in class alluxio.proto.journal.Journal.JournalEntry
optional .alluxio.proto.journal.RemoveTableEntry remove_table = 50;
getRemoveTableOrBuilder() - Method in interface alluxio.proto.journal.Journal.JournalEntryOrBuilder
optional .alluxio.proto.journal.RemoveTableEntry remove_table = 50;
getRemoveTransformJobInfo() - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
optional .alluxio.proto.journal.RemoveTransformJobInfoEntry remove_transform_job_info = 47;
getRemoveTransformJobInfo() - Method in class alluxio.proto.journal.Journal.JournalEntry
optional .alluxio.proto.journal.RemoveTransformJobInfoEntry remove_transform_job_info = 47;
getRemoveTransformJobInfo() - Method in interface alluxio.proto.journal.Journal.JournalEntryOrBuilder
optional .alluxio.proto.journal.RemoveTransformJobInfoEntry remove_transform_job_info = 47;
getRemoveTransformJobInfoBuilder() - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
optional .alluxio.proto.journal.RemoveTransformJobInfoEntry remove_transform_job_info = 47;
getRemoveTransformJobInfoOrBuilder() - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
optional .alluxio.proto.journal.RemoveTransformJobInfoEntry remove_transform_job_info = 47;
getRemoveTransformJobInfoOrBuilder() - Method in class alluxio.proto.journal.Journal.JournalEntry
optional .alluxio.proto.journal.RemoveTransformJobInfoEntry remove_transform_job_info = 47;
getRemoveTransformJobInfoOrBuilder() - Method in interface alluxio.proto.journal.Journal.JournalEntryOrBuilder
optional .alluxio.proto.journal.RemoveTransformJobInfoEntry remove_transform_job_info = 47;
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.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;
getReplicas() - Method in class alluxio.job.plan.replicate.EvictConfig
 
getReplicas() - Method in class alluxio.job.plan.replicate.ReplicateConfig
 
getReplication() - Method in class alluxio.job.plan.load.LoadConfig
 
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.
getReport() - Method in class alluxio.worker.block.DefaultBlockWorker
 
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.ReadRequestContext
 
getRequest() - Method in class alluxio.worker.grpc.WriteRequestContext
 
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.proxy.s3.S3Error
 
getRequestMarshaller() - Method in class alluxio.grpc.DataMessageMarshallerProvider
 
getResource() - Method in class alluxio.proxy.s3.S3Error
 
getResource() - Method in exception alluxio.proxy.s3.S3Exception
 
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
 
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
Get the combined result from all batches.
getResultFromProcess(String[]) - Static method in class alluxio.cli.validation.Utils
Executes a command in another process and check for its execution result.
getReverseResolveMethod() - Static method in class alluxio.grpc.FileSystemMasterClientServiceGrpc
 
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.kodo.KodoUnderFileSystem
Gets full path of root in object store.
getRootKey() - Method in class alluxio.underfs.ObjectUnderFileSystem
Get full path of root in object store.
getRootKey() - Method in class alluxio.underfs.oss.OSSUnderFileSystem
 
getRootKey() - Method in class alluxio.underfs.s3a.S3AUnderFileSystem
 
getRootKey() - Method in class alluxio.underfs.swift.SwiftUnderFileSystem
 
getRootPath() - Method in class alluxio.AlluxioURI
 
getRoots() - Method in class alluxio.collections.DirectedAcyclicGraph
Gets the payloads of all the root nodes of the DAG.
getRootUserName() - Method in class alluxio.master.file.meta.InodeTree
 
getRows() - Method in class alluxio.job.plan.transform.format.csv.CsvWriter
 
getRows() - Method in class alluxio.job.plan.transform.format.parquet.ParquetWriter
 
getRows() - Method in class alluxio.job.plan.transform.format.tables.TablesWriter
 
getRows() - Method in interface alluxio.job.plan.transform.format.TableWriter
 
getRpcAddress() - Method in class alluxio.master.AlluxioJobMasterProcess
 
getRpcAddress() - Method in class alluxio.master.AlluxioMasterProcess
 
getRpcAddress() - Method in class alluxio.master.MasterProcess
 
getRpcAddress() - Method in class alluxio.master.meta.AlluxioMasterRestServiceHandler
Deprecated.
since version 1.4 and will be removed in version 2.0
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 class alluxio.worker.AlluxioWorkerRestServiceHandler
Deprecated.
since version 1.4 and will be removed in version 2.0
getRpcAddress() - Method in interface alluxio.worker.JobWorkerProcess
 
getRpcAddress() - Method in interface alluxio.worker.WorkerProcess
 
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.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) - Static method in class alluxio.util.network.NetworkAddressUtils
Extracts rpcPort InetSocketAddress from Alluxio representation of network address.
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;
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;
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.CoreMasterContext
 
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
getScale() - Method in class alluxio.job.plan.transform.format.csv.Decimal
 
getScheduleAsyncPersistenceMethod() - Static method in class alluxio.grpc.FileSystemMasterClientServiceGrpc
 
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;
getSchema() - Method in class alluxio.job.plan.transform.format.csv.CsvReader
 
getSchema() - Method in class alluxio.job.plan.transform.format.parquet.ParquetReader
 
getSchema() - Method in class alluxio.job.plan.transform.format.parquet.ParquetSchema
 
getSchema() - Method in interface alluxio.job.plan.transform.format.TableReader
 
getSchema() - Method in class alluxio.master.table.Table
 
getSchema() - Method in class alluxio.proto.journal.Table.AddTableEntry.Builder
optional .alluxio.grpc.table.Schema schema = 4;
getSchema() - Method in class alluxio.proto.journal.Table.AddTableEntry
optional .alluxio.grpc.table.Schema schema = 4;
getSchema() - Method in interface alluxio.proto.journal.Table.AddTableEntryOrBuilder
optional .alluxio.grpc.table.Schema schema = 4;
getSchema() - Method in interface alluxio.table.common.udb.UdbTable
 
getSchema() - Method in class alluxio.table.under.hive.HiveTable
 
getSchemaBuilder() - Method in class alluxio.grpc.table.TableInfo.Builder
optional .alluxio.grpc.table.Schema schema = 5;
getSchemaBuilder() - Method in class alluxio.proto.journal.Table.AddTableEntry.Builder
optional .alluxio.grpc.table.Schema schema = 4;
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;
getSchemaOrBuilder() - Method in class alluxio.proto.journal.Table.AddTableEntry.Builder
optional .alluxio.grpc.table.Schema schema = 4;
getSchemaOrBuilder() - Method in class alluxio.proto.journal.Table.AddTableEntry
optional .alluxio.grpc.table.Schema schema = 4;
getSchemaOrBuilder() - Method in interface alluxio.proto.journal.Table.AddTableEntryOrBuilder
optional .alluxio.grpc.table.Schema schema = 4;
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() - Method in class alluxio.uri.MultiPartSchemeURI
 
getScheme() - Method in class alluxio.uri.StandardURI
 
getScheme() - Method in interface alluxio.uri.URI
 
getSchemeAuthority(AlluxioConfiguration) - Static method in class alluxio.util.ConfigurationUtils
 
getSchemeComponents(String) - Static method in class alluxio.uri.URI.Factory
Returns a Pair of components of the given scheme.
getSchemeSpecificPart() - Method in class alluxio.uri.StandardURI
 
getSchemeSpecificPart() - Method in interface alluxio.uri.URI
 
getScope() - Method in class alluxio.conf.PropertyKey
 
getSecond() - Method in class alluxio.collections.Pair
 
getSecurityAuthorizationPermissionEnabled() - Method in class alluxio.wire.MasterWebUIInit
Gets security authorization permission enabled.
getSecurityAuthorizationPermissionEnabled() - Method in class alluxio.wire.WorkerWebUIInit
Gets security authorization permission enabled.
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
optional int64 sequence_number = 1;
getSequenceNumber() - Method in class alluxio.proto.journal.Journal.JournalEntry
optional int64 sequence_number = 1;
getSequenceNumber() - Method in interface alluxio.proto.journal.Journal.JournalEntryOrBuilder
optional int64 sequence_number = 1;
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;
getSerdeClass() - Method in class alluxio.job.plan.transform.PartitionInfo
 
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;
getSerdeProperties() - Method in class alluxio.job.plan.transform.PartitionInfo
 
getSerializedJournalEntry() - Method in class alluxio.master.journal.raft.JournalEntryCommand
 
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.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.BlockStoreLocationProto
 
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.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.Command
 
getSerializedSize() - Method in class alluxio.grpc.CommitBlockInUfsPOptions
 
getSerializedSize() - Method in class alluxio.grpc.CommitBlockInUfsPRequest
 
getSerializedSize() - Method in class alluxio.grpc.CommitBlockInUfsPResponse
 
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.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.CreateLocalBlockRequest
 
getSerializedSize() - Method in class alluxio.grpc.CreateLocalBlockResponse
 
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.ExistsPOptions
 
getSerializedSize() - Method in class alluxio.grpc.FileBlockInfo
 
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.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.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.GetJobServiceSummaryPOptions
 
getSerializedSize() - Method in class alluxio.grpc.GetJobServiceSummaryPRequest
 
getSerializedSize() - Method in class alluxio.grpc.GetJobServiceSummaryPResponse
 
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.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.GetPinnedFileIdsPOptions
 
getSerializedSize() - Method in class alluxio.grpc.GetPinnedFileIdsPRequest
 
getSerializedSize() - Method in class alluxio.grpc.GetPinnedFileIdsPResponse
 
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.GetServiceVersionPRequest
 
getSerializedSize() - Method in class alluxio.grpc.GetServiceVersionPResponse
 
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.GetSyncPathListPRequest
 
getSerializedSize() - Method in class alluxio.grpc.GetSyncPathListPResponse
 
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.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.JobServiceSummary
 
getSerializedSize() - Method in class alluxio.grpc.JobUnused
 
getSerializedSize() - Method in class alluxio.grpc.JobWorkerHealth
 
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.ListStatusPOptions
 
getSerializedSize() - Method in class alluxio.grpc.ListStatusPRequest
 
getSerializedSize() - Method in class alluxio.grpc.ListStatusPResponse
 
getSerializedSize() - Method in class alluxio.grpc.LoadMetadataPOptions
 
getSerializedSize() - Method in class alluxio.grpc.LocalityTier
 
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.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.NetAddress
 
getSerializedSize() - Method in class alluxio.grpc.OpenFilePOptions
 
getSerializedSize() - Method in class alluxio.grpc.OpenLocalBlockRequest
 
getSerializedSize() - Method in class alluxio.grpc.OpenLocalBlockResponse
 
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.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.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.RemovePathConfigurationPOptions
 
getSerializedSize() - Method in class alluxio.grpc.RemovePathConfigurationPRequest
 
getSerializedSize() - Method in class alluxio.grpc.RemovePathConfigurationPResponse
 
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.ReverseResolvePRequest
 
getSerializedSize() - Method in class alluxio.grpc.ReverseResolvePResponse
 
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.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.StartSyncPOptions
 
getSerializedSize() - Method in class alluxio.grpc.StartSyncPRequest
 
getSerializedSize() - Method in class alluxio.grpc.StartSyncPResponse
 
getSerializedSize() - Method in class alluxio.grpc.StatusSummary
 
getSerializedSize() - Method in class alluxio.grpc.StopSyncPOptions
 
getSerializedSize() - Method in class alluxio.grpc.StopSyncPRequest
 
getSerializedSize() - Method in class alluxio.grpc.StopSyncPResponse
 
getSerializedSize() - Method in class alluxio.grpc.StorageList
 
getSerializedSize() - Method in class alluxio.grpc.SyncPointInfo
 
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.TieredIdentity
 
getSerializedSize() - Method in class alluxio.grpc.TierList
 
getSerializedSize() - Method in class alluxio.grpc.TransportMessage
 
getSerializedSize() - Method in class alluxio.grpc.UfsInfo
 
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.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.WorkerInfo
 
getSerializedSize() - Method in class alluxio.grpc.WorkerLostStorageInfo
 
getSerializedSize() - Method in class alluxio.grpc.WorkerNetAddress
 
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.CreateUfsBlockOptions
 
getSerializedSize() - Method in class alluxio.proto.dataserver.Protocol.CreateUfsFileOptions
 
getSerializedSize() - Method in class alluxio.proto.dataserver.Protocol.OpenUfsBlockOptions
 
getSerializedSize() - Method in class alluxio.proto.dataserver.Protocol.Response
 
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.Journal.JournalEntry
 
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.Table.AddTableEntry
 
getSerializedSize() - Method in class alluxio.proto.journal.Table.AddTransformJobInfoEntry
 
getSerializedSize() - Method in class alluxio.proto.journal.Table.AttachDbEntry
 
getSerializedSize() - Method in class alluxio.proto.journal.Table.CompleteTransformTableEntry
 
getSerializedSize() - Method in class alluxio.proto.journal.Table.DetachDbEntry
 
getSerializedSize() - Method in class alluxio.proto.journal.Table.RemoveTableEntry
 
getSerializedSize() - Method in class alluxio.proto.journal.Table.RemoveTransformJobInfoEntry
 
getSerializedSize() - Method in class alluxio.proto.journal.Table.UpdateDatabaseInfoEntry
 
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.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.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;
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;
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;
getServerChannelClass(boolean, AlluxioConfiguration) - Static method in class alluxio.util.network.NettyUtils
Returns the correct ServerSocketChannel class for use by the worker.
getServerHostnames() - Static method in class alluxio.cli.extensions.ExtensionsShellUtils
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
 
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.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.MetricsMasterClientServiceGrpc
 
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
 
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.block.BlockMasterClientRestServiceHandler
Deprecated.
 
getServiceName() - Method in class alluxio.master.file.FileSystemMasterClient
 
getServiceName() - Method in class alluxio.master.job.JobMasterClientRestServiceHandler
 
getServiceName() - Method in class alluxio.master.meta.RetryHandlingMetaMasterMasterClient
 
getServiceName() - Method in class alluxio.security.CurrentUser
 
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.meta.DefaultMetaMaster
 
getServices() - Method in class alluxio.master.metrics.DefaultMetricsMaster
 
getServices() - Method in class alluxio.master.NoopMaster
 
getServices() - Method in class alluxio.master.table.DefaultTableMaster
 
getServices() - Method in interface alluxio.Server
 
getServices() - Method in class alluxio.worker.block.DefaultBlockWorker
 
getServices() - Method in class alluxio.worker.JobWorker
 
getServiceType() - Method in class alluxio.grpc.GetServiceVersionPRequest.Builder
optional .alluxio.grpc.version.ServiceType serviceType = 1;
getServiceType() - Method in class alluxio.grpc.GetServiceVersionPRequest
optional .alluxio.grpc.version.ServiceType serviceType = 1;
getServiceType() - Method in interface alluxio.grpc.GetServiceVersionPRequestOrBuilder
optional .alluxio.grpc.version.ServiceType serviceType = 1;
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) - 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.ServiceVersionClientServiceImplBase
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.block.BlockMasterClientRestServiceHandler
Deprecated.
 
getServiceVersion() - Method in class alluxio.master.file.FileSystemMasterClient
 
getServiceVersion() - Method in class alluxio.master.job.JobMasterClientRestServiceHandler
 
getServiceVersion() - Method in class alluxio.master.meta.RetryHandlingMetaMasterMasterClient
 
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
 
getSessionId() - Method in class alluxio.SessionInfo
 
getSessionId() - Method in class alluxio.worker.block.meta.TempBlockMeta
 
getSessionId() - Method in class alluxio.worker.block.meta.UnderFileSystemBlockMeta
 
getSessionId() - Method in class alluxio.worker.grpc.WriteRequest
 
getSessionTempBlocks(long) - Method in class alluxio.worker.block.BlockMetadataManager
Gets all the temporary blocks associated with a session, empty list is returned if the session has no temporary blocks.
getSessionTempBlocks(long) - Method in class 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.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;
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
 
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
 
getShellName() - Method in class alluxio.cli.job.JobShell
 
getShellName() - Method in class alluxio.cli.table.TableShell
 
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.
getSize() - Method in class alluxio.master.journal.raft.JournalEntryCommand
 
getSize() - Method in class alluxio.proxy.s3.ListBucketResult.Content
 
getSize() - Method in class alluxio.proxy.s3.ListPartsResult.Part
 
getSize() - Method in class alluxio.util.UnixMountInfo.Options
 
getSize() - Method in class alluxio.util.webui.UIFileInfo
Gets size.
getSizeFromBytes(long) - Static method in class alluxio.util.FormatUtils
Returns a human-readable version of bytes 10GB 2048KB etc.
getSizeInfo(AlluxioURI, List<URIStatus>, boolean, boolean, boolean) - Static method in class alluxio.cli.fs.command.DuCommand
Gets and prints the size information of the input path according to options.
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;
getSleeper() - Method in class alluxio.time.TimeContext
 
getSleepTime() - Method in class alluxio.retry.ExponentialBackoffRetry
 
getSleepTime() - Method in class alluxio.retry.SleepingRetry
How long to sleep before the next retry is performed.
getSleepUnit() - Method in class alluxio.retry.SleepingRetry
Unit of time that SleepingRetry.getSleepTime() is measured in.
getSnapshot(UfsJournal) - Static method in class alluxio.master.journal.ufs.UfsJournalSnapshot
Creates a snapshot of the journal.
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() - Method in class alluxio.client.block.stream.BlockInStream
 
getSource(PropertyKey) - Method in interface alluxio.conf.AlluxioConfiguration
 
getSource(PropertyKey) - Method in class alluxio.conf.AlluxioProperties
 
getSource(PropertyKey) - Method in class alluxio.conf.InstancedConfiguration
 
getSource(PropertyKey) - Method in class alluxio.conf.path.SpecificPathConfiguration
 
getSource(PropertyKey) - Static method in class alluxio.conf.ServerConfiguration
 
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.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() - 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
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
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;
getSpace(String, UnderFileSystem.SpaceType) - Method in class alluxio.concurrent.ManagedBlockingUfsForwarder
 
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
 
getSpace(String, UnderFileSystem.SpaceType) - Method in class alluxio.underfs.web.WebUnderFileSystem
 
getSpaceToReserve() - Method in class alluxio.grpc.CreateLocalBlockRequest.Builder
optional int64 space_to_reserve = 4;
getSpaceToReserve() - Method in class alluxio.grpc.CreateLocalBlockRequest
optional int64 space_to_reserve = 4;
getSpaceToReserve() - Method in interface alluxio.grpc.CreateLocalBlockRequestOrBuilder
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;
getSpec() - Method in class alluxio.master.table.Partition
 
getSpec() - Method in interface alluxio.table.common.Layout
 
getSpec() - Method in class alluxio.table.common.layout.HiveLayout
 
getSpec() - Method in interface alluxio.table.common.UdbPartition
 
getSpec() - Method in class alluxio.table.under.hive.HivePartition
 
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;
getSrcLocation() - Method in class alluxio.worker.block.evictor.BlockTransferInfo
 
getStartSyncMethod() - Static method in class alluxio.grpc.FileSystemMasterClientServiceGrpc
 
getStartTime() - Method in class alluxio.job.MasterWorkerInfo
 
getStartTime() - Method in class alluxio.master.block.meta.MasterWorkerInfo
 
getStartTime() - Method in class alluxio.util.webui.UIWorkerInfo
Gets start time.
getStartTime() - Method in class alluxio.wire.MasterWebUIOverview
Gets start time.
getStartTimeMs() - Method in class alluxio.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.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.AlluxioMasterRestServiceHandler
Deprecated.
since version 1.4 and will be removed in version 2.0
getStartTimeMs() - Method in class alluxio.master.meta.DefaultMetaMaster
 
getStartTimeMs() - Method in interface alluxio.master.meta.MetaMaster
 
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 class alluxio.worker.AlluxioWorkerRestServiceHandler
Deprecated.
since version 1.4 and will be removed in version 2.0
getStartTimeMs() - Method in interface alluxio.worker.JobWorkerProcess
 
getStartTimeMs() - Method in interface alluxio.worker.WorkerProcess
 
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 interface alluxio.master.PrimarySelector
 
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.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;
getStateLockManager() - Method in class alluxio.master.MasterContext
 
getStateLockSleepDurationMs() - Method in class alluxio.grpc.BackupPOptions.Builder
optional int64 stateLockSleepDurationMs = 5;
getStateLockSleepDurationMs() - Method in class alluxio.grpc.BackupPOptions
optional int64 stateLockSleepDurationMs = 5;
getStateLockSleepDurationMs() - Method in interface alluxio.grpc.BackupPOptionsOrBuilder
optional int64 stateLockSleepDurationMs = 5;
getStateLockTimeoutMs() - Method in class alluxio.grpc.BackupPOptions.Builder
optional int64 stateLockTimeoutMs = 6;
getStateLockTimeoutMs() - Method in class alluxio.grpc.BackupPOptions
optional int64 stateLockTimeoutMs = 6;
getStateLockTimeoutMs() - Method in interface alluxio.grpc.BackupPOptionsOrBuilder
optional int64 stateLockTimeoutMs = 6;
getStateLockTryDurationMs() - Method in class alluxio.grpc.BackupPOptions.Builder
optional int64 stateLockTryDurationMs = 4;
getStateLockTryDurationMs() - Method in class alluxio.grpc.BackupPOptions
optional int64 stateLockTryDurationMs = 4;
getStateLockTryDurationMs() - Method in interface alluxio.grpc.BackupPOptionsOrBuilder
optional int64 stateLockTryDurationMs = 4;
getStateMachine() - Method in class alluxio.master.journal.raft.RaftJournal
 
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;
getStatistics(String) - Method in class alluxio.master.table.Database
 
getStatistics() - Method in class alluxio.master.table.Table
 
getStatistics() - Method in interface alluxio.table.common.udb.UdbTable
 
getStatistics() - Method in class alluxio.table.under.hive.HiveTable
 
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(AlluxioURI, GetStatusPOptions) - Method in class alluxio.client.file.BaseFileSystem
 
getStatus(AlluxioURI, GetStatusPOptions) - Method in class alluxio.client.file.DelegatingFileSystem
 
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.MetadataCachingBaseFileSystem
 
getStatus() - Method in class alluxio.client.file.options.InStreamOptions
 
getStatus(AlluxioURI, GetStatusPOptions) - Method in class alluxio.client.file.RetryHandlingFileSystemMasterClient
 
getStatus(String) - Method in class alluxio.concurrent.ManagedBlockingUfsForwarder
 
getStatus() - Method in exception alluxio.exception.status.AlluxioStatusException
 
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(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.FileSystemMasterClientServiceImplBase
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.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.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(AlluxioURI, GetStatusPOptions) - Method in class alluxio.hadoop.AlluxioHdfsFileSystem
 
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.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.
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.proxy.s3.S3ErrorCode
 
getStatus(String) - Method in class alluxio.underfs.hdfs.HdfsUnderFileSystem
 
getStatus(String) - Method in class alluxio.underfs.local.LocalUnderFileSystem
 
getStatus(String) - Method in class alluxio.underfs.ObjectUnderFileSystem
 
getStatus(String) - Method in interface alluxio.underfs.UnderFileSystem
Gets the file or directory status.
getStatus(String) - Method in class alluxio.underfs.UnderFileSystemWithLogging
 
getStatus(String) - Method in class alluxio.underfs.web.WebUnderFileSystem
 
getStatusBuilder() - Method in class alluxio.grpc.table.SyncDatabasePResponse.Builder
optional .alluxio.grpc.table.SyncStatus status = 2;
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.
getStatusDefaults(AlluxioConfiguration) - Static method in class alluxio.util.FileSystemOptions
 
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;
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
 
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.
getStopSyncMethod() - Static method in class alluxio.grpc.FileSystemMasterClientServiceGrpc
 
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.ListBucketResult.Content
 
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 class 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;
getStorageLevel() - Method in class alluxio.master.journal.raft.RaftJournalConfiguration
 
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 class alluxio.master.block.meta.MasterWorkerInfo
 
getStorageTierAssoc() - Method in class alluxio.worker.block.BlockMetadataManager
 
getStorageTierAssoc() - Method in interface alluxio.worker.block.BlockStoreMeta
 
getStorageTierAssoc() - Method in class alluxio.worker.block.DefaultBlockStoreMeta
 
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
getStoreMeta() - Method in interface alluxio.worker.block.BlockWorker
Gets the metadata for the entire block store.
getStoreMeta() - Method in class alluxio.worker.block.DefaultBlockWorker
 
getStoreMetaFull() - Method in interface alluxio.worker.block.BlockWorker
Similar as BlockWorker.getStoreMeta() except that this also contains full blockId list.
getStoreMetaFull() - Method in class alluxio.worker.block.DefaultBlockWorker
 
getStorePath(PageStoreType, String) - Static method in interface alluxio.client.file.cache.PageStore
Gets store path given root directory and store type.
getStream() - Method in class alluxio.master.journal.checkpoint.CompoundCheckpointFormat.CompoundCheckpointReader.Entry
Return a checkpoint stream containing the bytes for this checkpoint.
getStringStats() - Method in class alluxio.grpc.table.ColumnStatisticsData.Builder
optional .alluxio.grpc.table.StringColumnStatsData string_stats = 4;
getStringStats() - Method in class alluxio.grpc.table.ColumnStatisticsData
optional .alluxio.grpc.table.StringColumnStatsData string_stats = 4;
getStringStats() - Method in interface alluxio.grpc.table.ColumnStatisticsDataOrBuilder
optional .alluxio.grpc.table.StringColumnStatsData string_stats = 4;
getStringStatsBuilder() - Method in class alluxio.grpc.table.ColumnStatisticsData.Builder
optional .alluxio.grpc.table.StringColumnStatsData string_stats = 4;
getStringStatsOrBuilder() - Method in class alluxio.grpc.table.ColumnStatisticsData.Builder
optional .alluxio.grpc.table.StringColumnStatsData string_stats = 4;
getStringStatsOrBuilder() - Method in class alluxio.grpc.table.ColumnStatisticsData
optional .alluxio.grpc.table.StringColumnStatsData string_stats = 4;
getStringStatsOrBuilder() - Method in interface alluxio.grpc.table.ColumnStatisticsDataOrBuilder
optional .alluxio.grpc.table.StringColumnStatsData string_stats = 4;
getStringType() - Method in class alluxio.grpc.table.Value.Builder
optional string string_type = 3;
getStringType() - Method in class alluxio.grpc.table.Value
optional string string_type = 3;
getStringType() - Method in interface alluxio.grpc.table.ValueOrBuilder
optional string string_type = 3;
getStringTypeBytes() - Method in class alluxio.grpc.table.Value.Builder
optional string string_type = 3;
getStringTypeBytes() - Method in class alluxio.grpc.table.Value
optional string string_type = 3;
getStringTypeBytes() - Method in interface alluxio.grpc.table.ValueOrBuilder
optional 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.fsadmin.command.JournalCommand
 
getSubCommands() - Method in class alluxio.cli.fsadmin.command.MetricsCommand
 
getSubCommands() - Method in class alluxio.cli.fsadmin.command.PathConfCommand
 
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;
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
getSuffix() - Method in enum alluxio.job.plan.transform.Format
 
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;
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;
getSyncPathList() - Method in class alluxio.client.file.BaseFileSystem
 
getSyncPathList() - Method in class alluxio.client.file.DelegatingFileSystem
 
getSyncPathList() - Method in interface alluxio.client.file.FileSystem
Lists all the actively synced paths.
getSyncPathList() - Method in class alluxio.client.file.FileSystemCache.InstanceCachingFileSystem
 
getSyncPathList() - Method in interface alluxio.client.file.FileSystemMasterClient
get the list of paths that are currently being actively synced.
getSyncPathList() - Method in class alluxio.client.file.RetryHandlingFileSystemMasterClient
 
getSyncPathList(GetSyncPathListPRequest) - Method in class alluxio.grpc.FileSystemMasterClientServiceGrpc.FileSystemMasterClientServiceBlockingStub
Returns a list of paths that are being actively synced by Alluxio
getSyncPathList(GetSyncPathListPRequest) - Method in class alluxio.grpc.FileSystemMasterClientServiceGrpc.FileSystemMasterClientServiceFutureStub
Returns a list of paths that are being actively synced by Alluxio
getSyncPathList(GetSyncPathListPRequest, StreamObserver<GetSyncPathListPResponse>) - Method in class alluxio.grpc.FileSystemMasterClientServiceGrpc.FileSystemMasterClientServiceImplBase
Returns a list of paths that are being actively synced by Alluxio
getSyncPathList(GetSyncPathListPRequest, StreamObserver<GetSyncPathListPResponse>) - Method in class alluxio.grpc.FileSystemMasterClientServiceGrpc.FileSystemMasterClientServiceStub
Returns a list of paths that are being actively synced by Alluxio
getSyncPathList() - Method in class alluxio.hadoop.AlluxioHdfsFileSystem
 
getSyncPathList() - Method in class alluxio.master.file.activesync.ActiveSyncManager
Get the sync point list.
getSyncPathList() - Method in class alluxio.master.file.DefaultFileSystemMaster
 
getSyncPathList() - Method in interface alluxio.master.file.FileSystemMaster
 
getSyncPathList(GetSyncPathListPRequest, StreamObserver<GetSyncPathListPResponse>) - Method in class alluxio.master.file.FileSystemMasterClientServiceHandler
 
GetSyncPathListCommand - Class in alluxio.cli.fs.command
This class represents a getSyncPathList Command.
GetSyncPathListCommand(FileSystemContext) - Constructor for class alluxio.cli.fs.command.GetSyncPathListCommand
Create a GetSyncPathListCommand object.
GetSyncPathListPRequest - Class in alluxio.grpc
Protobuf type alluxio.grpc.file.GetSyncPathListPRequest
GetSyncPathListPRequest.Builder - Class in alluxio.grpc
Protobuf type alluxio.grpc.file.GetSyncPathListPRequest
GetSyncPathListPRequestOrBuilder - Interface in alluxio.grpc
 
GetSyncPathListPResponse - Class in alluxio.grpc
Protobuf type alluxio.grpc.file.GetSyncPathListPResponse
GetSyncPathListPResponse.Builder - Class in alluxio.grpc
Protobuf type alluxio.grpc.file.GetSyncPathListPResponse
GetSyncPathListPResponseOrBuilder - Interface in alluxio.grpc
 
getSyncPaths(int) - Method in class alluxio.grpc.GetSyncPathListPResponse.Builder
repeated .alluxio.grpc.file.SyncPointInfo syncPaths = 1;
getSyncPaths(int) - Method in class alluxio.grpc.GetSyncPathListPResponse
repeated .alluxio.grpc.file.SyncPointInfo syncPaths = 1;
getSyncPaths(int) - Method in interface alluxio.grpc.GetSyncPathListPResponseOrBuilder
repeated .alluxio.grpc.file.SyncPointInfo syncPaths = 1;
getSyncPathsBuilder(int) - Method in class alluxio.grpc.GetSyncPathListPResponse.Builder
repeated .alluxio.grpc.file.SyncPointInfo syncPaths = 1;
getSyncPathsBuilderList() - Method in class alluxio.grpc.GetSyncPathListPResponse.Builder
repeated .alluxio.grpc.file.SyncPointInfo syncPaths = 1;
getSyncPathsCount() - Method in class alluxio.grpc.GetSyncPathListPResponse.Builder
repeated .alluxio.grpc.file.SyncPointInfo syncPaths = 1;
getSyncPathsCount() - Method in class alluxio.grpc.GetSyncPathListPResponse
repeated .alluxio.grpc.file.SyncPointInfo syncPaths = 1;
getSyncPathsCount() - Method in interface alluxio.grpc.GetSyncPathListPResponseOrBuilder
repeated .alluxio.grpc.file.SyncPointInfo syncPaths = 1;
getSyncPathsList() - Method in class alluxio.grpc.GetSyncPathListPResponse.Builder
repeated .alluxio.grpc.file.SyncPointInfo syncPaths = 1;
getSyncPathsList() - Method in class alluxio.grpc.GetSyncPathListPResponse
repeated .alluxio.grpc.file.SyncPointInfo syncPaths = 1;
getSyncPathsList() - Method in interface alluxio.grpc.GetSyncPathListPResponseOrBuilder
repeated .alluxio.grpc.file.SyncPointInfo syncPaths = 1;
getSyncPathsOrBuilder(int) - Method in class alluxio.grpc.GetSyncPathListPResponse.Builder
repeated .alluxio.grpc.file.SyncPointInfo syncPaths = 1;
getSyncPathsOrBuilder(int) - Method in class alluxio.grpc.GetSyncPathListPResponse
repeated .alluxio.grpc.file.SyncPointInfo syncPaths = 1;
getSyncPathsOrBuilder(int) - Method in interface alluxio.grpc.GetSyncPathListPResponseOrBuilder
repeated .alluxio.grpc.file.SyncPointInfo syncPaths = 1;
getSyncPathsOrBuilderList() - Method in class alluxio.grpc.GetSyncPathListPResponse.Builder
repeated .alluxio.grpc.file.SyncPointInfo syncPaths = 1;
getSyncPathsOrBuilderList() - Method in class alluxio.grpc.GetSyncPathListPResponse
repeated .alluxio.grpc.file.SyncPointInfo syncPaths = 1;
getSyncPathsOrBuilderList() - Method in interface alluxio.grpc.GetSyncPathListPResponseOrBuilder
repeated .alluxio.grpc.file.SyncPointInfo syncPaths = 1;
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;
getSyncPoints() - Method in class alluxio.SyncInfo
Returns a list of sync points.
getSyncPointUri() - Method in class alluxio.grpc.SyncPointInfo.Builder
optional string syncPointUri = 1;
getSyncPointUri() - Method in class alluxio.grpc.SyncPointInfo
optional string syncPointUri = 1;
getSyncPointUri() - Method in interface alluxio.grpc.SyncPointInfoOrBuilder
optional string syncPointUri = 1;
getSyncPointUri() - Method in class alluxio.wire.SyncPointInfo
Get the uri of the sync point.
getSyncPointUriBytes() - Method in class alluxio.grpc.SyncPointInfo.Builder
optional string syncPointUri = 1;
getSyncPointUriBytes() - Method in class alluxio.grpc.SyncPointInfo
optional string syncPointUri = 1;
getSyncPointUriBytes() - Method in interface alluxio.grpc.SyncPointInfoOrBuilder
optional string syncPointUri = 1;
getSyncStatus() - Method in class alluxio.grpc.SyncPointInfo.Builder
optional .alluxio.grpc.file.SyncPointStatus syncStatus = 2;
getSyncStatus() - Method in class alluxio.grpc.SyncPointInfo
optional .alluxio.grpc.file.SyncPointStatus syncStatus = 2;
getSyncStatus() - Method in interface alluxio.grpc.SyncPointInfoOrBuilder
optional .alluxio.grpc.file.SyncPointStatus syncStatus = 2;
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;
getSyncStatus() - Method in class alluxio.wire.SyncPointInfo
Get the initial sync status.
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;
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) - 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.TableMasterClientServiceImplBase
Returns a specific table info
getTable(GetTablePRequest, StreamObserver<GetTablePResponse>) - Method in class alluxio.grpc.table.TableMasterClientServiceGrpc.TableMasterClientServiceStub
Returns a specific table info
getTable(String, String) - Method in class alluxio.master.table.AlluxioCatalog
Get a table object by name.
getTable(String) - Method in class alluxio.master.table.Database
 
getTable(String, String) - Method in class alluxio.master.table.DefaultTableMaster
 
getTable(String, String) - Method in interface alluxio.master.table.TableMaster
Get a table.
getTable(GetTablePRequest, StreamObserver<GetTablePResponse>) - Method in class alluxio.master.table.TableMasterClientServiceHandler
 
getTable() - Method in class alluxio.master.table.transform.TransformJobInfo
 
getTable(String) - Method in interface alluxio.table.common.udb.UnderDatabase
 
getTable(String) - Method in class alluxio.table.under.hive.HiveDatabase
 
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) - 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.TableMasterClientServiceImplBase
 
getTableColumnStatistics(GetTableColumnStatisticsPRequest, StreamObserver<GetTableColumnStatisticsPResponse>) - Method in class alluxio.grpc.table.TableMasterClientServiceGrpc.TableMasterClientServiceStub
 
getTableColumnStatistics(String, String, List<String>) - Method in class alluxio.master.table.AlluxioCatalog
Returns the statistics for the specified table.
getTableColumnStatistics(String, String, List<String>) - Method in class alluxio.master.table.DefaultTableMaster
 
getTableColumnStatistics(String, String, List<String>) - Method in interface alluxio.master.table.TableMaster
Get statistics on the table.
getTableColumnStatistics(GetTableColumnStatisticsPRequest, StreamObserver<GetTableColumnStatisticsPResponse>) - Method in class alluxio.master.table.TableMasterClientServiceHandler
 
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;
getTableLayout() - Method in class alluxio.master.table.PartitionedTableScheme
 
getTableLayout() - Method in interface alluxio.master.table.PartitionScheme
Get table layout.
getTableLayout() - Method in class alluxio.master.table.UnpartitionedTableScheme
 
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;
getTableLocation(String) - Method in class alluxio.table.common.udb.UdbContext
 
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;
getTableName() - Method in class alluxio.proto.journal.Table.AddTableEntry.Builder
optional string table_name = 2;
getTableName() - Method in class alluxio.proto.journal.Table.AddTableEntry
optional string table_name = 2;
getTableName() - Method in interface alluxio.proto.journal.Table.AddTableEntryOrBuilder
optional string table_name = 2;
getTableName() - Method in class alluxio.proto.journal.Table.AddTransformJobInfoEntry.Builder
optional string table_name = 2;
getTableName() - Method in class alluxio.proto.journal.Table.AddTransformJobInfoEntry
optional string table_name = 2;
getTableName() - Method in interface alluxio.proto.journal.Table.AddTransformJobInfoEntryOrBuilder
optional string table_name = 2;
getTableName() - Method in class alluxio.proto.journal.Table.CompleteTransformTableEntry.Builder
optional string table_name = 2;
getTableName() - Method in class alluxio.proto.journal.Table.CompleteTransformTableEntry
optional string table_name = 2;
getTableName() - Method in interface alluxio.proto.journal.Table.CompleteTransformTableEntryOrBuilder
optional string table_name = 2;
getTableName() - Method in class alluxio.proto.journal.Table.RemoveTableEntry.Builder
optional string table_name = 2;
getTableName() - Method in class alluxio.proto.journal.Table.RemoveTableEntry
optional string table_name = 2;
getTableName() - Method in interface alluxio.proto.journal.Table.RemoveTableEntryOrBuilder
optional string table_name = 2;
getTableName() - Method in class alluxio.proto.journal.Table.RemoveTransformJobInfoEntry.Builder
optional string table_name = 2;
getTableName() - Method in class alluxio.proto.journal.Table.RemoveTransformJobInfoEntry
optional string table_name = 2;
getTableName() - Method in interface alluxio.proto.journal.Table.RemoveTransformJobInfoEntryOrBuilder
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;
getTableNameBytes() - Method in class alluxio.proto.journal.Table.AddTableEntry.Builder
optional string table_name = 2;
getTableNameBytes() - Method in class alluxio.proto.journal.Table.AddTableEntry
optional string table_name = 2;
getTableNameBytes() - Method in interface alluxio.proto.journal.Table.AddTableEntryOrBuilder
optional string table_name = 2;
getTableNameBytes() - Method in class alluxio.proto.journal.Table.AddTransformJobInfoEntry.Builder
optional string table_name = 2;
getTableNameBytes() - Method in class alluxio.proto.journal.Table.AddTransformJobInfoEntry
optional string table_name = 2;
getTableNameBytes() - Method in interface alluxio.proto.journal.Table.AddTransformJobInfoEntryOrBuilder
optional string table_name = 2;
getTableNameBytes() - Method in class alluxio.proto.journal.Table.CompleteTransformTableEntry.Builder
optional string table_name = 2;
getTableNameBytes() - Method in class alluxio.proto.journal.Table.CompleteTransformTableEntry
optional string table_name = 2;
getTableNameBytes() - Method in interface alluxio.proto.journal.Table.CompleteTransformTableEntryOrBuilder
optional string table_name = 2;
getTableNameBytes() - Method in class alluxio.proto.journal.Table.RemoveTableEntry.Builder
optional string table_name = 2;
getTableNameBytes() - Method in class alluxio.proto.journal.Table.RemoveTableEntry
optional string table_name = 2;
getTableNameBytes() - Method in interface alluxio.proto.journal.Table.RemoveTableEntryOrBuilder
optional string table_name = 2;
getTableNameBytes() - Method in class alluxio.proto.journal.Table.RemoveTransformJobInfoEntry.Builder
optional string table_name = 2;
getTableNameBytes() - Method in class alluxio.proto.journal.Table.RemoveTransformJobInfoEntry
optional string table_name = 2;
getTableNameBytes() - Method in interface alluxio.proto.journal.Table.RemoveTransformJobInfoEntryOrBuilder
optional string table_name = 2;
getTableNames() - Method in interface alluxio.table.common.udb.UnderDatabase
 
getTableNames() - Method in class alluxio.table.under.hive.HiveDatabase
 
getTablePathInternal(String, String) - Static method in class alluxio.table.common.CatalogPathUtils
 
getTablePathUdb(String, String, String) - Static method in class alluxio.table.common.CatalogPathUtils
 
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
 
getTableProperties() - Method in class alluxio.job.plan.transform.PartitionInfo
 
getTables() - Method in class alluxio.master.table.Database
 
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;
getTableStats(int) - Method in class alluxio.proto.journal.Table.AddTableEntry.Builder
repeated .alluxio.grpc.table.ColumnStatisticsInfo table_stats = 6;
getTableStats(int) - Method in class alluxio.proto.journal.Table.AddTableEntry
repeated .alluxio.grpc.table.ColumnStatisticsInfo table_stats = 6;
getTableStats(int) - Method in interface alluxio.proto.journal.Table.AddTableEntryOrBuilder
repeated .alluxio.grpc.table.ColumnStatisticsInfo table_stats = 6;
getTableStatsBuilder(int) - Method in class alluxio.proto.journal.Table.AddTableEntry.Builder
repeated .alluxio.grpc.table.ColumnStatisticsInfo table_stats = 6;
getTableStatsBuilderList() - Method in class alluxio.proto.journal.Table.AddTableEntry.Builder
repeated .alluxio.grpc.table.ColumnStatisticsInfo table_stats = 6;
getTableStatsCount() - Method in class alluxio.proto.journal.Table.AddTableEntry.Builder
repeated .alluxio.grpc.table.ColumnStatisticsInfo table_stats = 6;
getTableStatsCount() - Method in class alluxio.proto.journal.Table.AddTableEntry
repeated .alluxio.grpc.table.ColumnStatisticsInfo table_stats = 6;
getTableStatsCount() - Method in interface alluxio.proto.journal.Table.AddTableEntryOrBuilder
repeated .alluxio.grpc.table.ColumnStatisticsInfo table_stats = 6;
getTableStatsList() - Method in class alluxio.proto.journal.Table.AddTableEntry.Builder
repeated .alluxio.grpc.table.ColumnStatisticsInfo table_stats = 6;
getTableStatsList() - Method in class alluxio.proto.journal.Table.AddTableEntry
repeated .alluxio.grpc.table.ColumnStatisticsInfo table_stats = 6;
getTableStatsList() - Method in interface alluxio.proto.journal.Table.AddTableEntryOrBuilder
repeated .alluxio.grpc.table.ColumnStatisticsInfo table_stats = 6;
getTableStatsOrBuilder(int) - Method in class alluxio.proto.journal.Table.AddTableEntry.Builder
repeated .alluxio.grpc.table.ColumnStatisticsInfo table_stats = 6;
getTableStatsOrBuilder(int) - Method in class alluxio.proto.journal.Table.AddTableEntry
repeated .alluxio.grpc.table.ColumnStatisticsInfo table_stats = 6;
getTableStatsOrBuilder(int) - Method in interface alluxio.proto.journal.Table.AddTableEntryOrBuilder
repeated .alluxio.grpc.table.ColumnStatisticsInfo table_stats = 6;
getTableStatsOrBuilderList() - Method in class alluxio.proto.journal.Table.AddTableEntry.Builder
repeated .alluxio.grpc.table.ColumnStatisticsInfo table_stats = 6;
getTableStatsOrBuilderList() - Method in class alluxio.proto.journal.Table.AddTableEntry
repeated .alluxio.grpc.table.ColumnStatisticsInfo table_stats = 6;
getTableStatsOrBuilderList() - Method in interface alluxio.proto.journal.Table.AddTableEntryOrBuilder
repeated .alluxio.grpc.table.ColumnStatisticsInfo table_stats = 6;
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(Fingerprint.Tag) - Method in class alluxio.underfs.Fingerprint
 
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;
getTagUfsValueFromFullName(String) - Static method in class alluxio.metrics.Metric
Gets value of ufs tag from the full metric name.
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
 
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
 
getTempBlockMeta(long) - Method in class alluxio.worker.block.BlockMetadataManager
Gets the metadata of a temp block.
getTempBlockMeta(long, long) - Method in interface alluxio.worker.block.BlockStore
Gets the temp metadata of a specific block from local storage.
getTempBlockMeta(long) - Method in class alluxio.worker.block.meta.StorageDir
Gets the BlockMeta from this storage dir by its block id.
getTempBlockMeta(long, long) - Method in class alluxio.worker.block.TieredBlockStore
 
getTempBlockMetaOrNull(long) - Method in class alluxio.worker.block.BlockMetadataManager
Gets the metadata of a temp block.
getTempBlockWriterRemote(long, long) - Method in interface alluxio.worker.block.BlockWorker
Opens a BlockWriter for an existing temporary block for non short-circuit writes or cache requests.
getTempBlockWriterRemote(long, long) - Method in class alluxio.worker.block.DefaultBlockWorker
 
getTemporaryCheckpoints() - Method in class alluxio.master.journal.ufs.UfsJournalSnapshot
 
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;
getTempUrlPrefix(TempUrlHashPrefixSource) - Method in class alluxio.underfs.swift.KeystoneV3Access
 
getThis() - Method in class alluxio.master.file.contexts.CreateDirectoryContext
 
getThis() - Method in class alluxio.master.file.contexts.CreateFileContext
 
getThis() - Method in class alluxio.master.file.contexts.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
 
getThreadIdentifier(Thread) - Static method in class alluxio.util.ThreadUtils
 
getThreadName() - Method in class alluxio.heartbeat.ScheduledTimer
 
getThreadNames() - Static method in class alluxio.heartbeat.HeartbeatScheduler
 
getTier() - Method in class alluxio.grpc.CreateLocalBlockRequest.Builder
optional int32 tier = 3;
getTier() - Method in class alluxio.grpc.CreateLocalBlockRequest
optional int32 tier = 3;
getTier() - Method in interface alluxio.grpc.CreateLocalBlockRequestOrBuilder
optional int32 tier = 3;
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.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(int) - Method in class alluxio.wire.TieredIdentity
 
getTier(String) - Method in class alluxio.worker.block.BlockMetadataManager
Gets the StorageTier given its tierAlias.
getTier() - Method in class alluxio.worker.grpc.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 class 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
 
getTieredIdentity() - Method in class alluxio.grpc.WorkerNetAddress.Builder
optional .alluxio.grpc.TieredIdentity tieredIdentity = 6;
getTieredIdentity() - Method in class alluxio.grpc.WorkerNetAddress
optional .alluxio.grpc.TieredIdentity tieredIdentity = 6;
getTieredIdentity() - Method in interface alluxio.grpc.WorkerNetAddressOrBuilder
optional .alluxio.grpc.TieredIdentity tieredIdentity = 6;
getTieredIdentity() - Method in class alluxio.wire.WorkerNetAddress
 
getTieredIdentityBuilder() - Method in class alluxio.grpc.WorkerNetAddress.Builder
optional .alluxio.grpc.TieredIdentity tieredIdentity = 6;
getTieredIdentityOrBuilder() - Method in class alluxio.grpc.WorkerNetAddress.Builder
optional .alluxio.grpc.TieredIdentity tieredIdentity = 6;
getTieredIdentityOrBuilder() - Method in class alluxio.grpc.WorkerNetAddress
optional .alluxio.grpc.TieredIdentity tieredIdentity = 6;
getTieredIdentityOrBuilder() - Method in interface alluxio.grpc.WorkerNetAddressOrBuilder
optional .alluxio.grpc.TieredIdentity tieredIdentity = 6;
getTierName() - Method in class alluxio.grpc.LocalityTier.Builder
optional string tierName = 1;
getTierName() - Method in class alluxio.grpc.LocalityTier
optional string tierName = 1;
getTierName() - Method in interface alluxio.grpc.LocalityTierOrBuilder
optional string tierName = 1;
getTierName() - Method in class alluxio.wire.TieredIdentity.LocalityTier
 
getTierNameBytes() - Method in class alluxio.grpc.LocalityTier.Builder
optional string tierName = 1;
getTierNameBytes() - Method in class alluxio.grpc.LocalityTier
optional string tierName = 1;
getTierNameBytes() - Method in interface alluxio.grpc.LocalityTierOrBuilder
optional string tierName = 1;
getTierOrdinal() - Method in class alluxio.worker.block.meta.StorageTier
 
getTierPaths() - Method in class alluxio.wire.AlluxioWorkerInfo
 
getTiers(int) - Method in class alluxio.grpc.TieredIdentity.Builder
repeated .alluxio.grpc.LocalityTier tiers = 1;
getTiers(int) - Method in class alluxio.grpc.TieredIdentity
repeated .alluxio.grpc.LocalityTier tiers = 1;
getTiers(int) - Method in interface alluxio.grpc.TieredIdentityOrBuilder
repeated .alluxio.grpc.LocalityTier tiers = 1;
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;
getTiers() - Method in class alluxio.wire.TieredIdentity
 
getTiers() - Method in class alluxio.worker.block.BlockMetadataManager
Gets the list of StorageTier managed.
getTiersBelow(String) - Method in class alluxio.worker.block.BlockMetadataManager
Gets the list of StorageTier below the tier with the given tierAlias.
getTiersBuilder(int) - Method in class alluxio.grpc.TieredIdentity.Builder
repeated .alluxio.grpc.LocalityTier tiers = 1;
getTiersBuilderList() - Method in class alluxio.grpc.TieredIdentity.Builder
repeated .alluxio.grpc.LocalityTier tiers = 1;
getTiersCount() - Method in class alluxio.grpc.TieredIdentity.Builder
repeated .alluxio.grpc.LocalityTier tiers = 1;
getTiersCount() - Method in class alluxio.grpc.TieredIdentity
repeated .alluxio.grpc.LocalityTier tiers = 1;
getTiersCount() - Method in interface alluxio.grpc.TieredIdentityOrBuilder
repeated .alluxio.grpc.LocalityTier 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.TieredIdentity.Builder
repeated .alluxio.grpc.LocalityTier tiers = 1;
getTiersList() - Method in class alluxio.grpc.TieredIdentity
repeated .alluxio.grpc.LocalityTier tiers = 1;
getTiersList() - Method in interface alluxio.grpc.TieredIdentityOrBuilder
repeated .alluxio.grpc.LocalityTier 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;
getTiersOrBuilder(int) - Method in class alluxio.grpc.TieredIdentity.Builder
repeated .alluxio.grpc.LocalityTier tiers = 1;
getTiersOrBuilder(int) - Method in class alluxio.grpc.TieredIdentity
repeated .alluxio.grpc.LocalityTier tiers = 1;
getTiersOrBuilder(int) - Method in interface alluxio.grpc.TieredIdentityOrBuilder
repeated .alluxio.grpc.LocalityTier tiers = 1;
getTiersOrBuilderList() - Method in class alluxio.grpc.TieredIdentity.Builder
repeated .alluxio.grpc.LocalityTier tiers = 1;
getTiersOrBuilderList() - Method in class alluxio.grpc.TieredIdentity
repeated .alluxio.grpc.LocalityTier tiers = 1;
getTiersOrBuilderList() - Method in interface alluxio.grpc.TieredIdentityOrBuilder
repeated .alluxio.grpc.LocalityTier tiers = 1;
getTierView(String) - Method in class alluxio.worker.block.BlockMetadataView
Provides StorageTierView given tierAlias.
getTierViewAlias() - Method in class alluxio.worker.block.meta.StorageTierView
 
getTierViewOrdinal() - Method in class alluxio.worker.block.meta.StorageTierView
 
getTierViews() - Method in class alluxio.worker.block.BlockMetadataView
Gets all tierViews under this storage metadata view.
getTierViewsBelow(String) - Method in class alluxio.worker.block.BlockMetadataView
Gets all tierViews before certain tierView.
getTimedOutSessions() - Method in class alluxio.Sessions
Gets the sessions that timed out.
getTimeoutMs() - Method in class alluxio.util.WaitForOptions
 
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
 
getTmpDir(List<String>) - Static method in class alluxio.util.CommonUtils
 
getTo(int) - Method in class alluxio.underfs.swift.MidPartLongRange
 
getToBePersistedIds() - Method in class alluxio.master.file.meta.InodeTree
 
getToBePersistedIds() - Method in class alluxio.master.file.meta.InodeTreePersistentState
 
getToken() - Method in class alluxio.underfs.swift.KeystoneV3Access
 
getToRemoveBlocks() - Method in class alluxio.master.block.meta.MasterWorkerInfo
 
getTotal() - Method in class alluxio.wire.Capacity
 
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.
getTotalBytesReadLocal() - Method in class alluxio.wire.MasterWebUIMetrics
Gets total bytes read local.
getTotalBytesReadLocalThroughput() - Method in class alluxio.wire.MasterWebUIMetrics
Gets total bytes read local throughput.
getTotalBytesReadRemote() - Method in class alluxio.wire.MasterWebUIMetrics
Gets total bytes read remote.
getTotalBytesReadRemoteThroughput() - Method in class alluxio.wire.MasterWebUIMetrics
Gets total bytes read remote throughput.
getTotalBytesReadUfs() - Method in class alluxio.wire.MasterWebUIMetrics
Gets total bytes read ufs.
getTotalBytesReadUfsThroughput() - Method in class alluxio.wire.MasterWebUIMetrics
Gets total bytes read ufs throughput.
getTotalBytesWrittenAlluxio() - Method in class alluxio.wire.MasterWebUIMetrics
Gets total bytes written alluxio.
getTotalBytesWrittenAlluxioThroughput() - Method in class alluxio.wire.MasterWebUIMetrics
Gets total bytes written alluxio throughput.
getTotalBytesWrittenDomainSocket() - Method in class alluxio.wire.MasterWebUIMetrics
Gets total bytes written through domain socket.
getTotalBytesWrittenDomainSocketThroughput() - Method in class alluxio.wire.MasterWebUIMetrics
Gets total bytes written through domain socket throughput.
getTotalBytesWrittenLocal() - Method in class alluxio.wire.MasterWebUIMetrics
Gets total bytes written local.
getTotalBytesWrittenLocalThroughput() - Method in class alluxio.wire.MasterWebUIMetrics
Gets total bytes written local throughput.
getTotalBytesWrittenUfs() - Method in class alluxio.wire.MasterWebUIMetrics
Gets total bytes written ufs.
getTotalBytesWrittenUfsThroughput() - Method in class alluxio.wire.MasterWebUIMetrics
Gets total bytes written ufs throughput.
getTotalExtraTime() - Method in class alluxio.util.JvmPauseMonitor
 
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.
getTransformedLayout() - Method in class alluxio.table.common.transform.TransformPlan
 
getTransformedLayouts() - Method in class alluxio.master.table.transform.TransformJobInfo
 
getTransformedLayouts() - Method in class alluxio.proto.journal.Table.AddTransformJobInfoEntry.Builder
Deprecated.
getTransformedLayouts() - Method in class alluxio.proto.journal.Table.AddTransformJobInfoEntry
Deprecated.
getTransformedLayouts() - Method in interface alluxio.proto.journal.Table.AddTransformJobInfoEntryOrBuilder
Deprecated.
getTransformedLayouts() - Method in class alluxio.proto.journal.Table.CompleteTransformTableEntry.Builder
Deprecated.
getTransformedLayouts() - Method in class alluxio.proto.journal.Table.CompleteTransformTableEntry
Deprecated.
getTransformedLayouts() - Method in interface alluxio.proto.journal.Table.CompleteTransformTableEntryOrBuilder
Deprecated.
getTransformedLayoutsCount() - Method in class alluxio.proto.journal.Table.AddTransformJobInfoEntry.Builder
 
getTransformedLayoutsCount() - Method in class alluxio.proto.journal.Table.AddTransformJobInfoEntry
 
getTransformedLayoutsCount() - Method in interface alluxio.proto.journal.Table.AddTransformJobInfoEntryOrBuilder
map<string, .alluxio.grpc.table.Layout> transformed_layouts = 5;
getTransformedLayoutsCount() - Method in class alluxio.proto.journal.Table.CompleteTransformTableEntry.Builder
 
getTransformedLayoutsCount() - Method in class alluxio.proto.journal.Table.CompleteTransformTableEntry
 
getTransformedLayoutsCount() - Method in interface alluxio.proto.journal.Table.CompleteTransformTableEntryOrBuilder
Map from partition spec to transformed layout
getTransformedLayoutsMap() - Method in class alluxio.proto.journal.Table.AddTransformJobInfoEntry.Builder
map<string, .alluxio.grpc.table.Layout> transformed_layouts = 5;
getTransformedLayoutsMap() - Method in class alluxio.proto.journal.Table.AddTransformJobInfoEntry
map<string, .alluxio.grpc.table.Layout> transformed_layouts = 5;
getTransformedLayoutsMap() - Method in interface alluxio.proto.journal.Table.AddTransformJobInfoEntryOrBuilder
map<string, .alluxio.grpc.table.Layout> transformed_layouts = 5;
getTransformedLayoutsMap() - Method in class alluxio.proto.journal.Table.CompleteTransformTableEntry.Builder
Map from partition spec to transformed layout
getTransformedLayoutsMap() - Method in class alluxio.proto.journal.Table.CompleteTransformTableEntry
Map from partition spec to transformed layout
getTransformedLayoutsMap() - Method in interface alluxio.proto.journal.Table.CompleteTransformTableEntryOrBuilder
Map from partition spec to transformed layout
getTransformedLayoutsOrDefault(String, Layout) - Method in class alluxio.proto.journal.Table.AddTransformJobInfoEntry.Builder
map<string, .alluxio.grpc.table.Layout> transformed_layouts = 5;
getTransformedLayoutsOrDefault(String, Layout) - Method in class alluxio.proto.journal.Table.AddTransformJobInfoEntry
map<string, .alluxio.grpc.table.Layout> transformed_layouts = 5;
getTransformedLayoutsOrDefault(String, Layout) - Method in interface alluxio.proto.journal.Table.AddTransformJobInfoEntryOrBuilder
map<string, .alluxio.grpc.table.Layout> transformed_layouts = 5;
getTransformedLayoutsOrDefault(String, Layout) - Method in class alluxio.proto.journal.Table.CompleteTransformTableEntry.Builder
Map from partition spec to transformed layout
getTransformedLayoutsOrDefault(String, Layout) - Method in class alluxio.proto.journal.Table.CompleteTransformTableEntry
Map from partition spec to transformed layout
getTransformedLayoutsOrDefault(String, Layout) - Method in interface alluxio.proto.journal.Table.CompleteTransformTableEntryOrBuilder
Map from partition spec to transformed layout
getTransformedLayoutsOrThrow(String) - Method in class alluxio.proto.journal.Table.AddTransformJobInfoEntry.Builder
map<string, .alluxio.grpc.table.Layout> transformed_layouts = 5;
getTransformedLayoutsOrThrow(String) - Method in class alluxio.proto.journal.Table.AddTransformJobInfoEntry
map<string, .alluxio.grpc.table.Layout> transformed_layouts = 5;
getTransformedLayoutsOrThrow(String) - Method in interface alluxio.proto.journal.Table.AddTransformJobInfoEntryOrBuilder
map<string, .alluxio.grpc.table.Layout> transformed_layouts = 5;
getTransformedLayoutsOrThrow(String) - Method in class alluxio.proto.journal.Table.CompleteTransformTableEntry.Builder
Map from partition spec to transformed layout
getTransformedLayoutsOrThrow(String) - Method in class alluxio.proto.journal.Table.CompleteTransformTableEntry
Map from partition spec to transformed layout
getTransformedLayoutsOrThrow(String) - Method in interface alluxio.proto.journal.Table.CompleteTransformTableEntryOrBuilder
Map from partition spec to transformed layout
getTransformJobInfo(long) - Method in class alluxio.client.table.RetryHandlingTableMasterClient
 
getTransformJobInfo(long) - Method in interface alluxio.client.table.TableMasterClient
 
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.TableMasterClientServiceImplBase
Gets information of transformation jobs.
getTransformJobInfo(GetTransformJobInfoPRequest, StreamObserver<GetTransformJobInfoPResponse>) - Method in class alluxio.grpc.table.TableMasterClientServiceGrpc.TableMasterClientServiceStub
Gets information of transformation jobs.
getTransformJobInfo(long) - Method in class alluxio.master.table.DefaultTableMaster
 
getTransformJobInfo(long) - Method in interface alluxio.master.table.TableMaster
 
getTransformJobInfo(GetTransformJobInfoPRequest, StreamObserver<GetTransformJobInfoPResponse>) - Method in class alluxio.master.table.TableMasterClientServiceHandler
 
getTransformJobInfo(long) - Method in class alluxio.master.table.transform.TransformManager
 
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
 
getTransformPlan(String, String, TransformDefinition) - Method in class alluxio.master.table.AlluxioCatalog
 
getTransformPlan(TransformContext, TransformDefinition) - Method in class alluxio.master.table.Partition
Returns a plan to transform this partition.
getTransformPlan(TransformContext, TransformDefinition) - Method in interface alluxio.table.common.Layout
 
getTransformPlan(TransformContext, TransformDefinition) - Method in class alluxio.table.common.layout.HiveLayout
 
getTransformPlans(TransformDefinition) - Method in class alluxio.master.table.Table
Returns a list of plans to transform the table, according to the transformation definition.
getTransformTableMethod() - Static method in class alluxio.grpc.table.TableMasterClientServiceGrpc
 
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
 
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
 
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;
getTxId() - Method in class alluxio.SyncInfo
returns the transaction id that is synced in this sync period.
getType() - Method in class alluxio.client.file.cache.store.LocalPageStoreOptions
 
getType() - Method in class alluxio.client.file.cache.store.PageStoreOptions
 
getType() - Method in class alluxio.client.file.cache.store.RocksPageStoreOptions
 
getType() - Method in class alluxio.conf.Source
 
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.plan.transform.FieldSchema
 
getType() - Method in class alluxio.master.journal.checkpoint.CheckpointInputStream
 
getType() - Method in class alluxio.master.table.Database
 
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 interface alluxio.table.common.Layout
 
getType() - Method in class alluxio.table.common.layout.HiveLayout
 
getType() - Method in class alluxio.table.common.layout.HiveLayout.HiveLayoutFactory
 
getType() - Method in interface alluxio.table.common.LayoutFactory
 
getType() - Method in interface alluxio.table.common.udb.UnderDatabase
 
getType() - Method in interface alluxio.table.common.udb.UnderDatabaseFactory
 
getType() - Method in class alluxio.table.under.hive.HiveDatabase
 
getType() - Method in class alluxio.table.under.hive.HiveDatabaseFactory
 
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;
getUdb() - Method in class alluxio.master.table.Database
 
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;
getUdbConnectionUri() - Method in class alluxio.proto.journal.Table.AttachDbEntry.Builder
optional string udb_connection_uri = 2;
getUdbConnectionUri() - Method in class alluxio.proto.journal.Table.AttachDbEntry
optional string udb_connection_uri = 2;
getUdbConnectionUri() - Method in interface alluxio.proto.journal.Table.AttachDbEntryOrBuilder
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;
getUdbConnectionUriBytes() - Method in class alluxio.proto.journal.Table.AttachDbEntry.Builder
optional string udb_connection_uri = 2;
getUdbConnectionUriBytes() - Method in class alluxio.proto.journal.Table.AttachDbEntry
optional string udb_connection_uri = 2;
getUdbConnectionUriBytes() - Method in interface alluxio.proto.journal.Table.AttachDbEntryOrBuilder
optional string udb_connection_uri = 2;
getUdbContext() - Method in interface alluxio.table.common.udb.UnderDatabase
 
getUdbContext() - Method in class alluxio.table.under.hive.HiveDatabase
 
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;
getUdbDbName() - Method in class alluxio.proto.journal.Table.AttachDbEntry.Builder
optional string udb_db_name = 3;
getUdbDbName() - Method in class alluxio.proto.journal.Table.AttachDbEntry
optional string udb_db_name = 3;
getUdbDbName() - Method in interface alluxio.proto.journal.Table.AttachDbEntryOrBuilder
optional string udb_db_name = 3;
getUdbDbName() - Method in class alluxio.table.common.udb.UdbContext
 
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;
getUdbDbNameBytes() - Method in class alluxio.proto.journal.Table.AttachDbEntry.Builder
optional string udb_db_name = 3;
getUdbDbNameBytes() - Method in class alluxio.proto.journal.Table.AttachDbEntry
optional string udb_db_name = 3;
getUdbDbNameBytes() - Method in interface alluxio.proto.journal.Table.AttachDbEntryOrBuilder
optional string udb_db_name = 3;
getUdbPrefix(String) - Static method in class alluxio.table.common.ConfigurationUtils
 
getUdbRegistry() - Method in class alluxio.master.table.CatalogContext
 
getUdbRegistry() - Method in class alluxio.table.common.udb.UdbContext
 
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;
getUdbType() - Method in class alluxio.proto.journal.Table.AttachDbEntry.Builder
optional string udb_type = 1;
getUdbType() - Method in class alluxio.proto.journal.Table.AttachDbEntry
optional string udb_type = 1;
getUdbType() - Method in interface alluxio.proto.journal.Table.AttachDbEntryOrBuilder
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;
getUdbTypeBytes() - Method in class alluxio.proto.journal.Table.AttachDbEntry.Builder
optional string udb_type = 1;
getUdbTypeBytes() - Method in class alluxio.proto.journal.Table.AttachDbEntry
optional string udb_type = 1;
getUdbTypeBytes() - Method in interface alluxio.proto.journal.Table.AttachDbEntryOrBuilder
optional string udb_type = 1;
getUfsAddress() - Method in class alluxio.master.file.DefaultFileSystemMaster
 
getUfsAddress() - Method in interface alluxio.master.file.FileSystemMaster
 
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.master.meta.AlluxioMasterRestServiceHandler
Deprecated.
since version 1.4 and will be removed in version 2.0
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.
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;
getUfsFreeBytes() - Method in class alluxio.master.meta.AlluxioMasterRestServiceHandler
Deprecated.
since version 1.4 and will be removed in version 2.0
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.FileSystemMasterJobServiceImplBase
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) - 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.FileSystemMasterWorkerServiceImplBase
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
 
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.CoreMasterContext
 
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.underfs.UfsManager.UfsClient
 
getUfsMountPointUri() - Method in class alluxio.worker.block.UnderFileSystemBlockReader
 
getUfsOps() - Method in class alluxio.wire.MasterWebUIMetrics
Gets ufs ops.
getUfsPath() - Method in class alluxio.client.file.options.OutStreamOptions
 
getUfsPath() - Method in class alluxio.client.file.URIStatus
 
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 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.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.BlockWriteRequestContext
 
getUfsPath() - Method in class alluxio.worker.grpc.UfsFileWriteRequest
 
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 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;
getUfsReadLocationPolicy() - Method in class alluxio.client.file.options.InStreamOptions
 
getUfsReadSize() - Method in class alluxio.wire.MasterWebUIMetrics
Gets ufs read size.
getUfsResource() - Method in class alluxio.worker.grpc.BlockWriteRequestContext
 
getUfsResource() - Method in class alluxio.worker.grpc.UfsFileWriteRequestContext
 
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
 
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;
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.wire.MountPointInfo
 
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.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.wire.MountPointInfo
 
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.master.meta.AlluxioMasterRestServiceHandler
Deprecated.
since version 1.4 and will be removed in version 2.0
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.
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.
getUnderFileSystemPath() - Method in class alluxio.worker.block.meta.UnderFileSystemBlockMeta
 
getUnderFSType() - Method in class alluxio.concurrent.ManagedBlockingUfsForwarder
 
getUnderFSType() - Method in class alluxio.underfs.cos.COSUnderFileSystem
 
getUnderFSType() - Method in class alluxio.underfs.gcs.GCSUnderFileSystem
 
getUnderFSType() - Method in class alluxio.underfs.hdfs.HdfsUnderFileSystem
 
getUnderFSType() - Method in class alluxio.underfs.kodo.KodoUnderFileSystem
 
getUnderFSType() - Method in class alluxio.underfs.local.LocalUnderFileSystem
 
getUnderFSType() - Method in class alluxio.underfs.oss.OSSUnderFileSystem
 
getUnderFSType() - Method in class alluxio.underfs.s3a.S3AUnderFileSystem
 
getUnderFSType() - Method in class alluxio.underfs.swift.SwiftUnderFileSystem
 
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
 
getUnderFSType() - Method in class alluxio.underfs.web.WebUnderFileSystem
 
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
 
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.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.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.BlockStoreLocationProto
 
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.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.Command
 
getUnknownFields() - Method in class alluxio.grpc.CommitBlockInUfsPOptions
 
getUnknownFields() - Method in class alluxio.grpc.CommitBlockInUfsPRequest
 
getUnknownFields() - Method in class alluxio.grpc.CommitBlockInUfsPResponse
 
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.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.CreateLocalBlockRequest
 
getUnknownFields() - Method in class alluxio.grpc.CreateLocalBlockResponse
 
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.ExistsPOptions
 
getUnknownFields() - Method in class alluxio.grpc.FileBlockInfo
 
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.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.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.GetJobServiceSummaryPOptions
 
getUnknownFields() - Method in class alluxio.grpc.GetJobServiceSummaryPRequest
 
getUnknownFields() - Method in class alluxio.grpc.GetJobServiceSummaryPResponse
 
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.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.GetPinnedFileIdsPOptions
 
getUnknownFields() - Method in class alluxio.grpc.GetPinnedFileIdsPRequest
 
getUnknownFields() - Method in class alluxio.grpc.GetPinnedFileIdsPResponse
 
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.GetServiceVersionPRequest
 
getUnknownFields() - Method in class alluxio.grpc.GetServiceVersionPResponse
 
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.GetSyncPathListPRequest
 
getUnknownFields() - Method in class alluxio.grpc.GetSyncPathListPResponse
 
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.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.JobServiceSummary
 
getUnknownFields() - Method in class alluxio.grpc.JobUnused
 
getUnknownFields() - Method in class alluxio.grpc.JobWorkerHealth
 
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.ListStatusPOptions
 
getUnknownFields() - Method in class alluxio.grpc.ListStatusPRequest
 
getUnknownFields() - Method in class alluxio.grpc.ListStatusPResponse
 
getUnknownFields() - Method in class alluxio.grpc.LoadMetadataPOptions
 
getUnknownFields() - Method in class alluxio.grpc.LocalityTier
 
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.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.NetAddress
 
getUnknownFields() - Method in class alluxio.grpc.OpenFilePOptions
 
getUnknownFields() - Method in class alluxio.grpc.OpenLocalBlockRequest
 
getUnknownFields() - Method in class alluxio.grpc.OpenLocalBlockResponse
 
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.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.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.RemovePathConfigurationPOptions
 
getUnknownFields() - Method in class alluxio.grpc.RemovePathConfigurationPRequest
 
getUnknownFields() - Method in class alluxio.grpc.RemovePathConfigurationPResponse
 
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.ReverseResolvePRequest
 
getUnknownFields() - Method in class alluxio.grpc.ReverseResolvePResponse
 
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.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.StartSyncPOptions
 
getUnknownFields() - Method in class alluxio.grpc.StartSyncPRequest
 
getUnknownFields() - Method in class alluxio.grpc.StartSyncPResponse
 
getUnknownFields() - Method in class alluxio.grpc.StatusSummary
 
getUnknownFields() - Method in class alluxio.grpc.StopSyncPOptions
 
getUnknownFields() - Method in class alluxio.grpc.StopSyncPRequest
 
getUnknownFields() - Method in class alluxio.grpc.StopSyncPResponse
 
getUnknownFields() - Method in class alluxio.grpc.StorageList
 
getUnknownFields() - Method in class alluxio.grpc.SyncPointInfo
 
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.TieredIdentity
 
getUnknownFields() - Method in class alluxio.grpc.TierList
 
getUnknownFields() - Method in class alluxio.grpc.TransportMessage
 
getUnknownFields() - Method in class alluxio.grpc.UfsInfo
 
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.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.WorkerInfo
 
getUnknownFields() - Method in class alluxio.grpc.WorkerLostStorageInfo
 
getUnknownFields() - Method in class alluxio.grpc.WorkerNetAddress
 
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.CreateUfsBlockOptions
 
getUnknownFields() - Method in class alluxio.proto.dataserver.Protocol.CreateUfsFileOptions
 
getUnknownFields() - Method in class alluxio.proto.dataserver.Protocol.OpenUfsBlockOptions
 
getUnknownFields() - Method in class alluxio.proto.dataserver.Protocol.Response
 
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.Journal.JournalEntry
 
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.Table.AddTableEntry
 
getUnknownFields() - Method in class alluxio.proto.journal.Table.AddTransformJobInfoEntry
 
getUnknownFields() - Method in class alluxio.proto.journal.Table.AttachDbEntry
 
getUnknownFields() - Method in class alluxio.proto.journal.Table.CompleteTransformTableEntry
 
getUnknownFields() - Method in class alluxio.proto.journal.Table.DetachDbEntry
 
getUnknownFields() - Method in class alluxio.proto.journal.Table.RemoveTableEntry
 
getUnknownFields() - Method in class alluxio.proto.journal.Table.RemoveTransformJobInfoEntry
 
getUnknownFields() - Method in class alluxio.proto.journal.Table.UpdateDatabaseInfoEntry
 
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.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
 
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
getUpdateDatabaseInfo() - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
optional .alluxio.proto.journal.UpdateDatabaseInfoEntry update_database_info = 49;
getUpdateDatabaseInfo() - Method in class alluxio.proto.journal.Journal.JournalEntry
optional .alluxio.proto.journal.UpdateDatabaseInfoEntry update_database_info = 49;
getUpdateDatabaseInfo() - Method in interface alluxio.proto.journal.Journal.JournalEntryOrBuilder
optional .alluxio.proto.journal.UpdateDatabaseInfoEntry update_database_info = 49;
getUpdateDatabaseInfoBuilder() - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
optional .alluxio.proto.journal.UpdateDatabaseInfoEntry update_database_info = 49;
getUpdateDatabaseInfoOrBuilder() - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
optional .alluxio.proto.journal.UpdateDatabaseInfoEntry update_database_info = 49;
getUpdateDatabaseInfoOrBuilder() - Method in class alluxio.proto.journal.Journal.JournalEntry
optional .alluxio.proto.journal.UpdateDatabaseInfoEntry update_database_info = 49;
getUpdateDatabaseInfoOrBuilder() - Method in interface alluxio.proto.journal.Journal.JournalEntryOrBuilder
optional .alluxio.proto.journal.UpdateDatabaseInfoEntry update_database_info = 49;
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.ListPartsResult
 
getUploadPath() - Method in class alluxio.underfs.s3a.S3AOutputStream
 
getUptime() - Method in class alluxio.util.webui.UIWorkerInfo
Gets uptime.
getUptime() - Method in class alluxio.wire.MasterWebUIOverview
Gets uptime.
getUptimeClockTime() - Method in class alluxio.util.webui.NodeInfo
Gets uptime clock time.
getUpTimeMs() - Method in class alluxio.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.AlluxioMasterRestServiceHandler
Deprecated.
since version 1.4 and will be removed in version 2.0
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 class alluxio.worker.AlluxioWorkerRestServiceHandler
Deprecated.
since version 1.4 and will be removed in version 2.0
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;
getUriDefaultPort() - Method in class alluxio.hadoop.AlluxioFileSystem
 
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.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.CheckConsistencyCommand
 
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.CopyFromLocalCommand
 
getUsage() - Method in class alluxio.cli.fs.command.CopyToLocalCommand
 
getUsage() - Method in class alluxio.cli.fs.command.CountCommand
 
getUsage() - Method in class alluxio.cli.fs.command.CpCommand
 
getUsage() - Method in class alluxio.cli.fs.command.DistributedCpCommand
 
getUsage() - Method in class alluxio.cli.fs.command.DistributedLoadCommand
 
getUsage() - Method in class alluxio.cli.fs.command.DistributedMvCommand
 
getUsage() - Method in class alluxio.cli.fs.command.DuCommand
 
getUsage() - Method in class alluxio.cli.fs.command.FreeCommand
 
getUsage() - Method in class alluxio.cli.fs.command.GetCapacityBytesCommand
 
getUsage() - Method in class alluxio.cli.fs.command.GetFaclCommand
 
getUsage() - Method in class alluxio.cli.fs.command.GetSyncPathListCommand
 
getUsage() - Method in class alluxio.cli.fs.command.GetUsedBytesCommand
 
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.LeaderCommand
 
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.MasterInfoCommand
 
getUsage() - Method in class alluxio.cli.fs.command.MkdirCommand
 
getUsage() - Method in class alluxio.cli.fs.command.MountCommand
 
getUsage() - Method in class alluxio.cli.fs.command.MvCommand
 
getUsage() - Method in class alluxio.cli.fs.command.PersistCommand
 
getUsage() - Method in class alluxio.cli.fs.command.PinCommand
 
getUsage() - Method in class alluxio.cli.fs.command.RmCommand
 
getUsage() - Method in class alluxio.cli.fs.command.SetFaclCommand
 
getUsage() - Method in class alluxio.cli.fs.command.SetReplicationCommand
 
getUsage() - Method in class alluxio.cli.fs.command.SetTtlCommand
 
getUsage() - Method in class alluxio.cli.fs.command.StartSyncCommand
 
getUsage() - Method in class alluxio.cli.fs.command.StatCommand
 
getUsage() - Method in class alluxio.cli.fs.command.StopSyncCommand
 
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.fs.command.UnmountCommand
 
getUsage() - Method in class alluxio.cli.fs.command.UnpinCommand
 
getUsage() - Method in class alluxio.cli.fs.command.UnsetTtlCommand
 
getUsage() - Method in class alluxio.cli.fs.command.UpdateMountCommand
 
getUsage() - Method in class alluxio.cli.fsadmin.command.BackupCommand
 
getUsage() - Method in class alluxio.cli.fsadmin.command.DoctorCommand
 
getUsage() - Method in class alluxio.cli.fsadmin.command.GetBlockInfoCommand
 
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.PathConfCommand
 
getUsage() - Method in class alluxio.cli.fsadmin.command.ReportCommand
 
getUsage() - Method in class alluxio.cli.fsadmin.command.UfsCommand
 
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.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.pathconf.AddCommand
 
getUsage() - Method in class alluxio.cli.fsadmin.pathconf.ListCommand
 
getUsage() - Method in class alluxio.cli.fsadmin.pathconf.RemoveCommand
 
getUsage() - Method in class alluxio.cli.fsadmin.pathconf.ShowCommand
 
getUsage() - Static method in class alluxio.cli.fsadmin.report.CapacityCommand
 
getUsage() - Method in class alluxio.cli.job.command.CancelCommand
 
getUsage() - Method in class alluxio.cli.job.command.LeaderCommand
 
getUsage() - Method in class alluxio.cli.job.command.ListCommand
 
getUsage() - Method in class alluxio.cli.job.command.StatCommand
 
getUsage() - Method in class alluxio.cli.table.command.AttachDatabaseCommand
 
getUsage() - Method in class alluxio.cli.table.command.DetachDatabaseCommand
 
getUsage() - Method in class alluxio.cli.table.command.ListDatabasesCommand
 
getUsage() - Method in class alluxio.cli.table.command.SyncDatabaseCommand
 
getUsage() - Method in class alluxio.cli.table.command.TransformStatusCommand
 
getUsage() - Method in class alluxio.cli.table.command.TransformTableCommand
 
getUsageCount() - Method in class alluxio.worker.block.io.LocalFileBlockReader
 
getUsageOnTiers() - Method in class alluxio.wire.WorkerWebUIOverview
Gets usage on tiers.
getUsed() - Method in class alluxio.wire.Capacity
 
getUsedBytes() - Method in class alluxio.client.block.AlluxioBlockStore
Gets the used bytes of Alluxio's BlockStore.
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.BlockWorkerInfo
 
getUsedBytes() - Method in class alluxio.client.block.RetryHandlingBlockMasterClient
Gets the total amount of used space in bytes, on all the tiers of all the workers.
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.BlockMasterClientServiceImplBase
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.master.meta.AlluxioMasterRestServiceHandler
Deprecated.
since version 1.4 and will be removed in version 2.0
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.WorkerInfo
 
getUsedBytes() - Method in class alluxio.wire.WorkerWebUIOverview
Gets used bytes.
getUsedBytes() - Method in class alluxio.worker.AlluxioWorkerRestServiceHandler
Deprecated.
since version 1.4 and will be removed in version 2.0
getUsedBytes() - Method in interface alluxio.worker.block.BlockStoreMeta
 
getUsedBytes() - Method in class alluxio.worker.block.DefaultBlockStoreMeta
 
GetUsedBytesCommand - Class in alluxio.cli.fs.command
Gets number of bytes used in the FileSystem.
GetUsedBytesCommand(FileSystemContext) - Constructor for class alluxio.cli.fs.command.GetUsedBytesCommand
Constructs a new instance to get the number of bytes used in the FileSystem.
getUsedBytesOnDirs() - Method in interface alluxio.worker.block.BlockStoreMeta
 
getUsedBytesOnDirs() - Method in class alluxio.worker.block.DefaultBlockStoreMeta
 
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.master.meta.AlluxioMasterRestServiceHandler
Deprecated.
since version 1.4 and will be removed in version 2.0
getUsedBytesOnTiers() - Method in class alluxio.wire.BlockMasterInfo
 
getUsedBytesOnTiers() - Method in class alluxio.wire.WorkerInfo
 
getUsedBytesOnTiers() - Method in class alluxio.worker.AlluxioWorkerRestServiceHandler
Deprecated.
since version 1.4 and will be removed in version 2.0
getUsedBytesOnTiers() - Method in interface alluxio.worker.block.BlockStoreMeta
 
getUsedBytesOnTiers() - Method in class alluxio.worker.block.DefaultBlockStoreMeta
 
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.
getUsedMemory() - Method in class alluxio.util.webui.NodeInfo
Gets used memory.
getUsedSpacePercent() - Method in class alluxio.util.webui.NodeInfo
Gets used space percent.
getUsedSpacePercent() - Method in class alluxio.util.webui.StorageTierInfo
Gets used space percent.
getUser() - Method in class alluxio.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.security.user.BaseUserState
 
getUser() - Method in interface alluxio.security.user.UserState
Returns the User object for this user.
getUser() - Method in class alluxio.worker.block.meta.UnderFileSystemBlockMeta
 
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) - Static method in class alluxio.master.meta.UpdateCheck
 
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.
getUserChannel(AlluxioConfiguration) - Static method in class alluxio.util.network.NettyUtils
Gets the ChannelType properly from the USER_NETWORK_NETTY_CHANNEL property key.
getUserInfoForChannel(UUID) - Method in interface alluxio.security.authentication.AuthenticationServer
 
getUserInfoForChannel(UUID) - Method in class alluxio.security.authentication.DefaultAuthenticationServer
 
getUserName(long) - Static method in class alluxio.fuse.AlluxioFuseUtils
Gets the user name from the user id.
getUserState() - Method in class alluxio.ClientContext
 
getUserState() - Method in class alluxio.master.MasterContext
 
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.LocalityTier.Builder
optional string value = 2;
getValue() - Method in class alluxio.grpc.LocalityTier
optional string value = 2;
getValue() - Method in interface alluxio.grpc.LocalityTierOrBuilder
optional string value = 2;
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 enum alluxio.underfs.UnderFileSystem.SpaceType
 
getValue() - Method in class alluxio.util.executor.ControllableQueue.DelayNode
 
getValue() - Method in enum alluxio.wire.CommandType
 
getValue() - Method in enum alluxio.wire.LoadMetadataType
 
getValue() - Method in class alluxio.wire.Property
 
getValue() - Method in class alluxio.wire.TieredIdentity.LocalityTier
 
getValue() - Method in enum alluxio.worker.block.BlockLockType
 
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.grpc.LocalityTier.Builder
optional string value = 2;
getValueBytes() - Method in class alluxio.grpc.LocalityTier
optional string value = 2;
getValueBytes() - Method in interface alluxio.grpc.LocalityTierOrBuilder
optional string value = 2;
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;
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.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.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.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.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.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;
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.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.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.master.backcompat.Journal
 
getVersion() - Method in class alluxio.master.meta.AlluxioMasterRestServiceHandler
Deprecated.
since version 1.4 and will be removed in version 2.0
getVersion() - Method in class alluxio.master.table.Partition
 
getVersion() - Method in class alluxio.master.table.Table
 
getVersion() - Method in class alluxio.proto.journal.Table.AddTableEntry.Builder
optional int64 version = 11;
getVersion() - Method in class alluxio.proto.journal.Table.AddTableEntry
optional int64 version = 11;
getVersion() - Method in interface alluxio.proto.journal.Table.AddTableEntryOrBuilder
optional int64 version = 11;
getVersion() - Method in class alluxio.proto.journal.Table.RemoveTableEntry.Builder
optional int64 version = 4;
getVersion() - Method in class alluxio.proto.journal.Table.RemoveTableEntry
optional int64 version = 4;
getVersion() - Method in interface alluxio.proto.journal.Table.RemoveTableEntryOrBuilder
optional int64 version = 4;
getVersion() - Method in class alluxio.underfs.hdfs.HdfsUnderFileSystemFactory
 
getVersion() - Method in interface alluxio.underfs.UnderFileSystemFactory
Get the version supported by this factory.
getVersion() - Method in class alluxio.wire.AlluxioJobMasterInfo
 
getVersion() - Method in class alluxio.wire.AlluxioJobWorkerInfo
 
getVersion() - Method in class alluxio.wire.AlluxioMasterInfo
 
getVersion() - Method in class alluxio.wire.AlluxioProxyInfo
 
getVersion() - Method in class alluxio.wire.AlluxioWorkerInfo
 
getVersion() - Method in class alluxio.wire.MasterWebUIOverview
Gets version.
getVersion() - Method in class alluxio.wire.WorkerWebUIOverview
Gets version.
getVersion() - Method in class alluxio.worker.AlluxioWorkerRestServiceHandler
Deprecated.
since version 1.4 and will be removed in version 2.0
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;
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;
getVersionCreationTime() - Method in class alluxio.proto.journal.Table.AddTableEntry.Builder
optional int64 version_creation_time = 12;
getVersionCreationTime() - Method in class alluxio.proto.journal.Table.AddTableEntry
optional int64 version_creation_time = 12;
getVersionCreationTime() - Method in interface alluxio.proto.journal.Table.AddTableEntryOrBuilder
optional int64 version_creation_time = 12;
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 throws BlockDoesNotExistException.
getVolatileBlockMeta(long) - Method in interface alluxio.worker.block.BlockWorker
Gets the metadata of a block given its blockId or throws IOException.
getVolatileBlockMeta(long) - Method in class alluxio.worker.block.DefaultBlockWorker
 
getVolatileBlockMeta(long) - Method in class alluxio.worker.block.TieredBlockStore
 
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.AlluxioJobMasterProcess
 
getWebAddress() - Method in class alluxio.master.AlluxioMasterProcess
 
getWebAddress() - Method in class alluxio.master.MasterProcess
 
getWebAddress() - Method in class alluxio.worker.AlluxioJobWorkerProcess
 
getWebAddress() - Method in interface alluxio.worker.JobWorkerProcess
 
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.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
 
getWebUIBlockInfo(String, String, String) - Method in class alluxio.worker.AlluxioWorkerRestServiceHandler
Gets web ui block info page data.
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 ServerConfiguration 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.
getWebUIInit() - Method in class alluxio.worker.AlluxioWorkerRestServiceHandler
Gets Web UI initialization data.
getWebUILogs(String, String, String, String) - Method in class alluxio.master.meta.AlluxioMasterRestServiceHandler
Gets Web UI logs page data.
getWebUILogs(String, String, String, String) - Method in class alluxio.worker.AlluxioWorkerRestServiceHandler
Gets web ui logs page data.
getWebUIMetrics() - Method in class alluxio.master.meta.AlluxioMasterRestServiceHandler
Gets Web UI metrics page data.
getWebUIMetrics() - Method in class alluxio.worker.AlluxioWorkerRestServiceHandler
Gets web ui metrics page data.
getWebUIOverview() - Method in class alluxio.master.meta.AlluxioMasterRestServiceHandler
Gets Web UI overview page data.
getWebUIOverview() - Method in class alluxio.worker.AlluxioWorkerRestServiceHandler
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.
getWidthNano() - Method in class alluxio.job.util.TimeSeries
 
getWorker(GetWorkerOptions) - Method in interface alluxio.client.block.policy.BlockLocationPolicy
Gets the worker's network address for serving operations requested for the block.
getWorker(GetWorkerOptions) - Method in class alluxio.client.block.policy.DeterministicHashPolicy
 
getWorker(GetWorkerOptions) - Method in class alluxio.client.block.policy.LocalFirstAvoidEvictionPolicy
 
getWorker(GetWorkerOptions) - Method in class alluxio.client.block.policy.LocalFirstPolicy
 
getWorker(GetWorkerOptions) - Method in class alluxio.client.block.policy.MostAvailableFirstPolicy
 
getWorker(GetWorkerOptions) - Method in class alluxio.client.block.policy.RoundRobinPolicy
The policy uses the first fetch of worker info list as the base, and visits each of them in a round-robin manner in the subsequent calls.
getWorker(GetWorkerOptions) - Method in class alluxio.client.block.policy.SpecificHostPolicy
 
getWorker() - Method in class alluxio.master.LocalAlluxioJobCluster
 
getWorker(Class<T>) - Method in class alluxio.worker.AlluxioWorkerProcess
 
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
 
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
 
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;
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.
getWorkerCount() - Method in interface alluxio.master.block.BlockMaster
 
getWorkerCount() - Method in class alluxio.master.block.DefaultBlockMaster
 
getWorkerCount() - Method in class alluxio.master.meta.AlluxioMasterRestServiceHandler
Deprecated.
since version 1.4 and will be removed in version 2.0
getWorkerDataDirectory(String, AlluxioConfiguration) - Static method in class alluxio.util.CommonUtils
 
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;
getWorkerHostnames() - Static method in class alluxio.cli.extensions.ExtensionsShellUtils
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) - 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.BlockMasterWorkerServiceImplBase
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.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.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.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.block.BlockWorker
 
getWorkerId() - Method in class alluxio.worker.block.DefaultBlockWorker
 
getWorkerId() - Static method in class alluxio.worker.JobWorkerIdRegistry
 
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.wire.WorkerWebUIOverview
Gets worker info.
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) - 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.BlockMasterClientServiceImplBase
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
 
getWorkerInfoList() - Method in class alluxio.master.meta.AlluxioMasterRestServiceHandler
Deprecated.
since version 1.4 and will be removed in version 2.0
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;
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;
getWorkerLostStorage() - Method in interface alluxio.client.block.BlockMasterClient
 
getWorkerLostStorage() - Method in class alluxio.client.block.RetryHandlingBlockMasterClient
 
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.BlockMasterClientServiceImplBase
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() - 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.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;
getWorkerNetAddressBuilder() - Method in class alluxio.grpc.GetWorkerIdPRequest.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.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;
GetWorkerOptions - Class in alluxio.client.block.policy.options
getWorkerPort() - Method in class alluxio.wire.MasterWebUIInit
Gets worker port.
getWorkerProcess() - Method in class alluxio.master.LocalAlluxioCluster
 
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) - 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.BlockMasterClientServiceImplBase
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
 
getWorkers() - Method in class alluxio.master.block.meta.MasterBlockInfo
 
getWorkers() - Method in class alluxio.wire.AlluxioJobMasterInfo
 
getWorkers() - Method in class alluxio.wire.AlluxioMasterInfo
 
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
 
getWriteBufferSize() - Method in class alluxio.client.file.cache.store.RocksPageStoreOptions
 
getWriteHoldCount() - Method in class alluxio.concurrent.WeakSafeReentrantReadWriteLock
Queries the number of reentrant write holds on this lock by the current thread.
getWriter() - Method in interface alluxio.master.journalv0.MutableJournal
 
getWriter() - Method in class alluxio.master.journalv0.ufs.UfsMutableJournal
 
getWriteSchema() - Method in class alluxio.job.plan.transform.format.csv.CsvSchema
 
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.CreateDirectoryPOptions.Builder
optional .alluxio.grpc.file.WritePType writeType = 4;
getWriteType() - Method in class alluxio.grpc.CreateDirectoryPOptions
optional .alluxio.grpc.file.WritePType writeType = 4;
getWriteType() - Method in interface alluxio.grpc.CreateDirectoryPOptionsOrBuilder
optional .alluxio.grpc.file.WritePType writeType = 4;
getWriteType() - Method in class alluxio.grpc.CreateFilePOptions.Builder
optional .alluxio.grpc.file.WritePType writeType = 8;
getWriteType() - Method in class alluxio.grpc.CreateFilePOptions
optional .alluxio.grpc.file.WritePType writeType = 8;
getWriteType() - Method in interface alluxio.grpc.CreateFilePOptionsOrBuilder
optional .alluxio.grpc.file.WritePType writeType = 8;
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.FileInfo.Builder
Deprecated.
getXattr() - Method in class alluxio.grpc.FileInfo
Deprecated.
getXattr() - Method in interface alluxio.grpc.FileInfoOrBuilder
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
 
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.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.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.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.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.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.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.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.
getZkAddress() - Method in class alluxio.master.ZkMasterInquireClient.ZkMasterConnectDetails
 
getZone() - Method in class alluxio.clock.ElapsedTimeClock
 
getZone() - Method in class alluxio.clock.SystemClock
 
getZookeeperAddress() - Method in class alluxio.uri.ZookeeperAuthority
 
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 method in class alluxio.conf.ServerConfiguration
 
global() - Static method in class alluxio.security.user.ServerUserState
 
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.
GreedyAllocator - Class in alluxio.worker.block.allocator
A greedy allocator that returns the first Storage dir fitting the size of block to allocate.
GreedyAllocator(BlockMetadataView) - Constructor for class alluxio.worker.block.allocator.GreedyAllocator
Creates a new instance of GreedyAllocator.
GreedyEvictor - Class in alluxio.worker.block.evictor
A simple evictor that evicts arbitrary blocks until the required size is met.
GreedyEvictor(BlockMetadataEvictorView, Allocator) - Constructor for class alluxio.worker.block.evictor.GreedyEvictor
Creates a new instance of GreedyEvictor.
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.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.
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
An authenticated gRPC channel.
GrpcChannel(GrpcConnection, AuthenticatedChannelClientDriver) - Constructor for class alluxio.grpc.GrpcChannel
Create a new instance of GrpcChannel.
GrpcChannelBuilder - Class in alluxio.grpc
A gRPC channel builder that authenticates with GrpcServer at the target during channel building.
GrpcChannelKey - Class in alluxio.grpc
Used to identify a unique GrpcChannel.
GrpcChannelKey.IdentityField - Annotation Type in alluxio.grpc
 
GrpcConnection - Class in alluxio.grpc
Used to gather gRPC level resources and indexes together.
GrpcConnection(GrpcConnectionKey, ManagedChannel, AlluxioConfiguration) - Constructor for class alluxio.grpc.GrpcConnection
Creates a new connection object.
GrpcConnectionKey - Class in alluxio.grpc
Used to define a key for GrpcConnectionPool.
GrpcConnectionKey(GrpcChannelKey, int) - Constructor for class alluxio.grpc.GrpcConnectionKey
Creates a new gRPC connection key.
GrpcConnectionPool - Class in alluxio.grpc
Used to provide gRPC level connection management and pooling facilities.
GrpcConnectionPool() - Constructor for class alluxio.grpc.GrpcConnectionPool
Creates a new GrpcConnectionPool.
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, WorkerProcess) - 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
 
GrpcMessagingClient - Class in alluxio.master.transport
Client implementation based on Alluxio gRPC messaging.
GrpcMessagingClient(AlluxioConfiguration, UserState, ExecutorService, String) - 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(ThreadContext, ExecutorService, GrpcChannel, long) - Constructor for class alluxio.master.transport.GrpcMessagingClientConnection
Creates a messaging connection for client.
GrpcMessagingConnection - Class in alluxio.master.transport
Abstract Connection implementation based on Alluxio gRPC messaging.
GrpcMessagingConnection(GrpcMessagingConnection.ConnectionOwner, String, ThreadContext, 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.
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, ThreadContext, 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(Address, Consumer<Connection>, ThreadContext, ExecutorService, long) - Constructor for class alluxio.master.transport.GrpcMessagingServiceClientHandler
 
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 Transport based on Alluxio gRPC messaging.
GrpcMessagingTransport(AlluxioConfiguration, AlluxioConfiguration, UserState, UserState, String) - Constructor for class alluxio.master.transport.GrpcMessagingTransport
Creates Transport 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.
GrpcService - Class in alluxio.grpc
Utility class for wrapping gRPC service definition.
GrpcService(BindableService) - Constructor for class alluxio.grpc.GrpcService
Creates a new GrpcService.
GrpcService(ServerServiceDefinition) - Constructor for class alluxio.grpc.GrpcService
Creates a new GrpcService.
GrpcUtils - Class in alluxio.grpc
Utility methods for conversion between wire types and grpc types.

H

HADOOP_CONF_DIR_ENV_VAR - Static variable in class alluxio.cli.validation.HdfsValidationTask
Name of the environment variable to store the path to Hadoop config directory.
HADOOP_CONF_DIR_OPTION - Static variable in class alluxio.cli.validation.HdfsValidationTask
 
HADOOP_VERSION - Static variable in class alluxio.ProjectConstants
 
HadoopConfigurationFileParser - Class in alluxio.cli.validation
Parser for configuration files.
HadoopConfigurationFileParser() - Constructor for class alluxio.cli.validation.HadoopConfigurationFileParser
Constructs a HadoopConfigurationFileParser object.
HadoopConfigurationUtils - Class in alluxio.hadoop
Utility class for merging AlluxioConfiguration with Hadoop's Configuration class.
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(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.
handleCommand(WriteRequestCommand, BlockWriteRequestContext) - Method in class alluxio.worker.grpc.UfsFallbackBlockWriteHandler
 
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.
handleNodeLost(Address) - Method in class alluxio.master.meta.checkconf.ServerConfigurationStore
Updates configuration when a live node becomes lost.
handler(Class<T>, Consumer<T>) - Method in class alluxio.master.transport.GrpcMessagingConnection
 
handler(Class<T>, Function<T, CompletableFuture<U>>) - Method in class alluxio.master.transport.GrpcMessagingConnection
 
handleResponseMessage(TransportMessage) - Method in class alluxio.master.transport.GrpcMessagingConnection
 
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;
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;
hasActiveSyncTxId() - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
optional .alluxio.proto.journal.ActiveSyncTxIdEntry active_sync_tx_id = 34;
hasActiveSyncTxId() - Method in class alluxio.proto.journal.Journal.JournalEntry
optional .alluxio.proto.journal.ActiveSyncTxIdEntry active_sync_tx_id = 34;
hasActiveSyncTxId() - Method in interface alluxio.proto.journal.Journal.JournalEntryOrBuilder
optional .alluxio.proto.journal.ActiveSyncTxIdEntry active_sync_tx_id = 34;
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;
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;
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;
hasAddTable() - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
optional .alluxio.proto.journal.AddTableEntry add_table = 43;
hasAddTable() - Method in class alluxio.proto.journal.Journal.JournalEntry
optional .alluxio.proto.journal.AddTableEntry add_table = 43;
hasAddTable() - Method in interface alluxio.proto.journal.Journal.JournalEntryOrBuilder
optional .alluxio.proto.journal.AddTableEntry add_table = 43;
hasAddTransformJobInfo() - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
optional .alluxio.proto.journal.AddTransformJobInfoEntry add_transform_job_info = 46;
hasAddTransformJobInfo() - Method in class alluxio.proto.journal.Journal.JournalEntry
optional .alluxio.proto.journal.AddTransformJobInfoEntry add_transform_job_info = 46;
hasAddTransformJobInfo() - Method in interface alluxio.proto.journal.Journal.JournalEntryOrBuilder
optional .alluxio.proto.journal.AddTransformJobInfoEntry add_transform_job_info = 46;
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
optional .alluxio.grpc.table.AllOrNoneSet all_or_none = 3;
hasAllOrNone() - Method in class alluxio.grpc.table.Domain
optional .alluxio.grpc.table.AllOrNoneSet all_or_none = 3;
hasAllOrNone() - Method in interface alluxio.grpc.table.DomainOrBuilder
optional .alluxio.grpc.table.AllOrNoneSet all_or_none = 3;
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.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.
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;
hasAttachDb() - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
optional .alluxio.proto.journal.AttachDbEntry attach_db = 44;
hasAttachDb() - Method in class alluxio.proto.journal.Journal.JournalEntry
optional .alluxio.proto.journal.AttachDbEntry attach_db = 44;
hasAttachDb() - Method in interface alluxio.proto.journal.Journal.JournalEntryOrBuilder
optional .alluxio.proto.journal.AttachDbEntry attach_db = 44;
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;
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;
hasBinaryStats() - Method in class alluxio.grpc.table.ColumnStatisticsData.Builder
optional .alluxio.grpc.table.BinaryColumnStatsData binary_stats = 5;
hasBinaryStats() - Method in class alluxio.grpc.table.ColumnStatisticsData
optional .alluxio.grpc.table.BinaryColumnStatsData binary_stats = 5;
hasBinaryStats() - Method in interface alluxio.grpc.table.ColumnStatisticsDataOrBuilder
optional .alluxio.grpc.table.BinaryColumnStatsData binary_stats = 5;
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;
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;
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.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 class alluxio.grpc.CommitBlockInUfsPRequest.Builder
the id of the worker
hasBlockId() - Method in class alluxio.grpc.CommitBlockInUfsPRequest
the id of the worker
hasBlockId() - Method in interface alluxio.grpc.CommitBlockInUfsPRequestOrBuilder
the id of the worker
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.CreateLocalBlockRequest.Builder
optional int64 block_id = 1;
hasBlockId() - Method in class alluxio.grpc.CreateLocalBlockRequest
optional int64 block_id = 1;
hasBlockId() - Method in interface alluxio.grpc.CreateLocalBlockRequestOrBuilder
optional int64 block_id = 1;
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.OpenLocalBlockRequest.Builder
optional int64 block_id = 1;
hasBlockId() - Method in class alluxio.grpc.OpenLocalBlockRequest
optional int64 block_id = 1;
hasBlockId() - Method in interface alluxio.grpc.OpenLocalBlockRequestOrBuilder
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.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;
hasBlockInUfsTier() - Method in class alluxio.proto.dataserver.Protocol.OpenUfsBlockOptions.Builder
If set to true, the block is possibly stored as a UFS block.
hasBlockInUfsTier() - Method in class alluxio.proto.dataserver.Protocol.OpenUfsBlockOptions
If set to true, the block is possibly stored as a UFS block.
hasBlockInUfsTier() - Method in interface alluxio.proto.dataserver.Protocol.OpenUfsBlockOptionsOrBuilder
If set to true, the block is possibly stored as a UFS block.
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 class alluxio.worker.block.BlockMetadataManager
Checks if the storage has a given block.
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.BlockWorker
Checks if the storage has a given block.
hasBlockMeta(long) - Method in class alluxio.worker.block.DefaultBlockWorker
 
hasBlockMeta(long) - Method in class alluxio.worker.block.meta.StorageDir
Checks if a block is in this storage dir.
hasBlockMeta(long) - Method in class alluxio.worker.block.TieredBlockStore
 
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
optional .alluxio.grpc.table.BooleanColumnStatsData boolean_stats = 1;
hasBooleanStats() - Method in class alluxio.grpc.table.ColumnStatisticsData
optional .alluxio.grpc.table.BooleanColumnStatsData boolean_stats = 1;
hasBooleanStats() - Method in interface alluxio.grpc.table.ColumnStatisticsDataOrBuilder
optional .alluxio.grpc.table.BooleanColumnStatsData boolean_stats = 1;
hasBooleanType() - Method in class alluxio.grpc.table.Value.Builder
optional bool boolean_type = 4;
hasBooleanType() - Method in class alluxio.grpc.table.Value
optional bool boolean_type = 4;
hasBooleanType() - Method in interface alluxio.grpc.table.ValueOrBuilder
optional 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;
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;
hasBytesInBlockStore() - Method in class alluxio.proto.dataserver.Protocol.CreateUfsBlockOptions.Builder
the number of bytes previously written to block store zero if no previous temp block created
hasBytesInBlockStore() - Method in class alluxio.proto.dataserver.Protocol.CreateUfsBlockOptions
the number of bytes previously written to block store zero if no previous temp block created
hasBytesInBlockStore() - Method in interface alluxio.proto.dataserver.Protocol.CreateUfsBlockOptionsOrBuilder
the number of bytes previously written to block store zero if no previous temp block created
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;
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;
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;
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.WriteRequest.Builder
optional .alluxio.grpc.block.Chunk chunk = 2;
hasChunk() - Method in class alluxio.grpc.WriteRequest
optional .alluxio.grpc.block.Chunk chunk = 2;
hasChunk() - Method in interface alluxio.grpc.WriteRequestOrBuilder
optional .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;
hasCleanupOnFailure() - Method in class alluxio.grpc.CreateLocalBlockRequest.Builder
optional bool cleanup_on_failure = 6;
hasCleanupOnFailure() - Method in class alluxio.grpc.CreateLocalBlockRequest
optional bool cleanup_on_failure = 6;
hasCleanupOnFailure() - Method in interface alluxio.grpc.CreateLocalBlockRequestOrBuilder
optional bool cleanup_on_failure = 6;
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;
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;
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.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
optional .alluxio.grpc.block.WriteRequestCommand command = 1;
hasCommand() - Method in class alluxio.grpc.WriteRequest
optional .alluxio.grpc.block.WriteRequestCommand command = 1;
hasCommand() - Method in interface alluxio.grpc.WriteRequestOrBuilder
optional .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;
hasComment() - Method in class alluxio.proto.journal.Table.UpdateDatabaseInfoEntry.Builder
optional string comment = 6;
hasComment() - Method in class alluxio.proto.journal.Table.UpdateDatabaseInfoEntry
optional string comment = 6;
hasComment() - Method in interface alluxio.proto.journal.Table.UpdateDatabaseInfoEntryOrBuilder
optional string comment = 6;
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.StartSyncPOptions.Builder
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 1;
hasCommonOptions() - Method in class alluxio.grpc.StartSyncPOptions
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 1;
hasCommonOptions() - Method in interface alluxio.grpc.StartSyncPOptionsOrBuilder
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 1;
hasCommonOptions() - Method in class alluxio.grpc.StopSyncPOptions.Builder
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 1;
hasCommonOptions() - Method in class alluxio.grpc.StopSyncPOptions
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 1;
hasCommonOptions() - Method in interface alluxio.grpc.StopSyncPOptionsOrBuilder
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 1;
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;
hasCompleteTransformTable() - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
optional .alluxio.proto.journal.CompleteTransformTableEntry complete_transform_table = 48;
hasCompleteTransformTable() - Method in class alluxio.proto.journal.Journal.JournalEntry
optional .alluxio.proto.journal.CompleteTransformTableEntry complete_transform_table = 48;
hasCompleteTransformTable() - Method in interface alluxio.proto.journal.Journal.JournalEntryOrBuilder
optional .alluxio.proto.journal.CompleteTransformTableEntry complete_transform_table = 48;
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;
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;
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;
hasCreateUfsBlockOptions() - Method in class alluxio.grpc.WriteRequestCommand.Builder
optional .alluxio.proto.dataserver.CreateUfsBlockOptions create_ufs_block_options = 7;
hasCreateUfsBlockOptions() - Method in class alluxio.grpc.WriteRequestCommand
optional .alluxio.proto.dataserver.CreateUfsBlockOptions create_ufs_block_options = 7;
hasCreateUfsBlockOptions() - Method in interface alluxio.grpc.WriteRequestCommandOrBuilder
optional .alluxio.proto.dataserver.CreateUfsBlockOptions create_ufs_block_options = 7;
hasCreateUfsBlockOptions() - Method in class alluxio.worker.grpc.BlockWriteRequest
 
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.
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.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;
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
optional .alluxio.grpc.table.DateColumnStatsData date_stats = 7;
hasDateStats() - Method in class alluxio.grpc.table.ColumnStatisticsData
optional .alluxio.grpc.table.DateColumnStatsData date_stats = 7;
hasDateStats() - Method in interface alluxio.grpc.table.ColumnStatisticsDataOrBuilder
optional .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;
hasDbName() - Method in class alluxio.proto.journal.Table.AddTableEntry.Builder
optional string db_name = 1;
hasDbName() - Method in class alluxio.proto.journal.Table.AddTableEntry
optional string db_name = 1;
hasDbName() - Method in interface alluxio.proto.journal.Table.AddTableEntryOrBuilder
optional string db_name = 1;
hasDbName() - Method in class alluxio.proto.journal.Table.AddTransformJobInfoEntry.Builder
optional string db_name = 1;
hasDbName() - Method in class alluxio.proto.journal.Table.AddTransformJobInfoEntry
optional string db_name = 1;
hasDbName() - Method in interface alluxio.proto.journal.Table.AddTransformJobInfoEntryOrBuilder
optional string db_name = 1;
hasDbName() - Method in class alluxio.proto.journal.Table.AttachDbEntry.Builder
optional string db_name = 4;
hasDbName() - Method in class alluxio.proto.journal.Table.AttachDbEntry
optional string db_name = 4;
hasDbName() - Method in interface alluxio.proto.journal.Table.AttachDbEntryOrBuilder
optional string db_name = 4;
hasDbName() - Method in class alluxio.proto.journal.Table.CompleteTransformTableEntry.Builder
optional string db_name = 1;
hasDbName() - Method in class alluxio.proto.journal.Table.CompleteTransformTableEntry
optional string db_name = 1;
hasDbName() - Method in interface alluxio.proto.journal.Table.CompleteTransformTableEntryOrBuilder
optional string db_name = 1;
hasDbName() - Method in class alluxio.proto.journal.Table.DetachDbEntry.Builder
optional string db_name = 1;
hasDbName() - Method in class alluxio.proto.journal.Table.DetachDbEntry
optional string db_name = 1;
hasDbName() - Method in interface alluxio.proto.journal.Table.DetachDbEntryOrBuilder
optional string db_name = 1;
hasDbName() - Method in class alluxio.proto.journal.Table.RemoveTableEntry.Builder
optional string db_name = 1;
hasDbName() - Method in class alluxio.proto.journal.Table.RemoveTableEntry
optional string db_name = 1;
hasDbName() - Method in interface alluxio.proto.journal.Table.RemoveTableEntryOrBuilder
optional string db_name = 1;
hasDbName() - Method in class alluxio.proto.journal.Table.RemoveTransformJobInfoEntry.Builder
optional string db_name = 1;
hasDbName() - Method in class alluxio.proto.journal.Table.RemoveTransformJobInfoEntry
optional string db_name = 1;
hasDbName() - Method in interface alluxio.proto.journal.Table.RemoveTransformJobInfoEntryOrBuilder
optional string db_name = 1;
hasDbName() - Method in class alluxio.proto.journal.Table.UpdateDatabaseInfoEntry.Builder
optional string db_name = 1;
hasDbName() - Method in class alluxio.proto.journal.Table.UpdateDatabaseInfoEntry
optional string db_name = 1;
hasDbName() - Method in interface alluxio.proto.journal.Table.UpdateDatabaseInfoEntryOrBuilder
optional string db_name = 1;
hasDecimalStats() - Method in class alluxio.grpc.table.ColumnStatisticsData.Builder
optional .alluxio.grpc.table.DecimalColumnStatsData decimal_stats = 6;
hasDecimalStats() - Method in class alluxio.grpc.table.ColumnStatisticsData
optional .alluxio.grpc.table.DecimalColumnStatsData decimal_stats = 6;
hasDecimalStats() - Method in interface alluxio.grpc.table.ColumnStatisticsDataOrBuilder
optional .alluxio.grpc.table.DecimalColumnStatsData decimal_stats = 6;
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;
hasDefinition() - Method in class alluxio.proto.journal.Table.AddTransformJobInfoEntry.Builder
optional string definition = 3;
hasDefinition() - Method in class alluxio.proto.journal.Table.AddTransformJobInfoEntry
optional string definition = 3;
hasDefinition() - Method in interface alluxio.proto.journal.Table.AddTransformJobInfoEntryOrBuilder
optional string definition = 3;
hasDefinition() - Method in class alluxio.proto.journal.Table.CompleteTransformTableEntry.Builder
optional string definition = 3;
hasDefinition() - Method in class alluxio.proto.journal.Table.CompleteTransformTableEntry
optional string definition = 3;
hasDefinition() - Method in interface alluxio.proto.journal.Table.CompleteTransformTableEntryOrBuilder
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.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;
hasDetachDb() - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
optional .alluxio.proto.journal.DetachDbEntry detach_db = 45;
hasDetachDb() - Method in class alluxio.proto.journal.Journal.JournalEntry
optional .alluxio.proto.journal.DetachDbEntry detach_db = 45;
hasDetachDb() - Method in interface alluxio.proto.journal.Journal.JournalEntryOrBuilder
optional .alluxio.proto.journal.DetachDbEntry detach_db = 45;
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;
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
optional .alluxio.grpc.table.DoubleColumnStatsData double_stats = 3;
hasDoubleStats() - Method in class alluxio.grpc.table.ColumnStatisticsData
optional .alluxio.grpc.table.DoubleColumnStatsData double_stats = 3;
hasDoubleStats() - Method in interface alluxio.grpc.table.ColumnStatisticsDataOrBuilder
optional .alluxio.grpc.table.DoubleColumnStatsData double_stats = 3;
hasDoubleType() - Method in class alluxio.grpc.table.Value.Builder
optional double double_type = 2;
hasDoubleType() - Method in class alluxio.grpc.table.Value
optional double double_type = 2;
hasDoubleType() - Method in interface alluxio.grpc.table.ValueOrBuilder
optional 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;
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
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;
hasEquatable() - Method in class alluxio.grpc.table.Domain.Builder
optional .alluxio.grpc.table.EquatableValueSet equatable = 2;
hasEquatable() - Method in class alluxio.grpc.table.Domain
optional .alluxio.grpc.table.EquatableValueSet equatable = 2;
hasEquatable() - Method in interface alluxio.grpc.table.DomainOrBuilder
optional .alluxio.grpc.table.EquatableValueSet equatable = 2;
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;
hasExtended() - Method in class alluxio.security.authorization.AccessControlList
 
hasExtended() - Method in class alluxio.security.authorization.ExtendedACLEntries
 
hasFallback() - Method in class alluxio.proto.dataserver.Protocol.CreateUfsBlockOptions.Builder
true if the write request is already a fallback from a failed short-circuit write.
hasFallback() - Method in class alluxio.proto.dataserver.Protocol.CreateUfsBlockOptions
true if the write request is already a fallback from a failed short-circuit write.
hasFallback() - Method in interface alluxio.proto.dataserver.Protocol.CreateUfsBlockOptionsOrBuilder
true if the write request is already a fallback from a failed short-circuit write.
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;
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;
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.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 interface alluxio.conf.AlluxioConfiguration
 
hash() - Method in class alluxio.conf.AlluxioProperties
 
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() - Static method in class alluxio.conf.ServerConfiguration
 
hash() - Method in class alluxio.master.meta.PathProperties
 
hash(int, String) - Static method in class alluxio.util.URIUtils
Hashes a string for a URI hash.
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;
hashCode() - Method in class alluxio.AlluxioURI
 
hashCode() - Method in class alluxio.cli.docgen.MetricsDocGenerator.FileWriterKey
 
hashCode() - Method in class alluxio.client.block.options.GetWorkerReportOptions
 
hashCode() - Method in class alluxio.client.block.policy.DeterministicHashPolicy
 
hashCode() - Method in class alluxio.client.block.policy.LocalFirstAvoidEvictionPolicy
 
hashCode() - Method in class alluxio.client.block.policy.LocalFirstPolicy
 
hashCode() - Method in class alluxio.client.block.policy.MostAvailableFirstPolicy
 
hashCode() - Method in class alluxio.client.block.policy.options.GetWorkerOptions
 
hashCode() - Method in class alluxio.client.block.policy.RoundRobinPolicy
 
hashCode() - Method in class alluxio.client.block.policy.SpecificHostPolicy
 
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.FileSystemCache.Key
 
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.collections.DelegatingSet
 
hashCode() - Method in class alluxio.collections.Pair
 
hashCode() - Method in class alluxio.collections.TwoKeyConcurrentMap
The hashCode implementation for this map simply uses the superclass's.
hashCode() - Method in class alluxio.conf.PropertyKey
 
hashCode() - Method in class alluxio.conf.Source
 
hashCode() - Method in class alluxio.grpc.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.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.BlockStoreLocationProto
 
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.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.Command
 
hashCode() - Method in class alluxio.grpc.CommitBlockInUfsPOptions
 
hashCode() - Method in class alluxio.grpc.CommitBlockInUfsPRequest
 
hashCode() - Method in class alluxio.grpc.CommitBlockInUfsPResponse
 
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.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.CreateLocalBlockRequest
 
hashCode() - Method in class alluxio.grpc.CreateLocalBlockResponse
 
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.ExistsPOptions
 
hashCode() - Method in class alluxio.grpc.FileBlockInfo
 
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.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.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.GetJobServiceSummaryPOptions
 
hashCode() - Method in class alluxio.grpc.GetJobServiceSummaryPRequest
 
hashCode() - Method in class alluxio.grpc.GetJobServiceSummaryPResponse
 
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.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.GetPinnedFileIdsPOptions
 
hashCode() - Method in class alluxio.grpc.GetPinnedFileIdsPRequest
 
hashCode() - Method in class alluxio.grpc.GetPinnedFileIdsPResponse
 
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.GetServiceVersionPRequest
 
hashCode() - Method in class alluxio.grpc.GetServiceVersionPResponse
 
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.GetSyncPathListPRequest
 
hashCode() - Method in class alluxio.grpc.GetSyncPathListPResponse
 
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.GrpcChannelKey
 
hashCode() - Method in class alluxio.grpc.GrpcConnection
 
hashCode() - Method in class alluxio.grpc.GrpcConnectionKey
 
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.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.JobServiceSummary
 
hashCode() - Method in class alluxio.grpc.JobUnused
 
hashCode() - Method in class alluxio.grpc.JobWorkerHealth
 
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.ListStatusPOptions
 
hashCode() - Method in class alluxio.grpc.ListStatusPRequest
 
hashCode() - Method in class alluxio.grpc.ListStatusPResponse
 
hashCode() - Method in class alluxio.grpc.LoadMetadataPOptions
 
hashCode() - Method in class alluxio.grpc.LocalityTier
 
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.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.NetAddress
 
hashCode() - Method in class alluxio.grpc.OpenFilePOptions
 
hashCode() - Method in class alluxio.grpc.OpenLocalBlockRequest
 
hashCode() - Method in class alluxio.grpc.OpenLocalBlockResponse
 
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.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.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.RemovePathConfigurationPOptions
 
hashCode() - Method in class alluxio.grpc.RemovePathConfigurationPRequest
 
hashCode() - Method in class alluxio.grpc.RemovePathConfigurationPResponse
 
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.ReverseResolvePRequest
 
hashCode() - Method in class alluxio.grpc.ReverseResolvePResponse
 
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.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.StartSyncPOptions
 
hashCode() - Method in class alluxio.grpc.StartSyncPRequest
 
hashCode() - Method in class alluxio.grpc.StartSyncPResponse
 
hashCode() - Method in class alluxio.grpc.StatusSummary
 
hashCode() - Method in class alluxio.grpc.StopSyncPOptions
 
hashCode() - Method in class alluxio.grpc.StopSyncPRequest
 
hashCode() - Method in class alluxio.grpc.StopSyncPResponse
 
hashCode() - Method in class alluxio.grpc.StorageList
 
hashCode() - Method in class alluxio.grpc.SyncPointInfo
 
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.TieredIdentity
 
hashCode() - Method in class alluxio.grpc.TierList
 
hashCode() - Method in class alluxio.grpc.TransportMessage
 
hashCode() - Method in class alluxio.grpc.UfsInfo
 
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.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.WorkerInfo
 
hashCode() - Method in class alluxio.grpc.WorkerLostStorageInfo
 
hashCode() - Method in class alluxio.grpc.WorkerNetAddress
 
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.job.plan.load.LoadConfig
 
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.persist.PersistConfig
 
hashCode() - Method in class alluxio.job.plan.replicate.EvictConfig
 
hashCode() - Method in class alluxio.job.plan.replicate.MoveConfig
 
hashCode() - Method in class alluxio.job.plan.replicate.ReplicateConfig
 
hashCode() - Method in class alluxio.job.plan.transform.CompactConfig
 
hashCode() - Method in class alluxio.job.plan.transform.CompactTask
 
hashCode() - Method in class alluxio.job.plan.transform.FieldSchema
 
hashCode() - Method in class alluxio.job.plan.transform.format.csv.CsvRow
 
hashCode() - Method in class alluxio.job.plan.transform.format.csv.CsvSchema
 
hashCode() - Method in class alluxio.job.plan.transform.format.parquet.ParquetRow
 
hashCode() - Method in class alluxio.job.plan.transform.format.parquet.ParquetSchema
 
hashCode() - Method in class alluxio.job.plan.transform.PartitionInfo
 
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.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.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.SingleMasterInquireClient.SingleMasterConnectDetails
 
hashCode() - Method in class alluxio.master.table.DatabaseInfo
 
hashCode() - Method in class alluxio.master.ZkMasterInquireClient.ZkMasterConnectDetails
 
hashCode() - Method in class alluxio.metrics.Metric
 
hashCode() - Method in class alluxio.metrics.MetricKey
 
hashCode() - Method in class alluxio.metrics.MetricsFilter
 
hashCode() - Method in class alluxio.proto.client.Cache.PPageStoreCommonOptions
 
hashCode() - Method in class alluxio.proto.client.Cache.PRocksPageStoreOptions
 
hashCode() - Method in class alluxio.proto.dataserver.Protocol.CreateUfsBlockOptions
 
hashCode() - Method in class alluxio.proto.dataserver.Protocol.CreateUfsFileOptions
 
hashCode() - Method in class alluxio.proto.dataserver.Protocol.OpenUfsBlockOptions
 
hashCode() - Method in class alluxio.proto.dataserver.Protocol.Response
 
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.Journal.JournalEntry
 
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.Table.AddTableEntry
 
hashCode() - Method in class alluxio.proto.journal.Table.AddTransformJobInfoEntry
 
hashCode() - Method in class alluxio.proto.journal.Table.AttachDbEntry
 
hashCode() - Method in class alluxio.proto.journal.Table.CompleteTransformTableEntry
 
hashCode() - Method in class alluxio.proto.journal.Table.DetachDbEntry
 
hashCode() - Method in class alluxio.proto.journal.Table.RemoveTableEntry
 
hashCode() - Method in class alluxio.proto.journal.Table.RemoveTransformJobInfoEntry
 
hashCode() - Method in class alluxio.proto.journal.Table.UpdateDatabaseInfoEntry
 
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.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.ListBucketOptions
 
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.table.common.BaseProperty
 
hashCode() - Method in class alluxio.table.common.layout.HiveLayout
 
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.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.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.MountPointInfo
 
hashCode() - Method in class alluxio.wire.TieredIdentity
 
hashCode() - Method in class alluxio.wire.TieredIdentity.LocalityTier
 
hashCode() - Method in class alluxio.wire.WorkerInfo
 
hashCode() - Method in class alluxio.wire.WorkerNetAddress
 
hashCode() - Method in class alluxio.worker.block.BlockStoreLocation
 
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;
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.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.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.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;
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;
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;
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.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;
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
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;
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;
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;
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.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.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.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.Table.AddTransformJobInfoEntry.Builder
optional int64 job_id = 4;
hasJobId() - Method in class alluxio.proto.journal.Table.AddTransformJobInfoEntry
optional int64 job_id = 4;
hasJobId() - Method in interface alluxio.proto.journal.Table.AddTransformJobInfoEntryOrBuilder
optional int64 job_id = 4;
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;
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;
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;
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;
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;
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;
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;
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;
hasLayout() - Method in class alluxio.proto.journal.Table.AddTableEntry.Builder
optional .alluxio.grpc.table.Layout layout = 5;
hasLayout() - Method in class alluxio.proto.journal.Table.AddTableEntry
optional .alluxio.grpc.table.Layout layout = 5;
hasLayout() - Method in interface alluxio.proto.journal.Table.AddTableEntryOrBuilder
optional .alluxio.grpc.table.Layout layout = 5;
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;
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.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 class alluxio.grpc.CommitBlockInUfsPRequest.Builder
the space used in bytes on the target tier
hasLength() - Method in class alluxio.grpc.CommitBlockInUfsPRequest
the space used in bytes on the target tier
hasLength() - Method in interface alluxio.grpc.CommitBlockInUfsPRequestOrBuilder
the space used in bytes on the target tier
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.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 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.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.
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;
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;
hasLocalWorker() - Method in class alluxio.client.file.FileSystemContext
 
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;
hasLocation() - Method in class alluxio.proto.journal.Table.UpdateDatabaseInfoEntry.Builder
optional string location = 2;
hasLocation() - Method in class alluxio.proto.journal.Table.UpdateDatabaseInfoEntry
optional string location = 2;
hasLocation() - Method in interface alluxio.proto.journal.Table.UpdateDatabaseInfoEntryOrBuilder
optional string location = 2;
hasLongStats() - Method in class alluxio.grpc.table.ColumnStatisticsData.Builder
optional .alluxio.grpc.table.LongColumnStatsData long_stats = 2;
hasLongStats() - Method in class alluxio.grpc.table.ColumnStatisticsData
optional .alluxio.grpc.table.LongColumnStatsData long_stats = 2;
hasLongStats() - Method in interface alluxio.grpc.table.ColumnStatisticsDataOrBuilder
optional .alluxio.grpc.table.LongColumnStatsData long_stats = 2;
hasLongType() - Method in class alluxio.grpc.table.Value.Builder
optional int64 long_type = 1;
hasLongType() - Method in class alluxio.grpc.table.Value
optional int64 long_type = 1;
hasLongType() - Method in interface alluxio.grpc.table.ValueOrBuilder
optional int64 long_type = 1;
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.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;
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.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.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.CreateLocalBlockRequest.Builder
optional string medium_type = 7;
hasMediumType() - Method in class alluxio.grpc.CreateLocalBlockRequest
optional string medium_type = 7;
hasMediumType() - Method in interface alluxio.grpc.CreateLocalBlockRequestOrBuilder
optional string medium_type = 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.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.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;
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 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.proto.dataserver.Protocol.CreateUfsBlockOptions.Builder
mount ID of the UFS to write to
hasMountId() - Method in class alluxio.proto.dataserver.Protocol.CreateUfsBlockOptions
mount ID of the UFS to write to
hasMountId() - Method in interface alluxio.proto.dataserver.Protocol.CreateUfsBlockOptionsOrBuilder
mount ID of the UFS to write to
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;
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 do not have these
hasName() - Method in class alluxio.grpc.JobInfo
Some jobs don't have these do not have these
hasName() - Method in interface alluxio.grpc.JobInfoOrBuilder
Some jobs don't have these do not have these
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.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.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.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
 
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.
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.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
Errors will be handled by standard gRPC stream APIs.
hasOffset() - Method in class alluxio.grpc.WriteResponse
Errors will be handled by standard gRPC stream APIs.
hasOffset() - Method in interface alluxio.grpc.WriteResponseOrBuilder
Errors will be handled by standard gRPC stream APIs.
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.ReadRequest.Builder
Read receipt
hasOffsetReceived() - Method in class alluxio.grpc.ReadRequest
Read receipt
hasOffsetReceived() - Method in interface alluxio.grpc.ReadRequestOrBuilder
Read receipt
hasOnlyReserveSpace() - Method in class alluxio.grpc.CreateLocalBlockRequest.Builder
If set, only reserve space for the block.
hasOnlyReserveSpace() - Method in class alluxio.grpc.CreateLocalBlockRequest
If set, only reserve space for the block.
hasOnlyReserveSpace() - Method in interface alluxio.grpc.CreateLocalBlockRequestOrBuilder
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.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.
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.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.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.CommitBlockInUfsPRequest.Builder
optional .alluxio.grpc.block.CommitBlockInUfsPOptions options = 3;
hasOptions() - Method in class alluxio.grpc.CommitBlockInUfsPRequest
optional .alluxio.grpc.block.CommitBlockInUfsPOptions options = 3;
hasOptions() - Method in interface alluxio.grpc.CommitBlockInUfsPRequestOrBuilder
optional .alluxio.grpc.block.CommitBlockInUfsPOptions options = 3;
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.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.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.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.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.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.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.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.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.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.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.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.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.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.StartSyncPRequest.Builder
optional .alluxio.grpc.file.StartSyncPOptions options = 2;
hasOptions() - Method in class alluxio.grpc.StartSyncPRequest
optional .alluxio.grpc.file.StartSyncPOptions options = 2;
hasOptions() - Method in interface alluxio.grpc.StartSyncPRequestOrBuilder
optional .alluxio.grpc.file.StartSyncPOptions options = 2;
hasOptions() - Method in class alluxio.grpc.StopSyncPRequest.Builder
optional .alluxio.grpc.file.StopSyncPOptions options = 2;
hasOptions() - Method in class alluxio.grpc.StopSyncPRequest
optional .alluxio.grpc.file.StopSyncPOptions options = 2;
hasOptions() - Method in interface alluxio.grpc.StopSyncPRequestOrBuilder
optional .alluxio.grpc.file.StopSyncPOptions options = 2;
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;
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;
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.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;
hasOwner() - Method in class alluxio.proto.journal.Table.AddTableEntry.Builder
optional string owner = 3;
hasOwner() - Method in class alluxio.proto.journal.Table.AddTableEntry
optional string owner = 3;
hasOwner() - Method in interface alluxio.proto.journal.Table.AddTableEntryOrBuilder
optional string owner = 3;
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;
hasOwnerName() - Method in class alluxio.proto.journal.Table.UpdateDatabaseInfoEntry.Builder
optional string owner_name = 4;
hasOwnerName() - Method in class alluxio.proto.journal.Table.UpdateDatabaseInfoEntry
optional string owner_name = 4;
hasOwnerName() - Method in interface alluxio.proto.journal.Table.UpdateDatabaseInfoEntryOrBuilder
optional string owner_name = 4;
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;
hasOwnerType() - Method in class alluxio.proto.journal.Table.UpdateDatabaseInfoEntry.Builder
optional .alluxio.grpc.table.PrincipalType owner_type = 5;
hasOwnerType() - Method in class alluxio.proto.journal.Table.UpdateDatabaseInfoEntry
optional .alluxio.grpc.table.PrincipalType owner_type = 5;
hasOwnerType() - Method in interface alluxio.proto.journal.Table.UpdateDatabaseInfoEntryOrBuilder
optional .alluxio.grpc.table.PrincipalType owner_type = 5;
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.DefaultMetaStore
 
hasPage(PageId) - Method in interface alluxio.client.file.cache.MetaStore
 
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;
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.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.CreateLocalBlockResponse.Builder
optional string path = 1;
hasPath() - Method in class alluxio.grpc.CreateLocalBlockResponse
optional string path = 1;
hasPath() - Method in interface alluxio.grpc.CreateLocalBlockResponseOrBuilder
optional string path = 1;
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.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.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.OpenLocalBlockResponse.Builder
optional string path = 1;
hasPath() - Method in class alluxio.grpc.OpenLocalBlockResponse
optional string path = 1;
hasPath() - Method in interface alluxio.grpc.OpenLocalBlockResponseOrBuilder
optional 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.grpc.StartSyncPRequest.Builder
optional string path = 1;
hasPath() - Method in class alluxio.grpc.StartSyncPRequest
optional string path = 1;
hasPath() - Method in interface alluxio.grpc.StartSyncPRequestOrBuilder
optional string path = 1;
hasPath() - Method in class alluxio.grpc.StopSyncPRequest.Builder
optional string path = 1;
hasPath() - Method in class alluxio.grpc.StopSyncPRequest
optional string path = 1;
hasPath() - Method in interface alluxio.grpc.StopSyncPRequestOrBuilder
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;
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;
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.CreateLocalBlockRequest.Builder
optional bool pin_on_create = 8;
hasPinOnCreate() - Method in class alluxio.grpc.CreateLocalBlockRequest
optional bool pin_on_create = 8;
hasPinOnCreate() - Method in interface alluxio.grpc.CreateLocalBlockRequestOrBuilder
optional bool pin_on_create = 8;
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;
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
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;
hasPreviousVersion() - Method in class alluxio.proto.journal.Table.AddTableEntry.Builder
optional int64 previous_version = 10;
hasPreviousVersion() - Method in class alluxio.proto.journal.Table.AddTableEntry
optional int64 previous_version = 10;
hasPreviousVersion() - Method in interface alluxio.proto.journal.Table.AddTableEntryOrBuilder
optional int64 previous_version = 10;
hasPromote() - Method in class alluxio.grpc.OpenLocalBlockRequest.Builder
optional bool promote = 2;
hasPromote() - Method in class alluxio.grpc.OpenLocalBlockRequest
optional bool promote = 2;
hasPromote() - Method in interface alluxio.grpc.OpenLocalBlockRequestOrBuilder
optional bool promote = 2;
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
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;
hasProxyFor(Address) - 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.
hasRange() - Method in class alluxio.grpc.table.Domain.Builder
optional .alluxio.grpc.table.RangeSet range = 1;
hasRange() - Method in class alluxio.grpc.table.Domain
optional .alluxio.grpc.table.RangeSet range = 1;
hasRange() - Method in interface alluxio.grpc.table.DomainOrBuilder
optional .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;
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;
hasRemoveTable() - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
optional .alluxio.proto.journal.RemoveTableEntry remove_table = 50;
hasRemoveTable() - Method in class alluxio.proto.journal.Journal.JournalEntry
optional .alluxio.proto.journal.RemoveTableEntry remove_table = 50;
hasRemoveTable() - Method in interface alluxio.proto.journal.Journal.JournalEntryOrBuilder
optional .alluxio.proto.journal.RemoveTableEntry remove_table = 50;
hasRemoveTransformJobInfo() - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
optional .alluxio.proto.journal.RemoveTransformJobInfoEntry remove_transform_job_info = 47;
hasRemoveTransformJobInfo() - Method in class alluxio.proto.journal.Journal.JournalEntry
optional .alluxio.proto.journal.RemoveTransformJobInfoEntry remove_transform_job_info = 47;
hasRemoveTransformJobInfo() - Method in interface alluxio.proto.journal.Journal.JournalEntryOrBuilder
optional .alluxio.proto.journal.RemoveTransformJobInfoEntry remove_transform_job_info = 47;
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;
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;
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;
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
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;
hasSchema() - Method in class alluxio.proto.journal.Table.AddTableEntry.Builder
optional .alluxio.grpc.table.Schema schema = 4;
hasSchema() - Method in class alluxio.proto.journal.Table.AddTableEntry
optional .alluxio.grpc.table.Schema schema = 4;
hasSchema() - Method in interface alluxio.proto.journal.Table.AddTableEntryOrBuilder
optional .alluxio.grpc.table.Schema schema = 4;
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
optional int64 sequence_number = 1;
hasSequenceNumber() - Method in class alluxio.proto.journal.Journal.JournalEntry
optional int64 sequence_number = 1;
hasSequenceNumber() - Method in interface alluxio.proto.journal.Journal.JournalEntryOrBuilder
optional int64 sequence_number = 1;
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.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;
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
optional .alluxio.grpc.version.ServiceType serviceType = 1;
hasServiceType() - Method in class alluxio.grpc.GetServiceVersionPRequest
optional .alluxio.grpc.version.ServiceType serviceType = 1;
hasServiceType() - Method in interface alluxio.grpc.GetServiceVersionPRequestOrBuilder
optional .alluxio.grpc.version.ServiceType serviceType = 1;
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;
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
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;
hasSpaceToReserve() - Method in class alluxio.grpc.CreateLocalBlockRequest.Builder
optional int64 space_to_reserve = 4;
hasSpaceToReserve() - Method in class alluxio.grpc.CreateLocalBlockRequest
optional int64 space_to_reserve = 4;
hasSpaceToReserve() - Method in interface alluxio.grpc.CreateLocalBlockRequestOrBuilder
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;
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.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.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;
hasStateLockSleepDurationMs() - Method in class alluxio.grpc.BackupPOptions.Builder
optional int64 stateLockSleepDurationMs = 5;
hasStateLockSleepDurationMs() - Method in class alluxio.grpc.BackupPOptions
optional int64 stateLockSleepDurationMs = 5;
hasStateLockSleepDurationMs() - Method in interface alluxio.grpc.BackupPOptionsOrBuilder
optional int64 stateLockSleepDurationMs = 5;
hasStateLockTimeoutMs() - Method in class alluxio.grpc.BackupPOptions.Builder
optional int64 stateLockTimeoutMs = 6;
hasStateLockTimeoutMs() - Method in class alluxio.grpc.BackupPOptions
optional int64 stateLockTimeoutMs = 6;
hasStateLockTimeoutMs() - Method in interface alluxio.grpc.BackupPOptionsOrBuilder
optional int64 stateLockTimeoutMs = 6;
hasStateLockTryDurationMs() - Method in class alluxio.grpc.BackupPOptions.Builder
optional int64 stateLockTryDurationMs = 4;
hasStateLockTryDurationMs() - Method in class alluxio.grpc.BackupPOptions
optional int64 stateLockTryDurationMs = 4;
hasStateLockTryDurationMs() - Method in interface alluxio.grpc.BackupPOptionsOrBuilder
optional int64 stateLockTryDurationMs = 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.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.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;
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
optional .alluxio.grpc.table.StringColumnStatsData string_stats = 4;
hasStringStats() - Method in class alluxio.grpc.table.ColumnStatisticsData
optional .alluxio.grpc.table.StringColumnStatsData string_stats = 4;
hasStringStats() - Method in interface alluxio.grpc.table.ColumnStatisticsDataOrBuilder
optional .alluxio.grpc.table.StringColumnStatsData string_stats = 4;
hasStringType() - Method in class alluxio.grpc.table.Value.Builder
optional string string_type = 3;
hasStringType() - Method in class alluxio.grpc.table.Value
optional string string_type = 3;
hasStringType() - Method in interface alluxio.grpc.table.ValueOrBuilder
optional 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 class alluxio.cli.bundler.command.CollectConfigCommand
 
hasSubCommand() - Method in class alluxio.cli.bundler.command.CollectEnvCommand
 
hasSubCommand() - Method in class alluxio.cli.bundler.command.CollectLogCommand
 
hasSubCommand() - Method in class alluxio.cli.bundler.command.CollectMetricsCommand
 
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.
hasSubCommand() - Method in class alluxio.cli.fsadmin.command.JournalCommand
 
hasSubCommand() - Method in class alluxio.cli.fsadmin.command.MetricsCommand
 
hasSubCommand() - Method in class alluxio.cli.fsadmin.command.PathConfCommand
 
hasSubCommand() - Method in class alluxio.cli.fsadmin.journal.QuorumCommand
 
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;
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;
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;
hasSyncPointUri() - Method in class alluxio.grpc.SyncPointInfo.Builder
optional string syncPointUri = 1;
hasSyncPointUri() - Method in class alluxio.grpc.SyncPointInfo
optional string syncPointUri = 1;
hasSyncPointUri() - Method in interface alluxio.grpc.SyncPointInfoOrBuilder
optional string syncPointUri = 1;
hasSyncStatus() - Method in class alluxio.grpc.SyncPointInfo.Builder
optional .alluxio.grpc.file.SyncPointStatus syncStatus = 2;
hasSyncStatus() - Method in class alluxio.grpc.SyncPointInfo
optional .alluxio.grpc.file.SyncPointStatus syncStatus = 2;
hasSyncStatus() - Method in interface alluxio.grpc.SyncPointInfoOrBuilder
optional .alluxio.grpc.file.SyncPointStatus syncStatus = 2;
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;
hasTableName() - Method in class alluxio.proto.journal.Table.AddTableEntry.Builder
optional string table_name = 2;
hasTableName() - Method in class alluxio.proto.journal.Table.AddTableEntry
optional string table_name = 2;
hasTableName() - Method in interface alluxio.proto.journal.Table.AddTableEntryOrBuilder
optional string table_name = 2;
hasTableName() - Method in class alluxio.proto.journal.Table.AddTransformJobInfoEntry.Builder
optional string table_name = 2;
hasTableName() - Method in class alluxio.proto.journal.Table.AddTransformJobInfoEntry
optional string table_name = 2;
hasTableName() - Method in interface alluxio.proto.journal.Table.AddTransformJobInfoEntryOrBuilder
optional string table_name = 2;
hasTableName() - Method in class alluxio.proto.journal.Table.CompleteTransformTableEntry.Builder
optional string table_name = 2;
hasTableName() - Method in class alluxio.proto.journal.Table.CompleteTransformTableEntry
optional string table_name = 2;
hasTableName() - Method in interface alluxio.proto.journal.Table.CompleteTransformTableEntryOrBuilder
optional string table_name = 2;
hasTableName() - Method in class alluxio.proto.journal.Table.RemoveTableEntry.Builder
optional string table_name = 2;
hasTableName() - Method in class alluxio.proto.journal.Table.RemoveTableEntry
optional string table_name = 2;
hasTableName() - Method in interface alluxio.proto.journal.Table.RemoveTableEntryOrBuilder
optional string table_name = 2;
hasTableName() - Method in class alluxio.proto.journal.Table.RemoveTransformJobInfoEntry.Builder
optional string table_name = 2;
hasTableName() - Method in class alluxio.proto.journal.Table.RemoveTransformJobInfoEntry
optional string table_name = 2;
hasTableName() - Method in interface alluxio.proto.journal.Table.RemoveTransformJobInfoEntryOrBuilder
optional string table_name = 2;
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 class alluxio.worker.block.BlockMetadataManager
Checks if the storage has a given temp block.
hasTempBlockMeta(long) - Method in class alluxio.worker.block.meta.StorageDir
Checks if a temp block is in this storage dir.
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;
hasTerminal(String, boolean) - Method in class alluxio.conf.path.TrieNode
Checks whether the path has terminal nodes as parents or children.
hasTier() - Method in class alluxio.grpc.CreateLocalBlockRequest.Builder
optional int32 tier = 3;
hasTier() - Method in class alluxio.grpc.CreateLocalBlockRequest
optional int32 tier = 3;
hasTier() - Method in interface alluxio.grpc.CreateLocalBlockRequestOrBuilder
optional int32 tier = 3;
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.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
hasTieredIdentity() - Method in class alluxio.grpc.WorkerNetAddress.Builder
optional .alluxio.grpc.TieredIdentity tieredIdentity = 6;
hasTieredIdentity() - Method in class alluxio.grpc.WorkerNetAddress
optional .alluxio.grpc.TieredIdentity tieredIdentity = 6;
hasTieredIdentity() - Method in interface alluxio.grpc.WorkerNetAddressOrBuilder
optional .alluxio.grpc.TieredIdentity tieredIdentity = 6;
hasTierName() - Method in class alluxio.grpc.LocalityTier.Builder
optional string tierName = 1;
hasTierName() - Method in class alluxio.grpc.LocalityTier
optional string tierName = 1;
hasTierName() - Method in interface alluxio.grpc.LocalityTierOrBuilder
optional string tierName = 1;
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.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.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;
hasUdbConnectionUri() - Method in class alluxio.proto.journal.Table.AttachDbEntry.Builder
optional string udb_connection_uri = 2;
hasUdbConnectionUri() - Method in class alluxio.proto.journal.Table.AttachDbEntry
optional string udb_connection_uri = 2;
hasUdbConnectionUri() - Method in interface alluxio.proto.journal.Table.AttachDbEntryOrBuilder
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;
hasUdbDbName() - Method in class alluxio.proto.journal.Table.AttachDbEntry.Builder
optional string udb_db_name = 3;
hasUdbDbName() - Method in class alluxio.proto.journal.Table.AttachDbEntry
optional string udb_db_name = 3;
hasUdbDbName() - Method in interface alluxio.proto.journal.Table.AttachDbEntryOrBuilder
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;
hasUdbType() - Method in class alluxio.proto.journal.Table.AttachDbEntry.Builder
optional string udb_type = 1;
hasUdbType() - Method in class alluxio.proto.journal.Table.AttachDbEntry
optional string udb_type = 1;
hasUdbType() - Method in interface alluxio.proto.journal.Table.AttachDbEntryOrBuilder
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];
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;
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.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 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;
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.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
hasUpdateDatabaseInfo() - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
optional .alluxio.proto.journal.UpdateDatabaseInfoEntry update_database_info = 49;
hasUpdateDatabaseInfo() - Method in class alluxio.proto.journal.Journal.JournalEntry
optional .alluxio.proto.journal.UpdateDatabaseInfoEntry update_database_info = 49;
hasUpdateDatabaseInfo() - Method in interface alluxio.proto.journal.Journal.JournalEntryOrBuilder
optional .alluxio.proto.journal.UpdateDatabaseInfoEntry update_database_info = 49;
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
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.
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.LocalityTier.Builder
optional string value = 2;
hasValue() - Method in class alluxio.grpc.LocalityTier
optional string value = 2;
hasValue() - Method in interface alluxio.grpc.LocalityTierOrBuilder
optional string value = 2;
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;
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.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.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.proto.journal.Table.AddTableEntry.Builder
optional int64 version = 11;
hasVersion() - Method in class alluxio.proto.journal.Table.AddTableEntry
optional int64 version = 11;
hasVersion() - Method in interface alluxio.proto.journal.Table.AddTableEntryOrBuilder
optional int64 version = 11;
hasVersion() - Method in class alluxio.proto.journal.Table.RemoveTableEntry.Builder
optional int64 version = 4;
hasVersion() - Method in class alluxio.proto.journal.Table.RemoveTableEntry
optional int64 version = 4;
hasVersion() - Method in interface alluxio.proto.journal.Table.RemoveTableEntryOrBuilder
optional int64 version = 4;
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;
hasVersionCreationTime() - Method in class alluxio.proto.journal.Table.AddTableEntry.Builder
optional int64 version_creation_time = 12;
hasVersionCreationTime() - Method in class alluxio.proto.journal.Table.AddTableEntry
optional int64 version_creation_time = 12;
hasVersionCreationTime() - Method in interface alluxio.proto.journal.Table.AddTableEntryOrBuilder
optional int64 version_creation_time = 12;
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;
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.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.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;
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.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;
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.CreateDirectoryPOptions.Builder
optional .alluxio.grpc.file.WritePType writeType = 4;
hasWriteType() - Method in class alluxio.grpc.CreateDirectoryPOptions
optional .alluxio.grpc.file.WritePType writeType = 4;
hasWriteType() - Method in interface alluxio.grpc.CreateDirectoryPOptionsOrBuilder
optional .alluxio.grpc.file.WritePType writeType = 4;
hasWriteType() - Method in class alluxio.grpc.CreateFilePOptions.Builder
optional .alluxio.grpc.file.WritePType writeType = 8;
hasWriteType() - Method in class alluxio.grpc.CreateFilePOptions
optional .alluxio.grpc.file.WritePType writeType = 8;
hasWriteType() - Method in interface alluxio.grpc.CreateFilePOptionsOrBuilder
optional .alluxio.grpc.file.WritePType writeType = 8;
HdfsAclProvider - Interface in alluxio.underfs.hdfs
Interface for providing HDFS ACLs.
HdfsActiveSyncProvider - Interface in alluxio.underfs.hdfs
Interface for providing HDFS ActiveSync.
HdfsFileInputStream - Class in alluxio.hadoop
An input stream for reading a file from HDFS.
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.
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(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.
HdfsUnderFileSystemFactory - Class in alluxio.underfs.hdfs
Factory for creating HdfsUnderFileSystem.
HdfsUnderFileSystemFactory() - Constructor for class alluxio.underfs.hdfs.HdfsUnderFileSystemFactory
Constructs a new HdfsUnderFileSystemFactory.
HdfsValidationTask - Class in alluxio.cli.validation
Abstract class for validating HDFS-related configurations.
HdfsValidationTask() - Constructor for class alluxio.cli.validation.HdfsValidationTask
Constructor of HdfsValidationTask.
HdfsVersion - Enum in alluxio.underfs.hdfs
The set of supported Hdfs versions.
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.
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_COS - Static variable in class alluxio.Constants
 
HEADER_GCS - Static variable in class alluxio.Constants
 
HEADER_HTTP - Static variable in class alluxio.Constants
 
HEADER_HTTPS - Static variable in class alluxio.Constants
 
HEADER_KODO - Static variable in class alluxio.Constants
 
HEADER_OSS - Static variable in class alluxio.Constants
 
HEADER_S3 - Static variable in class alluxio.Constants
 
HEADER_S3A - Static variable in class alluxio.Constants
 
HEADER_SWIFT - Static variable in class alluxio.Constants
 
HealthCheckClient - Interface in alluxio
Client for checking service availability.
HeapBlockStore - Class in alluxio.master.metastore.heap
This class requires external synchronization for operations on the same block id.
HeapBlockStore() - Constructor for class alluxio.master.metastore.heap.HeapBlockStore
 
HeapInodeStore - Class in alluxio.master.metastore.heap
FileStore implementation using on-heap data structures.
HeapInodeStore() - Constructor for class alluxio.master.metastore.heap.HeapInodeStore
 
heartbeat() - 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(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.JobMasterWorkerServiceImplBase
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() - Method in interface alluxio.heartbeat.HeartbeatExecutor
Implements the heartbeat logic.
heartbeat() - Method in class alluxio.master.file.activesync.ActiveSyncer
 
heartbeat() - Method in class alluxio.master.file.BlockIntegrityChecker
 
heartbeat() - Method in class alluxio.master.file.replication.ReplicationChecker
Implements the heartbeat logic.
heartbeat(JobHeartbeatPRequest, StreamObserver<JobHeartbeatPResponse>) - Method in class alluxio.master.job.JobMasterWorkerServiceHandler
 
heartbeat() - Method in class alluxio.master.meta.MetaMasterSync
Heartbeats to the leader master node.
heartbeat(long) - Method in class alluxio.master.meta.RetryHandlingMetaMasterMasterClient
Sends a heartbeat to the leader master.
heartbeat() - Method in class alluxio.master.meta.UpdateChecker
Heartbeat for the periodically update check.
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() - Method in class alluxio.worker.block.BlockMasterSync
Heartbeats to the master node about the change in the worker's managed space.
heartbeat() - Method in class alluxio.worker.block.DefaultBlockWorker.StorageChecker
 
heartbeat() - Method in class alluxio.worker.block.PinListSync
 
heartbeat() - Method in class alluxio.worker.block.SpaceReserver
 
heartbeat(long, List<Long>) - Method in class alluxio.worker.file.FileSystemMasterClient
Heartbeats to the master.
heartbeat(long, List<Long>, FileSystemHeartbeatPOptions) - Method in class alluxio.worker.file.FileSystemMasterClient
Heartbeats to the master.
heartbeat() - 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.
HeartbeatExecutor - Interface in alluxio.heartbeat
An interface for a heartbeat execution.
HeartbeatScheduler - Class in alluxio.heartbeat
This class can be used for controlling heartbeat execution of a thread.
HeartbeatThread - Class in alluxio.heartbeat
Thread class to execute a heartbeat periodically.
HeartbeatThread(String, String, HeartbeatExecutor, long, AlluxioConfiguration, UserState) - Constructor for class alluxio.heartbeat.HeartbeatThread
Creates a Runnable to execute heartbeats for the given HeartbeatExecutor.
HeartbeatThread(String, HeartbeatExecutor, long, AlluxioConfiguration, UserState) - Constructor for class alluxio.heartbeat.HeartbeatThread
HeartbeatTimer - Interface in alluxio.heartbeat
An interface for heartbeat timers.
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
 
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
 
HiveClientPool - Class in alluxio.table.under.hive.util
A pool for hive clients, since hive clients are not thread safe.
HiveClientPool(String, String) - Constructor for class alluxio.table.under.hive.util.HiveClientPool
Creates a new hive client client pool.
HiveConstants - Class in alluxio.job.plan.transform
Constants related to Hive.
HiveConstants.Types - Class in alluxio.job.plan.transform
Hive Types.
HiveDatabase - Class in alluxio.table.under.hive
Hive database implementation.
HiveDatabaseFactory - Class in alluxio.table.under.hive
Factory to create database implementation.
HiveDatabaseFactory() - Constructor for class alluxio.table.under.hive.HiveDatabaseFactory
 
HiveIntegrationChecker - Class in alluxio.checker
Some Hive queries to test the integration of Hive with Alluxio.
HiveIntegrationChecker() - Constructor for class alluxio.checker.HiveIntegrationChecker
 
HiveIntegrationChecker.Mode - Enum in alluxio.checker
Hive and Alluxio integration mode.
HiveIntegrationChecker.ModeConverter - Class in alluxio.checker
Converts input string USER_MODE to enum Mode.
HiveLayout - Class in alluxio.table.common.layout
Hive layout implementation.
HiveLayout(PartitionInfo, List<ColumnStatisticsInfo>) - Constructor for class alluxio.table.common.layout.HiveLayout
Creates an instance.
HiveLayout.HiveLayoutFactory - Class in alluxio.table.common.layout
Factory to create layout implementation.
HiveLayoutFactory() - Constructor for class alluxio.table.common.layout.HiveLayout.HiveLayoutFactory
 
HiveLayoutProto - Class in alluxio.grpc.table.layout.hive
 
HivePartition - Class in alluxio.table.under.hive
Hive table implementation.
HivePartition(HiveLayout) - Constructor for class alluxio.table.under.hive.HivePartition
Creates an instance.
HiveTable - Class in alluxio.table.under.hive
Hive table implementation.
HiveTable(String, Schema, List<ColumnStatisticsInfo>, List<FieldSchema>, List<UdbPartition>, Layout, Table) - Constructor for class alluxio.table.under.hive.HiveTable
Creates a new instance.
HiveUtils - Class in alluxio.table.under.hive
Utilities for hive types.
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
 
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.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.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.meta.InodeMeta.Inode
 
ID_NOT_SET_VALUE - Static variable in class alluxio.fuse.AlluxioFuseFileSystem
4294967295 is unsigned long -1, -1 means that uid or gid is not set.
ID_NOT_SET_VALUE_UNSIGNED - Static variable in class alluxio.fuse.AlluxioFuseFileSystem
 
ID_PARAM - Static variable in class alluxio.proxy.StreamsRestServiceHandler
 
ID_VALUE - Static variable in enum alluxio.grpc.WorkerInfoField
ID = 4;
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.
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
 
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_FORMAT - Static variable in class alluxio.cli.fs.command.LsCommand
 
INALLUXIOPERCENTAGE_FIELD_NUMBER - Static variable in class alluxio.grpc.FileInfo
 
inc() - Method in class alluxio.concurrent.CountingLatch
Increases the counter.
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
 
increaseUsageCount() - Method in class alluxio.worker.block.io.LocalFileBlockReader
increase the file reader usage count.
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.
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
 
inForkJoinPool() - Static method in class alluxio.concurrent.jsr.ForkJoinTask
Returns true if the current thread is a ForkJoinWorkerThread executing as a ForkJoinPool computation.
init(CopycatServer) - Method in class alluxio.master.journal.raft.RaftPrimarySelector
 
initConfiguration(String) - Method in class alluxio.master.AbstractLocalAlluxioCluster
Creates a default ServerConfiguration for testing.
initConfiguration(String) - Method in class alluxio.master.LocalAlluxioCluster
 
initConfiguration(String) - Method in class alluxio.master.MultiMasterLocalAlluxioCluster
 
initCounterKeys() - Method in class alluxio.master.metrics.MetricsStore
Inits the metrics store.
initFromBackup(InputStream) - Method in class alluxio.master.BackupManager
Restores master state from the specified backup.
initialize(PageStoreOptions) - Static method in interface alluxio.client.file.cache.PageStore
Initializes a page store at the configured location.
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(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
 
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;
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.
initiateOrCompleteMultipartUpload(String, String, String, Long) - Method in class alluxio.proxy.s3.S3RestServiceHandler
 
Initiating_VALUE - Static variable in enum alluxio.grpc.BackupState
Initiating = 2;
initReportFile() - Static method in class alluxio.checker.CheckerUtils
 
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
 
InodeCounter - Class in alluxio.master.file.meta
A checkpointed atomic long.
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
 
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.
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.
InodeTreeBufferedIterator(InodeStore, InodeDirectory) - Constructor for class alluxio.master.file.meta.InodeTreeBufferedIterator
Creates buffered iterator.
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(String) - Method in class alluxio.conf.path.TrieNode
Inserts a path into the trie.
insert(Inode) - 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.
install(SnapshotReader) - Method in class alluxio.master.journal.raft.JournalStateMachine
 
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.GrpcConnectionPool
 
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 variable in class alluxio.time.ThreadSleeper
 
INSTANCE - Static variable in class alluxio.uri.NoAuthority
 
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(AlluxioConfiguration) - Constructor for class alluxio.conf.InstancedConfiguration
Creates a new instance of InstancedConfiguration.
instant() - Method in class alluxio.clock.ElapsedTimeClock
 
instant() - Method in class alluxio.clock.SystemClock
 
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, OpenFilePOptions, AlluxioConfiguration) - Constructor for class alluxio.client.file.options.InStreamOptions
Creates with given OpenFilePOptions instance.
INT - Static variable in class alluxio.job.plan.transform.HiveConstants.Types
Hive int type.
intAsUnsignedByteValue(int) - Static method in class alluxio.util.io.BufferUtils
Gets the unsigned byte value of an integer.
INTEGRATION_MASTER_RESOURCE_CPU - Static variable in class alluxio.conf.PropertyKey
 
INTEGRATION_MASTER_RESOURCE_CPU - Static variable in class alluxio.conf.PropertyKey.Name
 
INTEGRATION_MASTER_RESOURCE_MEM - Static variable in class alluxio.conf.PropertyKey
 
INTEGRATION_MASTER_RESOURCE_MEM - Static variable in class alluxio.conf.PropertyKey.Name
 
INTEGRATION_MESOS_ALLUXIO_JAR_URL - Static variable in class alluxio.conf.PropertyKey
 
INTEGRATION_MESOS_ALLUXIO_JAR_URL - Static variable in class alluxio.conf.PropertyKey.Name
 
INTEGRATION_MESOS_ALLUXIO_MASTER_NAME - Static variable in class alluxio.conf.PropertyKey
 
INTEGRATION_MESOS_ALLUXIO_MASTER_NAME - Static variable in class alluxio.conf.PropertyKey.Name
 
INTEGRATION_MESOS_ALLUXIO_MASTER_NODE_COUNT - Static variable in class alluxio.conf.PropertyKey
 
INTEGRATION_MESOS_ALLUXIO_MASTER_NODE_COUNT - Static variable in class alluxio.conf.PropertyKey.Name
 
INTEGRATION_MESOS_ALLUXIO_WORKER_NAME - Static variable in class alluxio.conf.PropertyKey
 
INTEGRATION_MESOS_ALLUXIO_WORKER_NAME - Static variable in class alluxio.conf.PropertyKey.Name
 
INTEGRATION_MESOS_JDK_PATH - Static variable in class alluxio.conf.PropertyKey
 
INTEGRATION_MESOS_JDK_PATH - Static variable in class alluxio.conf.PropertyKey.Name
 
INTEGRATION_MESOS_JDK_URL - Static variable in class alluxio.conf.PropertyKey
 
INTEGRATION_MESOS_JDK_URL - Static variable in class alluxio.conf.PropertyKey.Name
 
INTEGRATION_MESOS_PRINCIPAL - Static variable in class alluxio.conf.PropertyKey
 
INTEGRATION_MESOS_PRINCIPAL - Static variable in class alluxio.conf.PropertyKey.Name
 
INTEGRATION_MESOS_ROLE - Static variable in class alluxio.conf.PropertyKey
 
INTEGRATION_MESOS_ROLE - Static variable in class alluxio.conf.PropertyKey.Name
 
INTEGRATION_MESOS_SECRET - Static variable in class alluxio.conf.PropertyKey
 
INTEGRATION_MESOS_SECRET - Static variable in class alluxio.conf.PropertyKey.Name
 
INTEGRATION_MESOS_USER - Static variable in class alluxio.conf.PropertyKey
 
INTEGRATION_MESOS_USER - Static variable in class alluxio.conf.PropertyKey.Name
 
INTEGRATION_WORKER_RESOURCE_CPU - Static variable in class alluxio.conf.PropertyKey
 
INTEGRATION_WORKER_RESOURCE_CPU - Static variable in class alluxio.conf.PropertyKey.Name
 
INTEGRATION_WORKER_RESOURCE_MEM - Static variable in class alluxio.conf.PropertyKey
 
INTEGRATION_WORKER_RESOURCE_MEM - Static variable in class alluxio.conf.PropertyKey.Name
 
INTEGRATION_YARN_WORKERS_PER_HOST_MAX - Static variable in class alluxio.conf.PropertyKey
 
INTEGRATION_YARN_WORKERS_PER_HOST_MAX - Static variable in class alluxio.conf.PropertyKey.Name
 
intercept(ClientInterceptor) - Method in class alluxio.grpc.GrpcChannel
Intercepts the channel with given interceptor.
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(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.ClientIpAddressInjector
 
interceptChannel(ClientInterceptor) - Method in class alluxio.grpc.GrpcConnection
Registers interceptor to the channel.
INTERNAL_ERROR - Static variable in class alluxio.proxy.s3.S3ErrorCode
 
INTERNAL_ERROR - Static variable in class alluxio.proxy.s3.S3ErrorCode.Name
 
INTERNAL_SESSION_ID_BASE - Static variable in class alluxio.Sessions
 
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.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.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.BlockStoreLocationProto.Builder
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.BlockStoreLocationProto
 
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.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.Command.Builder
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.Command
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.CommitBlockInUfsPOptions.Builder
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.CommitBlockInUfsPOptions
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.CommitBlockInUfsPRequest.Builder
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.CommitBlockInUfsPRequest
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.CommitBlockInUfsPResponse.Builder
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.CommitBlockInUfsPResponse
 
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.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.CreateLocalBlockRequest.Builder
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.CreateLocalBlockRequest
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.CreateLocalBlockResponse.Builder
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.CreateLocalBlockResponse
 
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.ExistsPOptions.Builder
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.ExistsPOptions
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.FileBlockInfo.Builder
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.FileBlockInfo
 
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.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.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.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.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.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.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.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.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.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.GetSyncPathListPRequest.Builder
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.GetSyncPathListPRequest
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.GetSyncPathListPResponse.Builder
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.GetSyncPathListPResponse
 
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.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.JobServiceSummary.Builder
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.JobServiceSummary
 
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.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.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.LoadMetadataPOptions.Builder
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.LoadMetadataPOptions
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.LocalityTier.Builder
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.LocalityTier
 
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.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.NetAddress.Builder
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.NetAddress
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.OpenFilePOptions.Builder
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.OpenFilePOptions
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.OpenLocalBlockRequest.Builder
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.OpenLocalBlockRequest
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.OpenLocalBlockResponse.Builder
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.OpenLocalBlockResponse
 
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.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.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.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.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.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.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.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.StartSyncPOptions.Builder
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.StartSyncPOptions
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.StartSyncPRequest.Builder
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.StartSyncPRequest
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.StartSyncPResponse.Builder
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.StartSyncPResponse
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.StatusSummary.Builder
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.StatusSummary
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.StopSyncPOptions.Builder
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.StopSyncPOptions
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.StopSyncPRequest.Builder
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.StopSyncPRequest
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.StopSyncPResponse.Builder
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.StopSyncPResponse
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.StorageList.Builder
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.StorageList
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.SyncPointInfo.Builder
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.SyncPointInfo
 
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.TieredIdentity.Builder
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.TieredIdentity
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.TierList.Builder
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.TierList
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.TransportMessage.Builder
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.TransportMessage
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.UfsInfo.Builder
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.UfsInfo
 
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.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.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.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.CreateUfsBlockOptions.Builder
 
internalGetFieldAccessorTable() - Method in class alluxio.proto.dataserver.Protocol.CreateUfsBlockOptions
 
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.OpenUfsBlockOptions.Builder
 
internalGetFieldAccessorTable() - Method in class alluxio.proto.dataserver.Protocol.OpenUfsBlockOptions
 
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.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.Journal.JournalEntry.Builder
 
internalGetFieldAccessorTable() - Method in class alluxio.proto.journal.Journal.JournalEntry
 
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.Table.AddTableEntry.Builder
 
internalGetFieldAccessorTable() - Method in class alluxio.proto.journal.Table.AddTableEntry
 
internalGetFieldAccessorTable() - Method in class alluxio.proto.journal.Table.AddTransformJobInfoEntry.Builder
 
internalGetFieldAccessorTable() - Method in class alluxio.proto.journal.Table.AddTransformJobInfoEntry
 
internalGetFieldAccessorTable() - Method in class alluxio.proto.journal.Table.AttachDbEntry.Builder
 
internalGetFieldAccessorTable() - Method in class alluxio.proto.journal.Table.AttachDbEntry
 
internalGetFieldAccessorTable() - Method in class alluxio.proto.journal.Table.CompleteTransformTableEntry.Builder
 
internalGetFieldAccessorTable() - Method in class alluxio.proto.journal.Table.CompleteTransformTableEntry
 
internalGetFieldAccessorTable() - Method in class alluxio.proto.journal.Table.DetachDbEntry.Builder
 
internalGetFieldAccessorTable() - Method in class alluxio.proto.journal.Table.DetachDbEntry
 
internalGetFieldAccessorTable() - Method in class alluxio.proto.journal.Table.RemoveTableEntry.Builder
 
internalGetFieldAccessorTable() - Method in class alluxio.proto.journal.Table.RemoveTableEntry
 
internalGetFieldAccessorTable() - Method in class alluxio.proto.journal.Table.RemoveTransformJobInfoEntry.Builder
 
internalGetFieldAccessorTable() - Method in class alluxio.proto.journal.Table.RemoveTransformJobInfoEntry
 
internalGetFieldAccessorTable() - Method in class alluxio.proto.journal.Table.UpdateDatabaseInfoEntry.Builder
 
internalGetFieldAccessorTable() - Method in class alluxio.proto.journal.Table.UpdateDatabaseInfoEntry
 
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.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.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.RegisterWorkerPRequest.Builder
 
internalGetMapField(int) - Method in class alluxio.grpc.RegisterWorkerPRequest
 
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.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.journal.Table.AddTableEntry.Builder
 
internalGetMapField(int) - Method in class alluxio.proto.journal.Table.AddTableEntry
 
internalGetMapField(int) - Method in class alluxio.proto.journal.Table.AddTransformJobInfoEntry.Builder
 
internalGetMapField(int) - Method in class alluxio.proto.journal.Table.AddTransformJobInfoEntry
 
internalGetMapField(int) - Method in class alluxio.proto.journal.Table.AttachDbEntry.Builder
 
internalGetMapField(int) - Method in class alluxio.proto.journal.Table.AttachDbEntry
 
internalGetMapField(int) - Method in class alluxio.proto.journal.Table.CompleteTransformTableEntry.Builder
 
internalGetMapField(int) - Method in class alluxio.proto.journal.Table.CompleteTransformTableEntry
 
internalGetMapField(int) - Method in class alluxio.proto.journal.Table.UpdateDatabaseInfoEntry.Builder
 
internalGetMapField(int) - Method in class alluxio.proto.journal.Table.UpdateDatabaseInfoEntry
 
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.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.RegisterWorkerPRequest.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.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.journal.Table.AddTableEntry.Builder
 
internalGetMutableMapField(int) - Method in class alluxio.proto.journal.Table.AddTransformJobInfoEntry.Builder
 
internalGetMutableMapField(int) - Method in class alluxio.proto.journal.Table.AttachDbEntry.Builder
 
internalGetMutableMapField(int) - Method in class alluxio.proto.journal.Table.CompleteTransformTableEntry.Builder
 
internalGetMutableMapField(int) - Method in class alluxio.proto.journal.Table.UpdateDatabaseInfoEntry.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.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.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.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.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.shared.Acl.AclAction
 
internalGetValueMap() - Static method in enum alluxio.proto.shared.Acl.AclEntryType
 
internalGetValueMap() - Static method in enum alluxio.proto.status.Status.PStatus
 
interruptCycleTicking() - Method in class alluxio.master.StateLockManager
 
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.proxy.s3.S3ErrorCode
 
INVALID_BUCKET_NAME - Static variable in class alluxio.proxy.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_FILE_ID - Static variable in class alluxio.util.IdUtils
 
INVALID_LOCK_ID - Static variable in class alluxio.worker.block.BlockLockManager
Invalid lock ID.
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.proxy.s3.S3ErrorCode
 
INVALID_TXID - Static variable in class alluxio.SyncInfo
 
INVALID_UFS_FINGERPRINT - Static variable in class alluxio.Constants
 
INVALID_WORKER_ID - Static variable in class alluxio.util.IdUtils
 
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
 
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
 
invalidate(CachedSeekableInputStream) - Method in class alluxio.worker.block.UfsInputStreamManager
Invalidates an input stream from the 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.
InvalidJournalEntryException - Exception in alluxio.exception
The exception thrown when we have seen an invalid journal entry.
InvalidJournalEntryException(String) - Constructor for exception alluxio.exception.InvalidJournalEntryException
Constructs a new exception with the specified detail message.
InvalidJournalEntryException(String, Throwable) - Constructor for exception alluxio.exception.InvalidJournalEntryException
Constructs a new exception with the specified detail message and cause.
InvalidJournalEntryException(ExceptionMessage, Object...) - Constructor for exception alluxio.exception.InvalidJournalEntryException
Constructs a new exception with the specified exception message and multiple parameters.
InvalidJournalEntryException(ExceptionMessage, Throwable, Object...) - Constructor for exception alluxio.exception.InvalidJournalEntryException
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.
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(String, Throwable) - Constructor for exception alluxio.exception.InvalidWorkerStateException
Constructs a new exception with the specified detail message and cause.
InvalidWorkerStateException(ExceptionMessage, Object...) - Constructor for exception alluxio.exception.InvalidWorkerStateException
Constructs a new exception with the specified exception message and multiple parameters.
InvalidWorkerStateException(ExceptionMessage, Throwable, Object...) - Constructor for exception alluxio.exception.InvalidWorkerStateException
Constructs a new exception with the specified exception message, the cause 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.
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(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.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.
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.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
 
isAbsent(AlluxioURI) - Method in class alluxio.master.file.meta.AsyncUfsAbsentPathCache
 
isAbsent(AlluxioURI) - Method in class alluxio.master.file.meta.NoopUfsAbsentPathCache
 
isAbsent(AlluxioURI) - Method in interface alluxio.master.file.meta.UfsAbsentPathCache
Returns true if the given path is absent, 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.
isAddressReachable(String, int) - Static method in class alluxio.cli.validation.Utils
Validates whether a network address is reachable.
isAIX() - Static method in class alluxio.util.OSUtils
 
isAlluxioRunning(String) - Static method in class alluxio.cli.validation.Utils
Checks whether an Alluxio service is running.
isAncestorOf(AlluxioURI) - Method in class alluxio.AlluxioURI
Returns true if the current AlluxioURI is an ancestor of another AlluxioURI.
isAsync() - Method in enum alluxio.client.WriteType
 
isAsyncPersist() - Method in enum alluxio.client.UnderStorageType
 
isAuthenticated() - Method in class alluxio.grpc.GrpcService
 
isAuthenticated() - Method in class alluxio.security.authentication.AuthenticatedChannelClientDriver
 
isAuthenticationEnabled(AlluxioConfiguration) - Static method in class alluxio.util.SecurityUtils
Checks if authentication is enabled.
isAuthorizationEnabled(AlluxioConfiguration) - Static method in class alluxio.util.SecurityUtils
Checks if authorization is enabled.
isBackup() - Method in class alluxio.master.backcompat.Journal
 
isBlockEvictable(long) - Method in class alluxio.worker.block.BlockMetadataEvictorView
Tests if the block is evictable.
isBlockLocked(long) - Method in class alluxio.worker.block.BlockMetadataEvictorView
Tests if the block is locked.
isBlockMarked(long) - Method in class alluxio.worker.block.BlockMetadataEvictorView
Tests if the block is marked to move out of its current dir in this view.
isBlockPinned(long) - Method in class alluxio.worker.block.BlockMetadataEvictorView
Tests if the block is pinned either explicitly or because it is scheduled for async persist.
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.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.CompositeCallTracker
 
isCancelled() - Method in class alluxio.master.file.contexts.GrpcCallTracker
 
isCancelled() - Method in class alluxio.master.file.contexts.OperationContext
TODO(ggezer): Make the call-tracker infra note the source of cancellation.
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.BaseFileSystem
 
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 interface alluxio.Client
 
isClosed() - Method in class alluxio.hadoop.AlluxioHdfsFileSystem
 
isClosed() - Method in interface alluxio.worker.block.io.BlockReader
 
isClosed() - Method in class alluxio.worker.block.io.LocalFileBlockReader
 
isClosed() - Method in class alluxio.worker.block.RemoteBlockReader
 
isClosed() - Method in class alluxio.worker.block.UnderFileSystemBlockReader
 
isClosed() - Method in interface alluxio.worker.DataServer
Checks if the DataServer is closed.
isClosed() - Method in class alluxio.worker.grpc.GrpcDataServer
 
isClosedFromRemote() - Method in class alluxio.client.block.stream.GrpcBlockingStream
 
isClusterAggregated() - Method in class alluxio.metrics.MetricKey
 
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.
isCsv(String) - Static method in enum alluxio.job.plan.transform.Format
 
isDataReaderActive() - Method in class alluxio.worker.grpc.ReadRequestContext
 
isDebug() - Method in class alluxio.fuse.AlluxioFuseOptions
 
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
 
isDeleteSource() - Method in class alluxio.job.plan.migrate.MigrateConfig
 
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.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() - 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
 
isDirectory(String) - Method in class alluxio.underfs.web.WebUnderFileSystem
 
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
 
isDoneUnsafe() - Method in class alluxio.worker.grpc.ReadRequestContext
 
isDoneUnsafe() - Method in class alluxio.worker.grpc.WriteRequestContext
 
isEC2() - Static method in class alluxio.util.EnvironmentUtils
Utility to detect the EC2 deployment environment.
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.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() - Method in class alluxio.worker.block.evictor.EvictionPlan
Whether the plan is empty, an empty plan means both toMove and toEvict are empty, also, an empty plan indicates no action (move or evict) needs to be taken to meet the requirement.
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 interface alluxio.master.MasterFactory
 
isEnabled() - Method in class alluxio.master.meta.MetaMasterFactory
 
isEnabled() - Method in class alluxio.master.metrics.MetricsMasterFactory
 
isEnabled() - Method in class alluxio.master.table.TableMasterFactory
 
isEnabled() - Method in class alluxio.worker.block.BlockWorkerFactory
 
isEnabled() - Method in interface alluxio.worker.WorkerFactory
 
isEnsureAtomic() - Method in class alluxio.underfs.options.CreateOptions
 
isEof() - Method in class alluxio.worker.grpc.ReadRequestContext
 
isErrorEnabled() - Method in class alluxio.util.logging.SamplingLogger
 
isErrorEnabled(Marker) - Method in class alluxio.util.logging.SamplingLogger
 
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
 
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.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
 
isFile(String) - Method in class alluxio.underfs.web.WebUnderFileSystem
 
isFileTest() - Method in class alluxio.examples.UnderFileSystemCommonOperations
Test for checking file is actual file.
isFinished() - Method in enum alluxio.job.wire.Status
 
isFinished() - Method in class alluxio.wire.BackupStatus
 
isFolder() - Method in class alluxio.client.file.URIStatus
 
isFolder() - Method in class alluxio.wire.FileInfo
 
isForceSync() - Method in class alluxio.SyncInfo
returns true if this sync should happen on the entire directory.
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
 
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.
isGzipped(String) - Static method in enum alluxio.job.plan.transform.Format
 
isHaMode(AlluxioConfiguration) - Static method in class alluxio.util.ConfigurationUtils
 
isHdfs(UnderFileSystem) - Static method in class alluxio.util.UnderFileSystemUtils
 
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(T) - Method in class alluxio.resource.DynamicResourcePool
Checks whether a resource is healthy or not.
isHealthy(IMetaStoreClient) - Method in class alluxio.table.under.hive.util.HiveClientPool
 
isHealthy() - Method in class alluxio.worker.job.command.AlwaysHealthyJobWorkerHealthReporter
 
isHealthy() - Method in class alluxio.worker.job.command.JobWorkerHealthReporter
Determines whether the system is healthy from all the metrics it has collected.
isHidden() - Method in class alluxio.conf.PropertyKey
 
isHiveLayout(Layout) - Static method in class alluxio.table.ProtoUtils
 
isIgnoredSiteProperty() - Method in class alluxio.conf.PropertyKey
 
isInfoEnabled() - Method in class alluxio.util.logging.SamplingLogger
 
isInfoEnabled(Marker) - Method in class alluxio.util.logging.SamplingLogger
 
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.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.BlockStoreLocationProto.Builder
 
isInitialized() - Method in class alluxio.grpc.BlockStoreLocationProto
 
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.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.Command.Builder
 
isInitialized() - Method in class alluxio.grpc.Command
 
isInitialized() - Method in class alluxio.grpc.CommitBlockInUfsPOptions.Builder
 
isInitialized() - Method in class alluxio.grpc.CommitBlockInUfsPOptions
 
isInitialized() - Method in class alluxio.grpc.CommitBlockInUfsPRequest.Builder
 
isInitialized() - Method in class alluxio.grpc.CommitBlockInUfsPRequest
 
isInitialized() - Method in class alluxio.grpc.CommitBlockInUfsPResponse.Builder
 
isInitialized() - Method in class alluxio.grpc.CommitBlockInUfsPResponse
 
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.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.CreateLocalBlockRequest.Builder
 
isInitialized() - Method in class alluxio.grpc.CreateLocalBlockRequest
 
isInitialized() - Method in class alluxio.grpc.CreateLocalBlockResponse.Builder
 
isInitialized() - Method in class alluxio.grpc.CreateLocalBlockResponse
 
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.ExistsPOptions.Builder
 
isInitialized() - Method in class alluxio.grpc.ExistsPOptions
 
isInitialized() - Method in class alluxio.grpc.FileBlockInfo.Builder
 
isInitialized() - Method in class alluxio.grpc.FileBlockInfo
 
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.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.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.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.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.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.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.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.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.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.GetSyncPathListPRequest.Builder
 
isInitialized() - Method in class alluxio.grpc.GetSyncPathListPRequest
 
isInitialized() - Method in class alluxio.grpc.GetSyncPathListPResponse.Builder
 
isInitialized() - Method in class alluxio.grpc.GetSyncPathListPResponse
 
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.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.JobServiceSummary.Builder
 
isInitialized() - Method in class alluxio.grpc.JobServiceSummary
 
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.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.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.LoadMetadataPOptions.Builder
 
isInitialized() - Method in class alluxio.grpc.LoadMetadataPOptions
 
isInitialized() - Method in class alluxio.grpc.LocalityTier.Builder
 
isInitialized() - Method in class alluxio.grpc.LocalityTier
 
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.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.NetAddress.Builder
 
isInitialized() - Method in class alluxio.grpc.NetAddress
 
isInitialized() - Method in class alluxio.grpc.OpenFilePOptions.Builder
 
isInitialized() - Method in class alluxio.grpc.OpenFilePOptions
 
isInitialized() - Method in class alluxio.grpc.OpenLocalBlockRequest.Builder
 
isInitialized() - Method in class alluxio.grpc.OpenLocalBlockRequest
 
isInitialized() - Method in class alluxio.grpc.OpenLocalBlockResponse.Builder
 
isInitialized() - Method in class alluxio.grpc.OpenLocalBlockResponse
 
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.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.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.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.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.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.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.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.StartSyncPOptions.Builder
 
isInitialized() - Method in class alluxio.grpc.StartSyncPOptions
 
isInitialized() - Method in class alluxio.grpc.StartSyncPRequest.Builder
 
isInitialized() - Method in class alluxio.grpc.StartSyncPRequest
 
isInitialized() - Method in class alluxio.grpc.StartSyncPResponse.Builder
 
isInitialized() - Method in class alluxio.grpc.StartSyncPResponse
 
isInitialized() - Method in class alluxio.grpc.StatusSummary.Builder
 
isInitialized() - Method in class alluxio.grpc.StatusSummary
 
isInitialized() - Method in class alluxio.grpc.StopSyncPOptions.Builder
 
isInitialized() - Method in class alluxio.grpc.StopSyncPOptions
 
isInitialized() - Method in class alluxio.grpc.StopSyncPRequest.Builder
 
isInitialized() - Method in class alluxio.grpc.StopSyncPRequest
 
isInitialized() - Method in class alluxio.grpc.StopSyncPResponse.Builder
 
isInitialized() - Method in class alluxio.grpc.StopSyncPResponse
 
isInitialized() - Method in class alluxio.grpc.StorageList.Builder
 
isInitialized() - Method in class alluxio.grpc.StorageList
 
isInitialized() - Method in class alluxio.grpc.SyncPointInfo.Builder
 
isInitialized() - Method in class alluxio.grpc.SyncPointInfo
 
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.TieredIdentity.Builder
 
isInitialized() - Method in class alluxio.grpc.TieredIdentity
 
isInitialized() - Method in class alluxio.grpc.TierList.Builder
 
isInitialized() - Method in class alluxio.grpc.TierList
 
isInitialized() - Method in class alluxio.grpc.TransportMessage.Builder
 
isInitialized() - Method in class alluxio.grpc.TransportMessage
 
isInitialized() - Method in class alluxio.grpc.UfsInfo.Builder
 
isInitialized() - Method in class alluxio.grpc.UfsInfo
 
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.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.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.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.CreateUfsBlockOptions.Builder
 
isInitialized() - Method in class alluxio.proto.dataserver.Protocol.CreateUfsBlockOptions
 
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.OpenUfsBlockOptions.Builder
 
isInitialized() - Method in class alluxio.proto.dataserver.Protocol.OpenUfsBlockOptions
 
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.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.Journal.JournalEntry.Builder
 
isInitialized() - Method in class alluxio.proto.journal.Journal.JournalEntry
 
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.Table.AddTableEntry.Builder
 
isInitialized() - Method in class alluxio.proto.journal.Table.AddTableEntry
 
isInitialized() - Method in class alluxio.proto.journal.Table.AddTransformJobInfoEntry.Builder
 
isInitialized() - Method in class alluxio.proto.journal.Table.AddTransformJobInfoEntry
 
isInitialized() - Method in class alluxio.proto.journal.Table.AttachDbEntry.Builder
 
isInitialized() - Method in class alluxio.proto.journal.Table.AttachDbEntry
 
isInitialized() - Method in class alluxio.proto.journal.Table.CompleteTransformTableEntry.Builder
 
isInitialized() - Method in class alluxio.proto.journal.Table.CompleteTransformTableEntry
 
isInitialized() - Method in class alluxio.proto.journal.Table.DetachDbEntry.Builder
 
isInitialized() - Method in class alluxio.proto.journal.Table.DetachDbEntry
 
isInitialized() - Method in class alluxio.proto.journal.Table.RemoveTableEntry.Builder
 
isInitialized() - Method in class alluxio.proto.journal.Table.RemoveTableEntry
 
isInitialized() - Method in class alluxio.proto.journal.Table.RemoveTransformJobInfoEntry.Builder
 
isInitialized() - Method in class alluxio.proto.journal.Table.RemoveTransformJobInfoEntry
 
isInitialized() - Method in class alluxio.proto.journal.Table.UpdateDatabaseInfoEntry.Builder
 
isInitialized() - Method in class alluxio.proto.journal.Table.UpdateDatabaseInfoEntry
 
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.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
 
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.master.block.meta.MasterBlockInfo
 
isInTier(String) - Method in class alluxio.util.webui.UIFileBlockInfo
Is in tier boolean.
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
 
isLinux() - Static method in class alluxio.util.OSUtils
 
isLocal(UnderFileSystem) - Static method in class alluxio.util.UnderFileSystemUtils
 
isLocalFilesystem(String) - Static method in class alluxio.util.URIUtils
 
isLocalHost(WorkerNetAddress, AlluxioConfiguration) - Static method in class alluxio.util.CommonUtils
 
isMacOS() - Static method in class alluxio.util.OSUtils
 
isMarkedToMoveOut(long) - Method in class alluxio.worker.block.meta.StorageDirEvictorView
Returns an indication whether the given block is marked to be moved out.
isMetadataLoad() - Method in class alluxio.master.file.contexts.CreatePathContext
 
isMountingPoint(String, String[]) - Static method in class alluxio.cli.validation.Utils
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
 
isNested(String) - Method in class alluxio.conf.PropertyKey
 
isNettyEpollAvailable() - Static method in class alluxio.util.network.NettyUtils
 
isNoCache() - Method in class alluxio.worker.block.meta.UnderFileSystemBlockMeta
 
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
 
isOss(UnderFileSystem) - Static method in class alluxio.util.UnderFileSystemUtils
 
isOverwrite() - Method in class alluxio.job.plan.migrate.MigrateConfig
 
isOverwrite() - Method in class alluxio.job.plan.persist.PersistConfig
 
isParquet(String) - Static method in enum alluxio.job.plan.transform.Format
 
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.grpc.BlockReadRequest
 
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.worker.grpc.BlockReadRequest
 
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.worker.grpc.BlockReadRequest
 
isQuiescent() - Method in class alluxio.concurrent.jsr.ForkJoinPool
Returns true if all worker threads are currently idle.
isReadOnly() - Method in class alluxio.underfs.UnderFileSystemConfiguration
 
isReadWriteTypeInconsistent(String) - Static method in class alluxio.job.plan.transform.format.csv.CsvUtils
 
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
 
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.
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
 
isS3(UnderFileSystem) - Static method in class alluxio.util.UnderFileSystemUtils
 
isSecurityEnabled(AlluxioConfiguration) - Static method in class alluxio.util.SecurityUtils
Checks if security is enabled.
isSeekable() - Method in class alluxio.concurrent.ManagedBlockingUfsForwarder
 
isSeekable() - Method in class alluxio.underfs.BaseUnderFileSystem
 
isSeekable() - Method in 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
 
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.MasterProcess
 
isServing() - Method in class alluxio.proxy.ProxyHealthCheckClient
 
isServing(String, int) - Static method in class alluxio.util.network.NetworkAddressUtils
 
isSet(PropertyKey) - Method in interface alluxio.conf.AlluxioConfiguration
Checks if the configuration contains a value for the given key.
isSet(PropertyKey) - Method in class alluxio.conf.AlluxioProperties
Checks if there is a value set for the given key.
isSet(PropertyKey) - Method in class alluxio.conf.InstancedConfiguration
 
isSet(PropertyKey) - Method in class alluxio.conf.path.SpecificPathConfiguration
 
isSet(PropertyKey) - Static method in class alluxio.conf.ServerConfiguration
Checks if the configuration contains a value for the given key.
isSetByUser(PropertyKey) - Method in interface alluxio.conf.AlluxioConfiguration
 
isSetByUser(PropertyKey) - Method in class alluxio.conf.AlluxioProperties
 
isSetByUser(PropertyKey) - Method in class alluxio.conf.InstancedConfiguration
 
isSetByUser(PropertyKey) - Method in class alluxio.conf.path.SpecificPathConfiguration
 
isShared() - Method in class alluxio.underfs.UnderFileSystemConfiguration
 
isShortCircuit() - Method in class alluxio.client.block.stream.BlockInStream
 
isShortCircuit() - Method in interface alluxio.client.block.stream.DataReader.Factory
 
isShortCircuit() - Method in class alluxio.client.block.stream.GrpcDataReader.Factory
 
isShortCircuit() - Method in class alluxio.client.block.stream.LocalFileDataReader.Factory
 
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.util.executor.ControllableScheduler
 
isSnapshotting() - Method in class alluxio.master.journal.raft.JournalStateMachine
 
isStarted() - Method in class alluxio.util.JvmPauseMonitor
 
isStorageDirAccessible(String) - Static method in class alluxio.util.io.FileUtils
Checks if a storage directory path is accessible.
isStore() - Method in enum alluxio.client.AlluxioStorageType
 
isSuspended() - Method in class alluxio.master.journal.raft.BufferedJournalApplier
 
isSwift(UnderFileSystem) - Static method in class alluxio.util.UnderFileSystemUtils
 
isSyncPersist() - Method in enum alluxio.client.UnderStorageType
 
isSyncPoint(AlluxioURI) - Method in class alluxio.master.file.activesync.ActiveSyncManager
 
isTemporaryFileName(String) - Static method in class alluxio.util.io.PathUtils
Determines whether the given path is a temporary file name generated by Alluxio.
isTenantSupplied() - Method in class alluxio.underfs.swift.KeystoneV3Access
 
isTerminated() - Method in class alluxio.concurrent.jsr.ForkJoinPool
Returns true if all tasks have completed following shut down.
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
 
isTransformed(String) - Method in class alluxio.master.table.Partition
 
isTruncated() - Method in class alluxio.proxy.s3.ListBucketResult
 
isTruncated() - Method in class alluxio.proxy.s3.ListPartsResult
 
isTruncatedMessageException(IOException) - Static method in class alluxio.util.proto.ProtoUtils
Checks whether the exception is an InvalidProtocolBufferException thrown because of a truncated message.
isUnderSyncPoint(AlluxioURI) - Method in class alluxio.master.file.activesync.ActiveSyncManager
Check if a URI is actively synced.
isUnique() - Method in class alluxio.collections.IndexDefinition
 
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(String) - Static method in class alluxio.metrics.MetricKey
 
isValid() - Method in class alluxio.underfs.Fingerprint
Checks if the fingerprint object was generated from an INVALID_UFS_FINGERPRINT.
isWarnEnabled() - Method in class alluxio.util.logging.SamplingLogger
 
isWarnEnabled(Marker) - Method in class alluxio.util.logging.SamplingLogger
 
isWeb(UnderFileSystem) - Static method in class alluxio.util.UnderFileSystemUtils
 
isWindows() - Static method in class alluxio.util.OSUtils
 
isWritable() - Method in class alluxio.master.journal.ufs.UfsJournal
 
isWrite() - Method in enum alluxio.master.file.meta.InodeTree.LockPattern
 
isWritingToLocal() - Method in class alluxio.worker.grpc.BlockWriteRequestContext
 
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
 
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.master.file.meta.LockedInodePathList
 
iterator() - Method in class alluxio.master.metastore.heap.HeapBlockStore
 
iterator() - Method in class alluxio.master.metastore.rocks.RocksBlockStore
 
iterator() - Method in class alluxio.master.metastore.rocks.RocksInodeStore
 

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_VENDOR_NAME - Static variable in class alluxio.util.OSUtils
The java vendor name used in this platform.
JmxSink - Class in alluxio.metrics.sink
A sink which listens for new metrics and exposes them as namespaces MBeans.
JmxSink(Properties, MetricRegistry) - Constructor for class alluxio.metrics.sink.JmxSink
Creates a new JmxSink with a Properties and MetricRegistry.
JOB_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.Table.AddTransformJobInfoEntry
 
JOB_JOURNAL_NAME - Static variable in class alluxio.Constants
 
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_WORKER_DETECTION - Static variable in class alluxio.heartbeat.HeartbeatContext
 
JOB_MASTER_LOST_WORKER_INTERVAL - Static variable in class alluxio.conf.PropertyKey
 
JOB_MASTER_LOST_WORKER_INTERVAL - Static variable in class alluxio.conf.PropertyKey.Name
 
JOB_MASTER_NAME - Static variable in class alluxio.Constants
 
JOB_MASTER_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_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_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
 
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.
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(String, Throwable) - Constructor for exception alluxio.exception.JobDoesNotExistException
Constructs a new exception with the specified detail message and cause.
JobDoesNotExistException(ExceptionMessage, Object...) - Constructor for exception alluxio.exception.JobDoesNotExistException
Constructs a new exception with the specified exception message and multiple parameters.
JobDoesNotExistException(ExceptionMessage, Throwable, Object...) - Constructor for exception alluxio.exception.JobDoesNotExistException
Constructs a new exception with the specified exception message, the cause and multiple parameters.
JobDoesNotExistException(long) - Constructor for exception alluxio.exception.JobDoesNotExistException
Constructs a new exception saying the specified job ID does not exist.
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.GetJobStatusPRequest
 
JOBID_FIELD_NUMBER - Static variable in class alluxio.grpc.RunPResponse
 
JOBID_FIELD_NUMBER - Static variable in class alluxio.grpc.RunTaskCommand
 
JobIdGenerator - Class in alluxio.job.meta
This class generates unique job ids.
JobIdGenerator() - Constructor for class alluxio.job.meta.JobIdGenerator
Creates a new instance.
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.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.
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.JobMasterClientServiceBlockingStub - Class in alluxio.grpc
This interface contains job master service endpoints for job service clients.
JobMasterClientServiceGrpc.JobMasterClientServiceFutureStub - Class in alluxio.grpc
This interface contains job master service endpoints for job service clients.
JobMasterClientServiceGrpc.JobMasterClientServiceImplBase - Class in alluxio.grpc
This interface contains job master service endpoints for job service clients.
JobMasterClientServiceGrpc.JobMasterClientServiceStub - Class in alluxio.grpc
This interface contains job master service endpoints for job service clients.
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
 
jobMasterHostConfigured(AlluxioConfiguration) - Static method in class alluxio.util.ConfigurationUtils
 
JobMasterProto - Class in alluxio.grpc
 
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.
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.JobMasterWorkerServiceBlockingStub - Class in alluxio.grpc
This interface contains job master service endpoints for job service workers.
JobMasterWorkerServiceGrpc.JobMasterWorkerServiceFutureStub - Class in alluxio.grpc
This interface contains job master service endpoints for job service workers.
JobMasterWorkerServiceGrpc.JobMasterWorkerServiceImplBase - Class in alluxio.grpc
This interface contains job master service endpoints for job service workers.
JobMasterWorkerServiceGrpc.JobMasterWorkerServiceStub - Class in alluxio.grpc
This interface contains job master service endpoints for job service workers.
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
 
JobPath - Class in alluxio.job.plan.transform.format
Implementation of Path that has a cache for getting file system.
JobPath(String, String, String) - Constructor for class alluxio.job.plan.transform.format.JobPath
Copy of the constructor in Path.
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.
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
 
JobShell - Class in alluxio.cli.job
Class for handling job command line inputs.
JobShell(InstancedConfiguration) - Constructor for class alluxio.cli.job.JobShell
Creates a new instance of JobShell.
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(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
 
JobWorkerHealthReporter - Class in alluxio.worker.job.command
The job worker health reporter.
JobWorkerHealthReporter() - Constructor for class alluxio.worker.job.command.JobWorkerHealthReporter
Default constructor.
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.
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: 51
Journal.JournalEntry.Builder - Class in alluxio.proto.journal
next available id: 51
Journal.JournalEntryOrBuilder - 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_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.
JournalCrashTest - Class in alluxio.cli
Class to perform Journal crash test.
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.
JournalEntryAssociation - Class in alluxio.master.journal
Association from journal entry to the master it applies to.
JournalEntryCommand - Class in alluxio.master.journal.raft
Command for writing an arbitrary journal entry.
JournalEntryCommand() - Constructor for class alluxio.master.journal.raft.JournalEntryCommand
No-arg constructor for use by Catalyst deserialization.
JournalEntryCommand(Journal.JournalEntry) - Constructor for class alluxio.master.journal.raft.JournalEntryCommand
Constructs a JournalEntryCommand for a journal entry.
JournalEntryIterable - Interface in alluxio.master.journal
Interface to get an iterator of Journal.JournalEntrys.
JournalEntryReplayable - Interface in alluxio.master.journal
Interface for classes which can replay journal entries.
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.
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.JournalMasterClientServiceBlockingStub - Class in alluxio.grpc
This interface contains journal master service endpoints for Alluxio clients.
JournalMasterClientServiceGrpc.JournalMasterClientServiceFutureStub - Class in alluxio.grpc
This interface contains journal master service endpoints for Alluxio clients.
JournalMasterClientServiceGrpc.JournalMasterClientServiceImplBase - Class in alluxio.grpc
This interface contains journal master service endpoints for Alluxio clients.
JournalMasterClientServiceGrpc.JournalMasterClientServiceStub - Class in alluxio.grpc
This interface contains journal master service endpoints for Alluxio clients.
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
 
JournalMasterProto - Class in alluxio.grpc
 
JournalOutputStream - Interface in alluxio.master.journalv0
This output stream writes Journal.JournalEntry objects to the journal.
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.
JournalStateMachine - Class in alluxio.master.journal.raft
A state machine for managing all of Alluxio's journaled state.
JournalStateMachine(Map<String, RaftJournal>, Supplier<Set<JournalSink>>) - 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.
JournalUpgrader - Class in alluxio.master.journal
Tool to upgrade journal from v0 to v1.
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.
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
 
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.
JvmSource - Class in alluxio.metrics.source
A Source which collects JVM metrics, including JVM memory usage, GC counts, GC times, etc.
JvmSource() - Constructor for class alluxio.metrics.source.JvmSource
Creates a new JvmSource and register all JVM metrics.

K

KB - Static variable in class alluxio.Constants
 
keepAliveTime(long, TimeUnit) - Method in class alluxio.grpc.GrpcServerBuilder
Sets the keep alive time.
keepAliveTimeout(long, TimeUnit) - Method in class alluxio.grpc.GrpcServerBuilder
Sets the keep alive timeout.
Key(Subject, AlluxioConfiguration) - Constructor for class alluxio.client.file.FileSystemCache.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
 
KEYS_OPTION_NAME - Static variable in class alluxio.cli.fsadmin.pathconf.RemoveCommand
 
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() - Method in class alluxio.conf.InstancedConfiguration
 
keySet() - Method in class alluxio.conf.path.SpecificPathConfiguration
 
keySet() - Static method in class alluxio.conf.ServerConfiguration
 
KeystoneV3Access - Class in alluxio.underfs.swift
Custom Access for Keystone V3 authentication.
KeystoneV3Access(String, String, String, String) - Constructor for class alluxio.underfs.swift.KeystoneV3Access
Construct a new instance of KeystoneV3Access.
KeystoneV3AccessProvider - Class in alluxio.underfs.swift
Custom AuthenticationMethod.AccessProvider for Keystone V3 authentication.
KeystoneV3AccessProvider(AccountConfig) - Constructor for class alluxio.underfs.swift.KeystoneV3AccessProvider
Create a new instance of KeystoneV3AccessProvider.
KODO_ACCESS_KEY - Static variable in class alluxio.conf.PropertyKey
 
KODO_ACCESS_KEY - Static variable in class alluxio.conf.PropertyKey.Name
 
KODO_DOWNLOAD_HOST - Static variable in class alluxio.conf.PropertyKey
 
KODO_DOWNLOAD_HOST - Static variable in class alluxio.conf.PropertyKey.Name
 
KODO_ENDPOINT - Static variable in class alluxio.conf.PropertyKey
 
KODO_ENDPOINT - Static variable in class alluxio.conf.PropertyKey.Name
 
KODO_SECRET_KEY - Static variable in class alluxio.conf.PropertyKey
 
KODO_SECRET_KEY - Static variable in class alluxio.conf.PropertyKey.Name
 
KodoClient - Class in alluxio.underfs.kodo
Client or Kodo under file system.
KodoClient(Auth, String, String, String, Configuration, OkHttpClient) - Constructor for class alluxio.underfs.kodo.KodoClient
Creates a new instance of KodoClient.
KodoInputStream - Class in alluxio.underfs.kodo
A stream for reading a file from Kodo.
KodoOutputStream - Class in alluxio.underfs.kodo
A stream for writing a file into Qiniu.
KodoOutputStream(String, KodoClient, List<String>) - Constructor for class alluxio.underfs.kodo.KodoOutputStream
Creates a name instance of KodoOutputStream.
KodoUnderFileSystem - Class in alluxio.underfs.kodo
Qiniu Kodo UnderFileSystem implementation.
KodoUnderFileSystem(AlluxioURI, KodoClient, UnderFileSystemConfiguration) - Constructor for class alluxio.underfs.kodo.KodoUnderFileSystem
 
KodoUnderFileSystemFactory - Class in alluxio.underfs.kodo
Factory for creating KodoUnderFileSystem.
KodoUnderFileSystemFactory() - Constructor for class alluxio.underfs.kodo.KodoUnderFileSystemFactory
Constructs a new KodoUnderFileSystem.

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_TIER - Static variable in class alluxio.Constants
 
LASTACCESSTIMEMS_FIELD_NUMBER - Static variable in class alluxio.grpc.FileInfo
 
LASTCONTACTSEC_FIELD_NUMBER - Static variable in class alluxio.grpc.WorkerInfo
 
LastContactSecComparator() - Constructor for class alluxio.wire.WorkerInfo.LastContactSecComparator
LastContactSecComparator constructor.
LASTMODIFICATIONTIMEMS_FIELD_NUMBER - Static variable in class alluxio.grpc.FileInfo
 
LASTUPDATED_FIELD_NUMBER - Static variable in class alluxio.grpc.JobInfo
 
LASTUPDATED_FIELD_NUMBER - Static variable in class alluxio.grpc.JobWorkerHealth
 
launchPollingThread(long, long) - Method in class alluxio.master.file.activesync.ActiveSyncManager
Launches polling thread on a particular mount point with starting txId.
Layout - Class in alluxio.grpc.table
Protobuf type alluxio.grpc.table.Layout
Layout - Interface in alluxio.table.common
An interface for a table/partition 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_FIELD_NUMBER - Static variable in class alluxio.proto.journal.Table.AddTableEntry
 
LAYOUT_SPEC_FIELD_NUMBER - Static variable in class alluxio.grpc.table.Layout
 
LAYOUT_TYPE_FIELD_NUMBER - Static variable in class alluxio.grpc.table.Layout
 
LayoutFactory - Interface in alluxio.table.common
The layout factory interface.
LayoutOrBuilder - Interface in alluxio.grpc.table
 
LayoutRegistry - Class in alluxio.table.common
The registry of layout implementations.
LayoutRegistry() - Constructor for class alluxio.table.common.LayoutRegistry
Creates an instance.
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;
LeaderCommand - Class in alluxio.cli.fs.command
Prints the current leader master host name.
LeaderCommand(FileSystemContext) - Constructor for class alluxio.cli.fs.command.LeaderCommand
 
LeaderCommand - Class in alluxio.cli.job.command
Prints the current leader master host name.
LeaderCommand(FileSystemContext) - Constructor for class alluxio.cli.job.command.LeaderCommand
creates the job leader command.
LEADERMASTERADDRESS_FIELD_NUMBER - Static variable in class alluxio.grpc.MasterInfo
 
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.BlockInfo
 
LENGTH_FIELD_NUMBER - Static variable in class alluxio.grpc.CommitBlockInUfsPRequest
 
LENGTH_FIELD_NUMBER - Static variable in class alluxio.grpc.CommitBlockPRequest
 
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.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
 
LFUCacheEvictor - Class in alluxio.client.file.cache.evictor
LFU client-side cache eviction policy.
LFUCacheEvictor(AlluxioConfiguration) - Constructor for class alluxio.client.file.cache.evictor.LFUCacheEvictor
Required constructor.
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.
LINES_TO_SKIP - Static variable in class alluxio.job.plan.transform.HiveConstants
Number of lines to skip when reading from CSV.
list() - Method in interface alluxio.client.job.JobMasterClient
 
list() - Method in class alluxio.client.job.RetryHandlingJobMasterClient
 
LIST - Static variable in class alluxio.job.ServiceConstants
 
list() - Method in class alluxio.master.job.JobMaster
 
list() - 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) - 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.JobMasterClientServiceImplBase
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
 
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.proxy.s3
The options for list bucket operation.
ListBucketResult - Class in alluxio.proxy.s3
Get bucket result defined in http://docs.aws.amazon.com/AmazonS3/latest/API/v2-RESTBucketGET.html It will be encoded into an XML string to be returned as a response for the REST call.
ListBucketResult() - Constructor for class alluxio.proxy.s3.ListBucketResult
Creates an ListBucketResult.
ListBucketResult(String, List<URIStatus>, ListBucketOptions) - Constructor for class alluxio.proxy.s3.ListBucketResult
Creates an ListBucketResult.
ListBucketResult.Content - Class in alluxio.proxy.s3
Object metadata class.
ListCommand - Class in alluxio.cli.fsadmin.pathconf
Lists paths that have path level configuration.
ListCommand(Context, AlluxioConfiguration) - Constructor for class alluxio.cli.fsadmin.pathconf.ListCommand
 
ListCommand - Class in alluxio.cli.job.command
Lists the job ids in the history.
ListCommand(FileSystemContext) - Constructor for class alluxio.cli.job.command.ListCommand
Creates the job list command.
listDatabases() - Method in class alluxio.cli.table.command.ListDatabasesCommand
Print attached databases to stdout.
ListDatabasesCommand - Class in alluxio.cli.table.command
List information about attached databases and tables in the Alluxio catalog.
ListDatabasesCommand(AlluxioConfiguration, TableMasterClient) - Constructor for class alluxio.cli.table.command.ListDatabasesCommand
Creates a new instance of ListDatabasesCommand.
listDetailed() - Method in interface alluxio.client.job.JobMasterClient
 
listDetailed() - Method in class alluxio.client.job.RetryHandlingJobMasterClient
 
listDetailed() - Method in class alluxio.master.job.JobMaster
 
listen(Address, Consumer<Connection>) - Method in class alluxio.master.transport.GrpcMessagingServer
 
listExtensions(String) - Static method in class alluxio.util.ExtensionUtils
List extension jars from the configured extensions directory.
listFiles(String, String, int, String) - Method in class alluxio.underfs.kodo.KodoClient
Lists object for Qiniu kodo.
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.
listLargeDirectoryTest() - Method in class alluxio.examples.UnderFileSystemCommonOperations
Test for listing large directory.
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.
listStatus(AlluxioURI, ListStatusPOptions) - Method in class alluxio.client.file.BaseFileSystem
 
listStatus(AlluxioURI, ListStatusPOptions) - Method in class alluxio.client.file.DelegatingFileSystem
 
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(AlluxioURI, ListStatusPOptions) - Method in class alluxio.client.file.MetadataCachingBaseFileSystem
 
listStatus(AlluxioURI, ListStatusPOptions) - Method in class alluxio.client.file.RetryHandlingFileSystemMasterClient
 
listStatus(String) - Method in class alluxio.concurrent.ManagedBlockingUfsForwarder
 
listStatus(String, ListOptions) - Method in class alluxio.concurrent.ManagedBlockingUfsForwarder
 
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.FileSystemMasterClientServiceImplBase
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(AlluxioURI, ListStatusPOptions) - Method in class alluxio.hadoop.AlluxioHdfsFileSystem
 
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.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) - Method in class alluxio.underfs.web.WebUnderFileSystem
 
ListStatusContext - Class in alluxio.master.file.contexts
Used to merge and wrap ListStatusPOptions.
listStatusDefaults(AlluxioConfiguration) - Static method in class alluxio.util.FileSystemOptions
 
listStatusEmptyTest() - Method in class alluxio.examples.UnderFileSystemCommonOperations
Test for listing empty directory.
listStatusFileTest() - Method in class alluxio.examples.UnderFileSystemCommonOperations
Test for listing status on file.
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.examples.UnderFileSystemCommonOperations
Test for listing status recursively.
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.
listStatusTest() - Method in class alluxio.examples.UnderFileSystemCommonOperations
Test for listing status.
listTable(String, String) - Method in class alluxio.cli.table.command.ListDatabasesCommand
Print table information to stdout.
listTables(String) - Method in class alluxio.cli.table.command.ListDatabasesCommand
Print list of tables stdout.
listToString(List<T>) - Static method in class alluxio.util.CommonUtils
Converts a list of objects to a string.
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(K) - Method in class alluxio.master.metastore.caching.Cache
Loads a key from the backing store.
LOADAVERAGE_FIELD_NUMBER - Static variable in class alluxio.grpc.JobWorkerHealth
 
loadBlock(FileSystem, FileSystemContext, String, long) - Static method in class alluxio.job.util.JobUtils
Loads a block into the local worker.
loadClass(String, boolean) - Method in class alluxio.extensions.ExtensionsClassLoader
 
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() - Static method in class alluxio.cli.extensions.ExtensionsShellUtils
Gets all Command instances in the same package as ExtensionsShell and loads them into a map.
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
 
loadCommands() - Method in class alluxio.cli.job.JobShell
 
loadCommands() - Method in class alluxio.cli.table.TableShell
 
loadConf(InetSocketAddress, boolean, boolean) - Method in class alluxio.ClientContext
This method will load the cluster and path level configuration defaults and update the configuration in one RPC.
loadConfIfNotLoaded(InetSocketAddress) - Method in class alluxio.ClientContext
Loads configuration if not loaded from meta master yet.
LoadConfig - Class in alluxio.job.plan.load
The configuration of loading a file.
LoadConfig(String, Integer) - Constructor for class alluxio.job.plan.load.LoadConfig
 
loadConfiguration(InetSocketAddress, AlluxioConfiguration, boolean, boolean) - Static method in class alluxio.util.ConfigurationUtils
Loads configuration from meta master in one RPC.
LoadDefinition - Class in alluxio.job.plan.load
A simple loading job that loads the blocks of a file in a distributed and round-robin fashion.
LoadDefinition() - Constructor for class alluxio.job.plan.load.LoadDefinition
Constructs a new LoadDefinition.
LoadDefinition.LoadTask - Class in alluxio.job.plan.load
A task representing loading a block into the memory of a worker.
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
 
LoadMetadataContext - Class in alluxio.master.file.contexts
Used to merge and wrap LoadMetadataPOptions.
loadMetadataDefaults(AlluxioConfiguration) - Static method in class alluxio.util.FileSystemOptions
 
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
 
loadProperties(InputStream) - Static method in class alluxio.util.ConfigurationUtils
 
loadPropertiesFromFile(String) - Static method in class alluxio.util.ConfigurationUtils
Loads properties from the given file.
loadPropertiesFromResource(URL) - Static method in class alluxio.util.ConfigurationUtils
Loads properties from a resource.
LoadTask(long) - Constructor for class alluxio.job.plan.load.LoadDefinition.LoadTask
 
loadWorkerClusterDefaults(InetSocketAddress) - Static method in class alluxio.conf.ServerConfiguration
Loads cluster default values for workers from the meta master if it's not loaded yet.
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) - 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(AlluxioURI, OpenFilePOptions, FileSystem, CacheManager) - Constructor for class alluxio.client.file.cache.LocalCacheFileInStream
Constructor when only path information is available.
LocalCacheFileInStream(URIStatus, OpenFilePOptions, FileSystem, CacheManager) - Constructor for class alluxio.client.file.cache.LocalCacheFileInStream
Constructor when the URIStatus is already available.
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
 
LocalCacheManager - Class in alluxio.client.file.cache
A class to manage & serve cached pages.
LocalFileBlockReader - Class in alluxio.worker.block.io
This class provides read access to a block data file locally stored in managed storage.
LocalFileBlockReader(String) - Constructor for class alluxio.worker.block.io.LocalFileBlockReader
Constructs a Block reader given the file path of the block.
LocalFileBlockWriter - Class in alluxio.worker.block.io
This class provides write access to a temp block data file locally stored in managed storage.
LocalFileBlockWriter(String) - Constructor for class alluxio.worker.block.io.LocalFileBlockWriter
Constructs a Block writer given the file path of the block.
LocalFileDataReader - Class in alluxio.client.block.stream
A data reader that simply reads packets from a local file.
LocalFileDataReader.Factory - Class in alluxio.client.block.stream
Factory class to create LocalFileDataReaders.
LocalFileDataWriter - Class in alluxio.client.block.stream
A local data writer that simply writes packets to a local file.
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
 
LocalFirstAvoidEvictionPolicy - Class in alluxio.client.block.policy
A policy that returns local host first, and if the local worker doesn't have enough availability, it randomly picks a worker from the active workers list for each block write.
LocalFirstAvoidEvictionPolicy(AlluxioConfiguration) - Constructor for class alluxio.client.block.policy.LocalFirstAvoidEvictionPolicy
LocalFirstPolicy - Class in alluxio.client.block.policy
A policy that returns local host first, and if the local worker doesn't have enough availability, it randomly picks a worker from the active workers list for each block write.
LocalFirstPolicy(AlluxioConfiguration) - Constructor for class alluxio.client.block.policy.LocalFirstPolicy
Constructs a new LocalFirstPolicy.
localIdentity(AlluxioConfiguration) - Static method in class alluxio.network.TieredIdentityFactory
 
LOCALITY_COMPARE_NODE_IP - Static variable in class alluxio.conf.PropertyKey
 
LOCALITY_COMPARE_NODE_IP - Static variable in class alluxio.conf.PropertyKey.Name
 
LOCALITY_NODE - Static variable in class alluxio.Constants
 
LOCALITY_ORDER - Static variable in class alluxio.conf.PropertyKey
 
LOCALITY_ORDER - Static variable in class alluxio.conf.PropertyKey.Name
 
LOCALITY_RACK - Static variable in class alluxio.Constants
 
LOCALITY_SCRIPT - Static variable in class alluxio.conf.PropertyKey
 
LOCALITY_SCRIPT - Static variable in class alluxio.conf.PropertyKey.Name
 
LOCALITY_TIER_NODE - Static variable in class alluxio.conf.PropertyKey
 
LOCALITY_TIER_RACK - Static variable in class alluxio.conf.PropertyKey
 
LocalityTier - Class in alluxio.grpc
Protobuf type alluxio.grpc.LocalityTier
LocalityTier(String, String) - Constructor for class alluxio.wire.TieredIdentity.LocalityTier
 
LocalityTier.Builder - Class in alluxio.grpc
Protobuf type alluxio.grpc.LocalityTier
LocalityTierOrBuilder - Interface in alluxio.grpc
 
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(LocalPageStoreOptions) - Constructor for class alluxio.client.file.cache.store.LocalPageStore
Creates a new instance of LocalPageStore.
LocalPageStoreOptions - Class in alluxio.client.file.cache.store
Options used to instantiate the LocalPageStore.
LocalPageStoreOptions() - Constructor for class alluxio.client.file.cache.store.LocalPageStoreOptions
Creates a new instance of LocalPageStoreOptions.
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.
LOCATION_FIELD_NUMBER - Static variable in class alluxio.grpc.table.Database
 
LOCATION_FIELD_NUMBER - Static variable in class alluxio.grpc.table.layout.hive.Storage
 
LOCATION_FIELD_NUMBER - Static variable in class alluxio.proto.journal.Table.UpdateDatabaseInfoEntry
 
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
 
lockBlock(long, long, BlockLockType) - Method in class alluxio.worker.block.BlockLockManager
Locks a block.
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.
lockBlock(long, long) - Method in class alluxio.worker.block.DefaultBlockWorker
 
lockBlock(long, long) - Method in class alluxio.worker.block.TieredBlockStore
 
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.
lockBlockNoException(long, long) - Method in class alluxio.worker.block.DefaultBlockWorker
 
lockBlockNoException(long, long) - Method in class alluxio.worker.block.TieredBlockStore
 
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.
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) - 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) - 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.
lockFinalEdgeWrite() - Method in class alluxio.master.file.meta.LockedInodePath
Returns a copy of the path with the final edge write locked.
lockFullInodePath(AlluxioURI, InodeTree.LockPattern) - 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) - 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.
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) - Method in class alluxio.master.file.meta.InodeLockManager
Acquires an inode lock.
lockInode(Inode, LockMode) - Method in class alluxio.master.file.meta.SimpleInodeLockList
 
lockInodePath(AlluxioURI, InodeTree.LockPattern) - 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) - Method in class alluxio.master.file.meta.InodeTree
Locks existing inodes on the two specified paths.
LockMode - Enum in alluxio.concurrent
ReadWriteLock types.
LockPool<K> - Class in alluxio.collections
A resource pool specifically designed to contain locks and will NOT evict any entries that are in use.
LockPool(Function<? super K, ? extends ReentrantReadWriteLock>, int, int, int, int) - Constructor for class alluxio.collections.LockPool
Constructor for a lock pool.
LockResource - Class in alluxio.resource
A resource lock that makes it possible to acquire and release locks using the following idiom:
LockResource(Lock) - Constructor for class alluxio.resource.LockResource
Creates a new instance of LockResource using the given lock.
LockResource(Lock, boolean, boolean) - Constructor for class alluxio.resource.LockResource
Creates a new instance of LockResource using the given lock.
LockResource(Lock, boolean, boolean, Runnable) - Constructor for class alluxio.resource.LockResource
Creates a new instance of LockResource using the given lock.
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.
LOG - Static variable in class alluxio.client.block.stream.DataWriter.Factory
 
LOG - Static variable in interface alluxio.client.file.cache.PageStore
 
LOG - Static variable in class alluxio.master.file.async.AsyncPersistHandler.Factory
 
LOG - Static variable in interface alluxio.uri.Authority
 
LOG_ARGUMENT_LEVEL - Static variable in class alluxio.master.meta.AlluxioMasterRestServiceHandler
 
LOG_ARGUMENT_LEVEL - Static variable in class alluxio.worker.AlluxioWorkerRestServiceHandler
 
LOG_ARGUMENT_NAME - Static variable in class alluxio.master.meta.AlluxioMasterRestServiceHandler
 
LOG_ARGUMENT_NAME - Static variable in class alluxio.worker.AlluxioWorkerRestServiceHandler
 
LOG_LEVEL - Static variable in class alluxio.master.meta.AlluxioMasterRestServiceHandler
 
LOG_LEVEL - Static variable in class alluxio.worker.AlluxioWorkerRestServiceHandler
 
logAllThreads() - Static method in class alluxio.util.ThreadUtils
Logs a stack trace for all threads currently running in the JVM, similar to jstack.
logConfigReport() - Method in class alluxio.master.meta.checkconf.ServerConfigurationChecker
Logs the configuration check report information.
LOGGER_TYPE - Static variable in class alluxio.conf.PropertyKey
 
LOGGER_TYPE - Static variable in class alluxio.conf.PropertyKey.Name
 
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.meta.AlluxioMasterRestServiceHandler
 
logLevel(String, String) - Method in class alluxio.worker.AlluxioWorkerRestServiceHandler
 
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.
LOGS_DIR - Static variable in class alluxio.conf.PropertyKey
 
LOGS_DIR - Static variable in class alluxio.conf.PropertyKey.Name
 
LOGSERVER_CLIENT_LOGGER_APPENDER_NAME - Static variable in class alluxio.logserver.AlluxioLogServerProcess
Name of the appender used by log server to perform actual logging of messages received from remote Alluxio servers.
LOGSERVER_HOSTNAME - Static variable in class alluxio.conf.PropertyKey
 
LOGSERVER_HOSTNAME - Static variable in class alluxio.conf.PropertyKey.Name
 
LOGSERVER_LOGS_DIR - Static variable in class alluxio.conf.PropertyKey
 
LOGSERVER_LOGS_DIR - Static variable in class alluxio.conf.PropertyKey.Name
 
LOGSERVER_PORT - Static variable in class alluxio.conf.PropertyKey
 
LOGSERVER_PORT - Static variable in class alluxio.conf.PropertyKey.Name
 
LOGSERVER_THREADS_MAX - Static variable in class alluxio.conf.PropertyKey
 
LOGSERVER_THREADS_MAX - Static variable in class alluxio.conf.PropertyKey.Name
 
LOGSERVER_THREADS_MIN - Static variable in class alluxio.conf.PropertyKey
 
LOGSERVER_THREADS_MIN - Static variable in class alluxio.conf.PropertyKey.Name
 
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
 
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
 
losePrimacy() - Method in interface alluxio.master.journal.JournalSystem
Transitions the journal to secondary 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
 
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.ServerConfigurationStore
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
 
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
 
LRFUEvictor - Class in alluxio.worker.block.evictor
This class is used to evict blocks by LRFU.
LRFUEvictor(BlockMetadataEvictorView, Allocator) - Constructor for class alluxio.worker.block.evictor.LRFUEvictor
Creates a new instance of LRFUEvictor.
LRUCacheEvictor - Class in alluxio.client.file.cache.evictor
LRU client-side cache eviction policy.
LRUCacheEvictor(AlluxioConfiguration) - Constructor for class alluxio.client.file.cache.evictor.LRUCacheEvictor
Required constructor.
LRUEvictor - Class in alluxio.worker.block.evictor
Implementation of an evictor which follows the least recently used algorithm.
LRUEvictor(BlockMetadataEvictorView, Allocator) - Constructor for class alluxio.worker.block.evictor.LRUEvictor
Creates a new instance of LRUEvictor.
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

mAcl - Variable in class alluxio.master.file.contexts.CreatePathContext
 
mAcl - Variable in class alluxio.master.file.meta.MutableInode
 
mAddress - Variable in class alluxio.AbstractClient
 
main(String[]) - Static method in class alluxio.checker.HiveIntegrationChecker
Main function will be triggered by hive-checker.sh.
main(String[]) - Static method in class alluxio.checker.MapReduceIntegrationChecker
Main function will be triggered via hadoop jar.
main(String[]) - Static method in class alluxio.checker.SparkIntegrationChecker
Main function will be triggered via spark-submit.
main(String[]) - Static method in class alluxio.cli.AlluxioFrameworkIntegrationTest
 
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.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.job.JobShell
Main method, starts a new JobShell.
main(String[]) - Static method in class alluxio.cli.JournalCrashTest
Runs the crash test.
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.table.TableShell
Manage Alluxio extensions.
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.Version
Prints the version of the current build.
main(String[]) - Static method in class alluxio.examples.BasicCheckpoint
Example program for using checkpoints.
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.fuse.AlluxioFuse
Running this class will mount the file system according to the options passed to this function AlluxioFuse.parseOptions(String[], AlluxioConfiguration).
main(String[]) - Static method in class alluxio.logserver.AlluxioLogServer
Main entry point of AlluxioLogServer.
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.AlluxioSecondaryMaster
Starts the secondary Alluxio master.
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.JournalUpgrader
Reads a journal via java -cp \ assembly/server/target/alluxio-assembly-server-<ALLUXIO-VERSION>-jar-with-dependencies.jar \ alluxio.master.journal.JournalUpgrader -master BlockMaster.
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.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.
makeCORS(Response.ResponseBuilder, String) - Static method in class alluxio.RestUtils
Makes the responseBuilder CORS compatible.
makeCORS(Response.ResponseBuilder) - Static method in class alluxio.RestUtils
Makes the responseBuilder CORS compatible, assumes default methods.
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
 
mAllocator - Variable in class alluxio.worker.block.evictor.AbstractEvictor
 
mAlluxioConf - Variable in class alluxio.hadoop.AbstractFileSystem
 
mAlluxioVersion - Variable in class alluxio.client.file.cache.store.PageStoreOptions
Alluxio client version.
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(Object, Object, Mapper<Object, Object, Text, Text>.Context) - Method in class alluxio.checker.MapReduceIntegrationChecker.CheckerMapper
Records the Status and IP address of each mapper task node.
map(Function<T, R>, Collection<T>) - Static method in class alluxio.util.StreamUtils
 
MapReduceIntegrationChecker - Class in alluxio.checker
A MapReduce job to test the integration of MapReduce with Alluxio.
MapReduceIntegrationChecker() - Constructor for class alluxio.checker.MapReduceIntegrationChecker
 
MapReduceIntegrationChecker.CheckerMapper - Class in alluxio.checker
In each mapper node, we will check whether this node can recognize Alluxio classes and filesystem.
MapReduceIntegrationChecker.CheckerReducer - Class in alluxio.checker
In each reducer node, we will combine the IP addresses that have the same Status.
mark(int) - Method in class alluxio.hadoop.AlluxioHdfsInputStream
 
markBlockMoveIn(long, long) - Method in class alluxio.worker.block.meta.StorageDirEvictorView
Marks a block to move into this dir view, which is used by the evictor.
markBlockMoveOut(long, long) - Method in class alluxio.worker.block.meta.StorageDirEvictorView
Marks a block to move out of this dir view, which is used by the evictor.
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
 
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, String>) - Constructor for class alluxio.multi.process.Master
 
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_AUDIT_LOGGING_ENABLED - Static variable in class alluxio.conf.PropertyKey
Master related properties.
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_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_INTEGRITY_CHECK - Static variable in class alluxio.heartbeat.HeartbeatContext
 
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_COMPLETE_FILE_OPS - Static variable in class alluxio.metrics.MetricKey.Name
 
MASTER_CREATE_DIRECTORIES_OPS - Static variable in class alluxio.metrics.MetricKey
 
MASTER_CREATE_DIRECTORIES_OPS - Static variable in class alluxio.metrics.MetricKey.Name
 
MASTER_CREATE_FILES_OPS - Static variable in class alluxio.metrics.MetricKey
 
MASTER_CREATE_FILES_OPS - Static variable in class alluxio.metrics.MetricKey.Name
 
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_DELETE_PATHS_OPS - Static variable in class alluxio.metrics.MetricKey.Name
 
MASTER_DIRECTORIES_CREATED - Static variable in class alluxio.metrics.MetricKey
 
MASTER_DIRECTORIES_CREATED - Static variable in class alluxio.metrics.MetricKey.Name
 
MASTER_EDGE_CACHE_SIZE - Static variable in class alluxio.metrics.MetricKey
 
MASTER_EDGE_CACHE_SIZE - Static variable in class alluxio.metrics.MetricKey.Name
 
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_APPENDER_BATCH_SIZE - Static variable in class alluxio.conf.PropertyKey
 
MASTER_EMBEDDED_JOURNAL_APPENDER_BATCH_SIZE - Static variable in class alluxio.conf.PropertyKey.Name
 
MASTER_EMBEDDED_JOURNAL_ELECTION_TIMEOUT - Static variable in class alluxio.conf.PropertyKey
 
MASTER_EMBEDDED_JOURNAL_ELECTION_TIMEOUT - Static variable in class alluxio.conf.PropertyKey.Name
 
MASTER_EMBEDDED_JOURNAL_HEARTBEAT_INTERVAL - Static variable in class alluxio.conf.PropertyKey
 
MASTER_EMBEDDED_JOURNAL_HEARTBEAT_INTERVAL - Static variable in class alluxio.conf.PropertyKey.Name
 
MASTER_EMBEDDED_JOURNAL_PORT - Static variable in class alluxio.conf.PropertyKey
 
MASTER_EMBEDDED_JOURNAL_PORT - Static variable in class alluxio.conf.PropertyKey.Name
 
MASTER_EMBEDDED_JOURNAL_PROXY_HOST - Static variable in class alluxio.conf.PropertyKey
 
MASTER_EMBEDDED_JOURNAL_PROXY_HOST - Static variable in class alluxio.conf.PropertyKey.Name
 
MASTER_EMBEDDED_JOURNAL_SHUTDOWN_TIMEOUT - Static variable in class alluxio.conf.PropertyKey
 
MASTER_EMBEDDED_JOURNAL_SHUTDOWN_TIMEOUT - Static variable in class alluxio.conf.PropertyKey.Name
 
MASTER_EMBEDDED_JOURNAL_STORAGE_LEVEL - Static variable in class alluxio.conf.PropertyKey
 
MASTER_EMBEDDED_JOURNAL_STORAGE_LEVEL - Static variable in class alluxio.conf.PropertyKey.Name
 
MASTER_EMBEDDED_JOURNAL_TRANSPORT_MAX_INBOUND_MESSAGE_SIZE - Static variable in class alluxio.conf.PropertyKey
 
MASTER_EMBEDDED_JOURNAL_TRANSPORT_MAX_INBOUND_MESSAGE_SIZE - Static variable in class alluxio.conf.PropertyKey.Name
 
MASTER_EMBEDDED_JOURNAL_TRANSPORT_REQUEST_TIMEOUT_MS - Static variable in class alluxio.conf.PropertyKey
 
MASTER_EMBEDDED_JOURNAL_TRANSPORT_REQUEST_TIMEOUT_MS - Static variable in class alluxio.conf.PropertyKey.Name
 
MASTER_EMBEDDED_JOURNAL_TRIGGERED_SNAPSHOT_WAIT_TIMEOUT - Static variable in class alluxio.conf.PropertyKey
 
MASTER_EMBEDDED_JOURNAL_TRIGGERED_SNAPSHOT_WAIT_TIMEOUT - Static variable in class alluxio.conf.PropertyKey.Name
 
MASTER_EMBEDDED_JOURNAL_WRITE_TIMEOUT - Static variable in class alluxio.conf.PropertyKey
 
MASTER_EMBEDDED_JOURNAL_WRITE_TIMEOUT - Static variable in class alluxio.conf.PropertyKey.Name
 
MASTER_FILE_ACCESS_TIME_JOURNAL_FLUSH_INTERVAL - Static variable in class alluxio.conf.PropertyKey
 
MASTER_FILE_ACCESS_TIME_JOURNAL_FLUSH_INTERVAL - Static variable in class alluxio.conf.PropertyKey.Name
 
MASTER_FILE_ACCESS_TIME_UPDATE_PRECISION - Static variable in class alluxio.conf.PropertyKey
 
MASTER_FILE_ACCESS_TIME_UPDATE_PRECISION - Static variable in class alluxio.conf.PropertyKey.Name
 
MASTER_FILE_ACCESS_TIME_UPDATER_SHUTDOWN_TIMEOUT - Static variable in class alluxio.conf.PropertyKey
 
MASTER_FILE_ACCESS_TIME_UPDATER_SHUTDOWN_TIMEOUT - Static variable in class alluxio.conf.PropertyKey.Name
 
MASTER_FILE_BLOCK_INFOS_GOT - Static variable in class alluxio.metrics.MetricKey
 
MASTER_FILE_BLOCK_INFOS_GOT - Static variable in class alluxio.metrics.MetricKey.Name
 
MASTER_FILE_INFOS_GOT - Static variable in class alluxio.metrics.MetricKey
 
MASTER_FILE_INFOS_GOT - Static variable in class alluxio.metrics.MetricKey.Name
 
MASTER_FILE_RECOMPUTATION - Static variable in class alluxio.heartbeat.HeartbeatContext
 
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_FILES_COMPLETED - Static variable in class alluxio.metrics.MetricKey
 
MASTER_FILES_COMPLETED - Static variable in class alluxio.metrics.MetricKey.Name
 
MASTER_FILES_CREATED - Static variable in class alluxio.metrics.MetricKey
 
MASTER_FILES_CREATED - Static variable in class alluxio.metrics.MetricKey.Name
 
MASTER_FILES_FREED - Static variable in class alluxio.metrics.MetricKey
 
MASTER_FILES_FREED - Static variable in class alluxio.metrics.MetricKey.Name
 
MASTER_FILES_PERSISTED - Static variable in class alluxio.metrics.MetricKey
 
MASTER_FILES_PERSISTED - Static variable in class alluxio.metrics.MetricKey.Name
 
MASTER_FILES_PINNED - Static variable in class alluxio.metrics.MetricKey
 
MASTER_FILES_PINNED - Static variable in class alluxio.metrics.MetricKey.Name
 
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_FREE_FILE_OPS - Static variable in class alluxio.metrics.MetricKey.Name
 
MASTER_GET_FILE_BLOCK_INFO_OPS - Static variable in class alluxio.metrics.MetricKey
 
MASTER_GET_FILE_BLOCK_INFO_OPS - Static variable in class alluxio.metrics.MetricKey.Name
 
MASTER_GET_FILE_INFO_OPS - Static variable in class alluxio.metrics.MetricKey
 
MASTER_GET_FILE_INFO_OPS - Static variable in class alluxio.metrics.MetricKey.Name
 
MASTER_GET_NEW_BLOCK_OPS - Static variable in class alluxio.metrics.MetricKey
 
MASTER_GET_NEW_BLOCK_OPS - Static variable in class alluxio.metrics.MetricKey.Name
 
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_SIZE - Static variable in class alluxio.metrics.MetricKey
 
MASTER_INODE_CACHE_SIZE - Static variable in class alluxio.metrics.MetricKey.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_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_FAILURE - Static variable in class alluxio.metrics.MetricKey.Name
 
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_FLUSH_TIMER - Static variable in class alluxio.metrics.MetricKey.Name
 
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_GAIN_PRIMACY_TIMER - Static variable in class alluxio.metrics.MetricKey.Name
 
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_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_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_ENTRIES_COUNT - Static variable in class alluxio.metrics.MetricKey.Name
 
MASTER_LAST_BACKUP_RESTORE_COUNT - Static variable in class alluxio.metrics.MetricKey
 
MASTER_LAST_BACKUP_RESTORE_COUNT - Static variable in class alluxio.metrics.MetricKey.Name
 
MASTER_LAST_BACKUP_RESTORE_TIME_MS - Static variable in class alluxio.metrics.MetricKey
 
MASTER_LAST_BACKUP_RESTORE_TIME_MS - Static variable in class alluxio.metrics.MetricKey.Name
 
MASTER_LAST_BACKUP_TIME_MS - Static variable in class alluxio.metrics.MetricKey
 
MASTER_LAST_BACKUP_TIME_MS - Static variable in class alluxio.metrics.MetricKey.Name
 
MASTER_LISTING_CACHE_SIZE - Static variable in class alluxio.metrics.MetricKey
 
MASTER_LISTING_CACHE_SIZE - Static variable in class alluxio.metrics.MetricKey.Name
 
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_FILES_DETECTION - Static variable in class alluxio.heartbeat.HeartbeatContext
 
MASTER_LOST_MASTER_DETECTION - Static variable in class alluxio.heartbeat.HeartbeatContext
 
MASTER_LOST_WORKER_DETECTION - Static variable in class alluxio.heartbeat.HeartbeatContext
 
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_METASTORE - Static variable in class alluxio.conf.PropertyKey
 
MASTER_METASTORE - 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_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_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_MOUNT_OPS - Static variable in class alluxio.metrics.MetricKey
 
MASTER_MOUNT_OPS - Static variable in class alluxio.metrics.MetricKey.Name
 
MASTER_MOUNT_TABLE_ROOT_ALLUXIO - Static variable in class alluxio.conf.PropertyKey
 
MASTER_MOUNT_TABLE_ROOT_OPTION - Static variable in class alluxio.conf.PropertyKey
 
MASTER_MOUNT_TABLE_ROOT_READONLY - Static variable in class alluxio.conf.PropertyKey
 
MASTER_MOUNT_TABLE_ROOT_SHARED - Static variable in class alluxio.conf.PropertyKey
 
MASTER_MOUNT_TABLE_ROOT_UFS - Static variable in class alluxio.conf.PropertyKey
 
MASTER_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_NEW_BLOCKS_GOT - Static variable in class alluxio.metrics.MetricKey
 
MASTER_NEW_BLOCKS_GOT - Static variable in class alluxio.metrics.MetricKey.Name
 
MASTER_ORPHANED_METRICS_CLEANER - Static variable in class alluxio.heartbeat.HeartbeatContext
 
MASTER_PATHS_DELETED - Static variable in class alluxio.metrics.MetricKey
 
MASTER_PATHS_DELETED - Static variable in class alluxio.metrics.MetricKey.Name
 
MASTER_PATHS_MOUNTED - Static variable in class alluxio.metrics.MetricKey
 
MASTER_PATHS_MOUNTED - Static variable in class alluxio.metrics.MetricKey.Name
 
MASTER_PATHS_RENAMED - Static variable in class alluxio.metrics.MetricKey
 
MASTER_PATHS_RENAMED - Static variable in class alluxio.metrics.MetricKey.Name
 
MASTER_PATHS_UNMOUNTED - Static variable in class alluxio.metrics.MetricKey
 
MASTER_PATHS_UNMOUNTED - Static variable in class alluxio.metrics.MetricKey.Name
 
MASTER_PERIODIC_BLOCK_INTEGRITY_CHECK_INTERVAL - Static variable in class alluxio.conf.PropertyKey
 
MASTER_PERIODIC_BLOCK_INTEGRITY_CHECK_INTERVAL - Static variable in class alluxio.conf.PropertyKey.Name
 
MASTER_PERIODIC_BLOCK_INTEGRITY_CHECK_REPAIR - Static variable in class alluxio.conf.PropertyKey
 
MASTER_PERIODIC_BLOCK_INTEGRITY_CHECK_REPAIR - Static variable in class alluxio.conf.PropertyKey.Name
 
MASTER_PERSISTENCE_BLACKLIST - Static variable in class alluxio.conf.PropertyKey
 
MASTER_PERSISTENCE_BLACKLIST - Static variable in class alluxio.conf.PropertyKey.Name
 
MASTER_PERSISTENCE_CHECKER - 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_RENAME_PATH_OPS - Static variable in class alluxio.metrics.MetricKey
 
MASTER_RENAME_PATH_OPS - Static variable in class alluxio.metrics.MetricKey.Name
 
MASTER_REPLICATION_CHECK - Static variable in class alluxio.heartbeat.HeartbeatContext
 
MASTER_REPLICATION_CHECK_INTERVAL_MS - Static variable in class alluxio.conf.PropertyKey
 
MASTER_REPLICATION_CHECK_INTERVAL_MS - Static variable in class alluxio.conf.PropertyKey.Name
 
MASTER_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_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_MIN_RUNNABLE - Static variable in class alluxio.conf.PropertyKey
 
MASTER_RPC_EXECUTOR_MIN_RUNNABLE - Static variable in class alluxio.conf.PropertyKey.Name
 
MASTER_RPC_EXECUTOR_PARALLELISM - Static variable in class alluxio.conf.PropertyKey
 
MASTER_RPC_EXECUTOR_PARALLELISM - 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_SERVICE_PREFIX - Static variable in class alluxio.job.ServiceConstants
 
MASTER_SERVING_THREAD_TIMEOUT - Static variable in class alluxio.conf.PropertyKey
 
MASTER_SERVING_THREAD_TIMEOUT - Static variable in class alluxio.conf.PropertyKey.Name
 
MASTER_SET_ACL_OPS - Static variable in class alluxio.metrics.MetricKey
 
MASTER_SET_ACL_OPS - Static variable in class alluxio.metrics.MetricKey.Name
 
MASTER_SET_ATTRIBUTE_OPS - Static variable in class alluxio.metrics.MetricKey
 
MASTER_SET_ATTRIBUTE_OPS - Static variable in class alluxio.metrics.MetricKey.Name
 
MASTER_SHELL_BACKUP_STATE_LOCK_GRACE_MODE - Static variable in class alluxio.conf.PropertyKey
 
MASTER_SHELL_BACKUP_STATE_LOCK_GRACE_MODE - Static variable in class alluxio.conf.PropertyKey.Name
 
MASTER_SHELL_BACKUP_STATE_LOCK_SLEEP_DURATION - Static variable in class alluxio.conf.PropertyKey
 
MASTER_SHELL_BACKUP_STATE_LOCK_SLEEP_DURATION - Static variable in class alluxio.conf.PropertyKey.Name
 
MASTER_SHELL_BACKUP_STATE_LOCK_TIMEOUT - Static variable in class alluxio.conf.PropertyKey
 
MASTER_SHELL_BACKUP_STATE_LOCK_TIMEOUT - Static variable in class alluxio.conf.PropertyKey.Name
 
MASTER_SHELL_BACKUP_STATE_LOCK_TRY_DURATION - Static variable in class alluxio.conf.PropertyKey
 
MASTER_SHELL_BACKUP_STATE_LOCK_TRY_DURATION - Static variable in class alluxio.conf.PropertyKey.Name
 
MASTER_SKIP_ROOT_ACL_CHECK - Static variable in class alluxio.conf.PropertyKey
 
MASTER_SKIP_ROOT_ACL_CHECK - Static variable in class alluxio.conf.PropertyKey.Name
 
MASTER_STANDBY_HEARTBEAT_INTERVAL - Static variable in class alluxio.conf.PropertyKey
 
MASTER_STANDBY_HEARTBEAT_INTERVAL - Static variable in class alluxio.conf.PropertyKey.Name
 
MASTER_STARTUP_BLOCK_INTEGRITY_CHECK_ENABLED - Static variable in class alluxio.conf.PropertyKey
 
MASTER_STARTUP_BLOCK_INTEGRITY_CHECK_ENABLED - Static variable in class alluxio.conf.PropertyKey.Name
 
MASTER_TABLE_TRANSFORMATION_MONITOR - Static variable in class alluxio.heartbeat.HeartbeatContext
 
MASTER_TIERED_STORE_GLOBAL_LEVEL0_ALIAS - Static variable in class alluxio.conf.PropertyKey
 
MASTER_TIERED_STORE_GLOBAL_LEVEL0_ALIAS - Static variable in class alluxio.conf.PropertyKey.Name
 
MASTER_TIERED_STORE_GLOBAL_LEVEL1_ALIAS - Static variable in class alluxio.conf.PropertyKey
 
MASTER_TIERED_STORE_GLOBAL_LEVEL1_ALIAS - Static variable in class alluxio.conf.PropertyKey.Name
 
MASTER_TIERED_STORE_GLOBAL_LEVEL2_ALIAS - Static variable in class alluxio.conf.PropertyKey
 
MASTER_TIERED_STORE_GLOBAL_LEVEL2_ALIAS - Static variable in class alluxio.conf.PropertyKey.Name
 
MASTER_TIERED_STORE_GLOBAL_LEVELS - Static variable in class alluxio.conf.PropertyKey
 
MASTER_TIERED_STORE_GLOBAL_LEVELS - Static variable in class alluxio.conf.PropertyKey.Name
 
MASTER_TIERED_STORE_GLOBAL_MEDIUMTYPE - Static variable in class alluxio.conf.PropertyKey
 
MASTER_TIERED_STORE_GLOBAL_MEDIUMTYPE - Static variable in class alluxio.conf.PropertyKey.Name
 
MASTER_TOTAL_PATHS - Static variable in class alluxio.metrics.MetricKey
 
MASTER_TOTAL_PATHS - Static variable in class alluxio.metrics.MetricKey.Name
 
MASTER_TTL_CHECK - Static variable in class alluxio.heartbeat.HeartbeatContext
 
MASTER_TTL_CHECKER_INTERVAL_MS - Static variable in class alluxio.conf.PropertyKey
 
MASTER_TTL_CHECKER_INTERVAL_MS - Static variable in class alluxio.conf.PropertyKey.Name
 
MASTER_UFS_ACTIVE_SYNC_EVENT_RATE_INTERVAL - Static variable in class alluxio.conf.PropertyKey
 
MASTER_UFS_ACTIVE_SYNC_EVENT_RATE_INTERVAL - Static variable in class alluxio.conf.PropertyKey.Name
 
MASTER_UFS_ACTIVE_SYNC_INITIAL_SYNC_ENABLED - Static variable in class alluxio.conf.PropertyKey
 
MASTER_UFS_ACTIVE_SYNC_INITIAL_SYNC_ENABLED - Static variable in class alluxio.conf.PropertyKey.Name
 
MASTER_UFS_ACTIVE_SYNC_INTERVAL - Static variable in class alluxio.conf.PropertyKey
 
MASTER_UFS_ACTIVE_SYNC_INTERVAL - Static variable in class alluxio.conf.PropertyKey.Name
 
MASTER_UFS_ACTIVE_SYNC_MAX_ACTIVITIES - Static variable in class alluxio.conf.PropertyKey
 
MASTER_UFS_ACTIVE_SYNC_MAX_ACTIVITIES - Static variable in class alluxio.conf.PropertyKey.Name
 
MASTER_UFS_ACTIVE_SYNC_MAX_AGE - Static variable in class alluxio.conf.PropertyKey
 
MASTER_UFS_ACTIVE_SYNC_MAX_AGE - Static variable in class alluxio.conf.PropertyKey.Name
 
MASTER_UFS_ACTIVE_SYNC_POLL_TIMEOUT - Static variable in class alluxio.conf.PropertyKey
 
MASTER_UFS_ACTIVE_SYNC_POLL_TIMEOUT - Static variable in class alluxio.conf.PropertyKey.Name
 
MASTER_UFS_ACTIVE_SYNC_RETRY_TIMEOUT - Static variable in class alluxio.conf.PropertyKey
 
MASTER_UFS_ACTIVE_SYNC_RETRY_TIMEOUT - Static variable in class alluxio.conf.PropertyKey.Name
 
MASTER_UFS_ACTIVE_SYNC_THREAD_POOL_SIZE - Static variable in class alluxio.conf.PropertyKey
 
MASTER_UFS_ACTIVE_SYNC_THREAD_POOL_SIZE - Static variable in class alluxio.conf.PropertyKey.Name
 
MASTER_UFS_BLOCK_LOCATION_CACHE_CAPACITY - Static variable in class alluxio.conf.PropertyKey
 
MASTER_UFS_BLOCK_LOCATION_CACHE_CAPACITY - Static variable in class alluxio.conf.PropertyKey.Name
 
MASTER_UFS_CLEANUP - Static variable in class alluxio.heartbeat.HeartbeatContext
 
MASTER_UFS_JOURNAL_FAILURE_RECOVER_TIMER - Static variable in class alluxio.metrics.MetricKey
 
MASTER_UFS_JOURNAL_FAILURE_RECOVER_TIMER - Static variable in class alluxio.metrics.MetricKey.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_UNMOUNT_OPS - Static variable in class alluxio.metrics.MetricKey
 
MASTER_UNMOUNT_OPS - Static variable in class alluxio.metrics.MetricKey.Name
 
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_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_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_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.GetMasterIdPRequest
 
MASTERADDRESSES_FIELD_NUMBER - Static variable in class alluxio.grpc.MasterInfo
 
MasterBlockInfo - Class in alluxio.master.block.meta
The metadata for an Alluxio block, managed by the block master.
MasterBlockInfo(long, long) - Constructor for class alluxio.master.block.meta.MasterBlockInfo
Creates a new instance of MasterBlockInfo.
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 - Class in alluxio.master
Stores context information for Alluxio masters.
MasterContext(JournalSystem) - Constructor for class alluxio.master.MasterContext
Creates a new master context, using the global server UserState.
MasterContext(JournalSystem, UserState) - 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(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.MetaMasterMasterServiceImplBase
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) - Method in class alluxio.master.meta.DefaultMetaMaster
 
masterHeartbeat(long) - 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.GetMasterIdPResponse
 
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.Builder - Class in alluxio.grpc
Protobuf type alluxio.grpc.meta.MasterInfo
MASTERINFO_FIELD_NUMBER - Static variable in class alluxio.grpc.GetMasterInfoPResponse
 
MasterInfoCommand - Class in alluxio.cli.fs.command
Prints information regarding master fault tolerance such as leader address, list of master addresses, and the configured Zookeeper address.
MasterInfoCommand(FileSystemContext) - Constructor for class alluxio.cli.fs.command.MasterInfoCommand
 
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.
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, 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.
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.
MasterStorageTierAssoc - Class in alluxio
StorageTierAssoc for masters.
MasterStorageTierAssoc() - Constructor for class alluxio.MasterStorageTierAssoc
Creates a new instance of MasterStorageTierAssoc.
MasterStorageTierAssoc(List<String>) - Constructor for class alluxio.MasterStorageTierAssoc
Creates a new instance of MasterStorageTierAssoc.
MasterUfsManager - Class in alluxio.underfs
A class that manages the UFS for master servers.
MasterUfsManager() - Constructor for class alluxio.underfs.MasterUfsManager
Constructs the instance of MasterUfsManager.
MasterUtils - Class in alluxio.master
This class encapsulates the different master services that are configured to run.
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.
MasterWebUIMetrics - Class in alluxio.wire
Alluxio WebUI metrics information.
MasterWebUIMetrics() - Constructor for class alluxio.wire.MasterWebUIMetrics
Creates a new instance of MasterWebUIMetrics.
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 - Class in alluxio.master.block.meta
Metadata for an Alluxio worker.
MasterWorkerInfo(long, WorkerNetAddress) - Constructor for class alluxio.master.block.meta.MasterWorkerInfo
Creates a new instance of MasterWorkerInfo.
match(String, String) - Static method in class alluxio.cli.fs.FileSystemShellUtils
Returns whether or not filePath matches patternPath.
match(AlluxioURI) - Method in interface alluxio.conf.path.PathMatcher
 
match(AlluxioURI) - Method in class alluxio.conf.path.PrefixPathMatcher
 
match(String) - Method in enum alluxio.conf.PropertyKey.Template
 
matchContent(Fingerprint) - Method in class alluxio.underfs.Fingerprint
Returns true if the serialized fingerprint matches the fingerprint in the content part.
matches(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
 
matches(TieredIdentity.LocalityTier, TieredIdentity.LocalityTier, boolean) - Static method in class alluxio.util.TieredIdentityUtils
Locality comparison for wire type locality tiers, two locality tiers matches if both name and values are equal, or for the "node" tier, if the node names resolve to the same IP address.
matchMetadata(Fingerprint) - Method in class alluxio.underfs.Fingerprint
Returns true if the serialized fingerprint matches the fingerprint in metadata.
mAuthority - Variable in class alluxio.uri.StandardURI
 
MAX_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_NAME_LENGTH - Static variable in class alluxio.fuse.AlluxioFuseFileSystem
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
 
MaxFreeAllocator - Class in alluxio.worker.block.allocator
An allocator that allocates a block in the storage dir with most free space.
MaxFreeAllocator(BlockMetadataView) - Constructor for class alluxio.worker.block.allocator.MaxFreeAllocator
Creates a new instance of MaxFreeAllocator.
maxInboundMessageSize(int) - Method in class alluxio.grpc.GrpcServerBuilder
Sets the maximum size of inbound messages.
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.
mBlockClient - Variable in class alluxio.cli.fsadmin.command.AbstractFsAdminCommand
 
mBlockId - Variable in class alluxio.worker.block.meta.AbstractBlockMeta
 
mBlockLocations - Variable in class alluxio.master.metastore.heap.HeapBlockStore
 
mBlocks - Variable in class alluxio.master.metastore.heap.HeapBlockStore
 
mBlockSize - Variable in class alluxio.underfs.UfsFileStatus
 
mBlockStore - Variable in class alluxio.client.file.BaseFileSystem
 
mBuf - Variable in class alluxio.examples.Performance.Worker
 
mBytesWritten - Variable in class alluxio.client.file.FileOutStream
The number of bytes written.
mCacheSize - Variable in class alluxio.client.file.cache.store.PageStoreOptions
Cache size for the data.
mCatalystContext - Variable in class alluxio.master.backup.AbstractBackupRole
Catalyst context used for sending/receiving messages.
mCatalystRequestTimeout - Variable in class alluxio.master.backup.AbstractBackupRole
 
mChannel - Variable in class alluxio.AbstractClient
Underlying channel to the target service.
mChannels - Variable in class alluxio.security.authentication.DefaultAuthenticationServer
List of channels authenticated against this server.
mCheckpointsDir - Variable in class alluxio.master.journal.tool.AbstractJournalDumper
 
mCleanupIntervalMs - Variable in class alluxio.security.authentication.DefaultAuthenticationServer
Interval for clean-up task to fire.
mClient - Variable in class alluxio.cli.table.command.AbstractTableCommand
 
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.BaseFileSystem
 
mClosed - Variable in class alluxio.underfs.MultiRangeObjectInputStream
Has the stream been closed.
mCloser - Variable in class alluxio.cli.AbstractShell
 
mCloser - Variable in class alluxio.underfs.AbstractUfsManager
 
mCommands - Variable in class alluxio.cli.bundler.command.ExecuteShellCollectInfoCommand
 
mCommandsAlt - Variable in class alluxio.cli.bundler.command.ExecuteShellCollectInfoCommand
 
mConf - Variable in class alluxio.cli.table.command.AbstractTableCommand
 
mConf - Variable in class alluxio.security.user.BaseUserState
 
mConfAddress - Variable in class alluxio.AbstractClient
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
 
mContext - Variable in class alluxio.master.AlluxioMasterProcess
Master context.
mContext - Variable in class alluxio.master.MasterClientContextBuilder
 
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.
mDefaultAcl - Variable in class alluxio.master.file.contexts.CreateDirectoryContext
 
mDefaultValue - Variable in class alluxio.table.common.BaseProperty
 
mDelegatedFileSystem - Variable in class alluxio.client.file.DelegatingFileSystem
 
mDescription - Variable in class alluxio.table.common.BaseProperty
 
mDir - Variable in class alluxio.worker.block.meta.AbstractBlockMeta
 
mDirectory - Variable in class alluxio.master.file.meta.MutableInode
 
mDirty - Variable in class alluxio.master.metastore.caching.Cache.Entry
 
MECHANISM - Static variable in class alluxio.security.authentication.plain.PlainSaslServerProvider
 
mEdgeLocks - Variable in class alluxio.master.file.meta.InodeLockManager
Cache for supplying edge locks, similar to mInodeLocks.
MEDIUM_TYPE_FIELD_NUMBER - Static variable in class alluxio.grpc.CreateLocalBlockRequest
 
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.proto.meta.Block.BlockLocation
 
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.
mEnd - Variable in class alluxio.master.journal.tool.AbstractJournalDumper
 
mEndPos - Variable in class alluxio.underfs.MultiRangeObjectInputStream
Position the current stream was open till (exclusive).
mEntriesAdded - Variable in class alluxio.underfs.ObjectUnderFileSystem.OperationBuffer
Total number of inputs to be operated on across batches.
merge(Map<?, ?>, Source) - Method in class alluxio.conf.AlluxioProperties
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(Map<?, ?>, Source) - Static method in class alluxio.conf.ServerConfiguration
Merges the current configuration properties with new properties.
merge(AclActions) - Method in class alluxio.security.authorization.AclActions
Merges the actions.
merge(AlluxioConfiguration, Map<?, ?>, Source) - Static method in class alluxio.util.ConfigurationUtils
Merges the current configuration properties with new properties.
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
optional .alluxio.proto.journal.ActiveSyncTxIdEntry active_sync_tx_id = 34;
mergeAddMountPoint(File.AddMountPointEntry) - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
optional .alluxio.proto.journal.AddMountPointEntry add_mount_point = 2;
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;
mergeAddSyncPoint(File.AddSyncPointEntry) - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
optional .alluxio.proto.journal.AddSyncPointEntry add_sync_point = 32;
mergeAddTable(Table.AddTableEntry) - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
optional .alluxio.proto.journal.AddTableEntry add_table = 43;
mergeAddTransformJobInfo(Table.AddTransformJobInfoEntry) - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
optional .alluxio.proto.journal.AddTransformJobInfoEntry add_transform_job_info = 46;
mergeAllOrNone(AllOrNoneSet) - Method in class alluxio.grpc.table.Domain.Builder
optional .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;
mergeAttachDb(Table.AttachDbEntry) - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
optional .alluxio.proto.journal.AttachDbEntry attach_db = 44;
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
optional .alluxio.grpc.table.BinaryColumnStatsData binary_stats = 5;
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;
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
optional .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;
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
optional .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;
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
optional .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.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.StartSyncPOptions.Builder
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 1;
mergeCommonOptions(FileSystemMasterCommonPOptions) - Method in class alluxio.grpc.StopSyncPOptions.Builder
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 1;
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;
mergeCompleteTransformTable(Table.CompleteTransformTableEntry) - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
optional .alluxio.proto.journal.CompleteTransformTableEntry complete_transform_table = 48;
mergeConstraint(Constraint) - Method in class alluxio.grpc.table.ReadTablePRequest.Builder
optional .alluxio.grpc.table.Constraint constraint = 3;
mergeCreateUfsBlockOptions(Protocol.CreateUfsBlockOptions) - Method in class alluxio.grpc.WriteRequestCommand.Builder
optional .alluxio.proto.dataserver.CreateUfsBlockOptions create_ufs_block_options = 7;
mergeCreateUfsFileOptions(Protocol.CreateUfsFileOptions) - Method in class alluxio.grpc.WriteRequestCommand.Builder
Cancel, close and error will be handled by standard gRPC stream APIs.
mergeData(ColumnStatisticsData) - Method in class alluxio.grpc.table.ColumnStatisticsInfo.Builder
optional .alluxio.grpc.table.ColumnStatisticsData data = 3;
mergeDateStats(DateColumnStatsData) - Method in class alluxio.grpc.table.ColumnStatisticsData.Builder
optional .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
optional .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;
mergeDetachDb(Table.DetachDbEntry) - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
optional .alluxio.proto.journal.DetachDbEntry detach_db = 45;
mergeDoubleStats(DoubleColumnStatsData) - Method in class alluxio.grpc.table.ColumnStatisticsData.Builder
optional .alluxio.grpc.table.DoubleColumnStatsData double_stats = 3;
mergeEquatable(EquatableValueSet) - Method in class alluxio.grpc.table.Domain.Builder
optional .alluxio.grpc.table.EquatableValueSet equatable = 2;
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;
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.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.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.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.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.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.CommitBlockInUfsPOptions.Builder
 
mergeFrom(CommitBlockInUfsPOptions) - Method in class alluxio.grpc.CommitBlockInUfsPOptions.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class alluxio.grpc.CommitBlockInUfsPOptions.Builder
 
mergeFrom(Message) - Method in class alluxio.grpc.CommitBlockInUfsPRequest.Builder
 
mergeFrom(CommitBlockInUfsPRequest) - Method in class alluxio.grpc.CommitBlockInUfsPRequest.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class alluxio.grpc.CommitBlockInUfsPRequest.Builder
 
mergeFrom(Message) - Method in class alluxio.grpc.CommitBlockInUfsPResponse.Builder
 
mergeFrom(CommitBlockInUfsPResponse) - Method in class alluxio.grpc.CommitBlockInUfsPResponse.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class alluxio.grpc.CommitBlockInUfsPResponse.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.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.CreateLocalBlockRequest.Builder
 
mergeFrom(CreateLocalBlockRequest) - Method in class alluxio.grpc.CreateLocalBlockRequest.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class alluxio.grpc.CreateLocalBlockRequest.Builder
 
mergeFrom(Message) - Method in class alluxio.grpc.CreateLocalBlockResponse.Builder
 
mergeFrom(CreateLocalBlockResponse) - Method in class alluxio.grpc.CreateLocalBlockResponse.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class alluxio.grpc.CreateLocalBlockResponse.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.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.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.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.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.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.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.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.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.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.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.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.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.GetSyncPathListPRequest.Builder
 
mergeFrom(GetSyncPathListPRequest) - Method in class alluxio.grpc.GetSyncPathListPRequest.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class alluxio.grpc.GetSyncPathListPRequest.Builder
 
mergeFrom(Message) - Method in class alluxio.grpc.GetSyncPathListPResponse.Builder
 
mergeFrom(GetSyncPathListPResponse) - Method in class alluxio.grpc.GetSyncPathListPResponse.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class alluxio.grpc.GetSyncPathListPResponse.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.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.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.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.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.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.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.LocalityTier.Builder
 
mergeFrom(LocalityTier) - Method in class alluxio.grpc.LocalityTier.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class alluxio.grpc.LocalityTier.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.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.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.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.OpenLocalBlockRequest.Builder
 
mergeFrom(OpenLocalBlockRequest) - Method in class alluxio.grpc.OpenLocalBlockRequest.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class alluxio.grpc.OpenLocalBlockRequest.Builder
 
mergeFrom(Message) - Method in class alluxio.grpc.OpenLocalBlockResponse.Builder
 
mergeFrom(OpenLocalBlockResponse) - Method in class alluxio.grpc.OpenLocalBlockResponse.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class alluxio.grpc.OpenLocalBlockResponse.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.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.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.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.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.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.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.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.StartSyncPOptions.Builder
 
mergeFrom(StartSyncPOptions) - Method in class alluxio.grpc.StartSyncPOptions.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class alluxio.grpc.StartSyncPOptions.Builder
 
mergeFrom(Message) - Method in class alluxio.grpc.StartSyncPRequest.Builder
 
mergeFrom(StartSyncPRequest) - Method in class alluxio.grpc.StartSyncPRequest.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class alluxio.grpc.StartSyncPRequest.Builder
 
mergeFrom(Message) - Method in class alluxio.grpc.StartSyncPResponse.Builder
 
mergeFrom(StartSyncPResponse) - Method in class alluxio.grpc.StartSyncPResponse.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class alluxio.grpc.StartSyncPResponse.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.StopSyncPOptions.Builder
 
mergeFrom(StopSyncPOptions) - Method in class alluxio.grpc.StopSyncPOptions.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class alluxio.grpc.StopSyncPOptions.Builder
 
mergeFrom(Message) - Method in class alluxio.grpc.StopSyncPRequest.Builder
 
mergeFrom(StopSyncPRequest) - Method in class alluxio.grpc.StopSyncPRequest.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class alluxio.grpc.StopSyncPRequest.Builder
 
mergeFrom(Message) - Method in class alluxio.grpc.StopSyncPResponse.Builder
 
mergeFrom(StopSyncPResponse) - Method in class alluxio.grpc.StopSyncPResponse.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class alluxio.grpc.StopSyncPResponse.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.SyncPointInfo.Builder
 
mergeFrom(SyncPointInfo) - Method in class alluxio.grpc.SyncPointInfo.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class alluxio.grpc.SyncPointInfo.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.TieredIdentity.Builder
 
mergeFrom(TieredIdentity) - Method in class alluxio.grpc.TieredIdentity.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class alluxio.grpc.TieredIdentity.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.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.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.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.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.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.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(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(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(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.CreateUfsBlockOptions.Builder
 
mergeFrom(Protocol.CreateUfsBlockOptions) - Method in class alluxio.proto.dataserver.Protocol.CreateUfsBlockOptions.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class alluxio.proto.dataserver.Protocol.CreateUfsBlockOptions.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.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.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.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.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.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.Table.AddTableEntry.Builder
 
mergeFrom(Table.AddTableEntry) - Method in class alluxio.proto.journal.Table.AddTableEntry.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class alluxio.proto.journal.Table.AddTableEntry.Builder
 
mergeFrom(Message) - Method in class alluxio.proto.journal.Table.AddTransformJobInfoEntry.Builder
 
mergeFrom(Table.AddTransformJobInfoEntry) - Method in class alluxio.proto.journal.Table.AddTransformJobInfoEntry.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class alluxio.proto.journal.Table.AddTransformJobInfoEntry.Builder
 
mergeFrom(Message) - Method in class alluxio.proto.journal.Table.AttachDbEntry.Builder
 
mergeFrom(Table.AttachDbEntry) - Method in class alluxio.proto.journal.Table.AttachDbEntry.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class alluxio.proto.journal.Table.AttachDbEntry.Builder
 
mergeFrom(Message) - Method in class alluxio.proto.journal.Table.CompleteTransformTableEntry.Builder
 
mergeFrom(Table.CompleteTransformTableEntry) - Method in class alluxio.proto.journal.Table.CompleteTransformTableEntry.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class alluxio.proto.journal.Table.CompleteTransformTableEntry.Builder
 
mergeFrom(Message) - Method in class alluxio.proto.journal.Table.DetachDbEntry.Builder
 
mergeFrom(Table.DetachDbEntry) - Method in class alluxio.proto.journal.Table.DetachDbEntry.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class alluxio.proto.journal.Table.DetachDbEntry.Builder
 
mergeFrom(Message) - Method in class alluxio.proto.journal.Table.RemoveTableEntry.Builder
 
mergeFrom(Table.RemoveTableEntry) - Method in class alluxio.proto.journal.Table.RemoveTableEntry.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class alluxio.proto.journal.Table.RemoveTableEntry.Builder
 
mergeFrom(Message) - Method in class alluxio.proto.journal.Table.RemoveTransformJobInfoEntry.Builder
 
mergeFrom(Table.RemoveTransformJobInfoEntry) - Method in class alluxio.proto.journal.Table.RemoveTransformJobInfoEntry.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class alluxio.proto.journal.Table.RemoveTransformJobInfoEntry.Builder
 
mergeFrom(Message) - Method in class alluxio.proto.journal.Table.UpdateDatabaseInfoEntry.Builder
 
mergeFrom(Table.UpdateDatabaseInfoEntry) - Method in class alluxio.proto.journal.Table.UpdateDatabaseInfoEntry.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class alluxio.proto.journal.Table.UpdateDatabaseInfoEntry.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.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;
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;
mergeKey(BlockStoreLocationProto) - Method in class alluxio.grpc.LocationBlockIdListEntry.Builder
optional .alluxio.grpc.BlockStoreLocationProto key = 1;
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;
mergeLayout(Layout) - Method in class alluxio.proto.journal.Table.AddTableEntry.Builder
optional .alluxio.grpc.table.Layout layout = 5;
mergeLayoutSpec(LayoutSpec) - Method in class alluxio.grpc.table.Layout.Builder
optional .alluxio.grpc.table.LayoutSpec layout_spec = 2;
mergeLongStats(LongColumnStatsData) - Method in class alluxio.grpc.table.ColumnStatisticsData.Builder
optional .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.GetMasterIdPRequest.Builder
optional .alluxio.grpc.NetAddress masterAddress = 1;
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;
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.ReadRequest.Builder
This is only set for UFS block read.
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(CheckConsistencyPOptions) - Method in class alluxio.grpc.CheckConsistencyPRequest.Builder
optional .alluxio.grpc.file.CheckConsistencyPOptions options = 2;
mergeOptions(CommitBlockInUfsPOptions) - Method in class alluxio.grpc.CommitBlockInUfsPRequest.Builder
optional .alluxio.grpc.block.CommitBlockInUfsPOptions options = 3;
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(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(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(GetFileInfoPOptions) - Method in class alluxio.grpc.GetFileInfoPRequest.Builder
optional .alluxio.grpc.file.GetFileInfoPOptions options = 2;
mergeOptions(GetJobServiceSummaryPOptions) - Method in class alluxio.grpc.GetJobServiceSummaryPRequest.Builder
optional .alluxio.grpc.job.GetJobServiceSummaryPOptions options = 1;
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(GetQuorumInfoPOptions) - Method in class alluxio.grpc.GetQuorumInfoPRequest.Builder
optional .alluxio.grpc.journal.GetQuorumInfoPOptions 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(ListAllPOptions) - Method in class alluxio.grpc.ListAllPRequest.Builder
optional .alluxio.grpc.job.ListAllPOptions options = 1;
mergeOptions(ListStatusPOptions) - Method in class alluxio.grpc.ListStatusPRequest.Builder
optional .alluxio.grpc.file.ListStatusPOptions 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(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(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(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(StartSyncPOptions) - Method in class alluxio.grpc.StartSyncPRequest.Builder
optional .alluxio.grpc.file.StartSyncPOptions options = 2;
mergeOptions(StopSyncPOptions) - Method in class alluxio.grpc.StopSyncPRequest.Builder
optional .alluxio.grpc.file.StopSyncPOptions options = 2;
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;
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;
mergeProperties(MountPOptions) - Method in class alluxio.grpc.UfsInfo.Builder
optional .alluxio.grpc.file.MountPOptions properties = 2;
mergeRange(RangeSet) - Method in class alluxio.grpc.table.Domain.Builder
optional .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;
mergeRemoveTable(Table.RemoveTableEntry) - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
optional .alluxio.proto.journal.RemoveTableEntry remove_table = 50;
mergeRemoveTransformJobInfo(Table.RemoveTransformJobInfoEntry) - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
optional .alluxio.proto.journal.RemoveTransformJobInfoEntry remove_transform_job_info = 47;
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;
mergeRunTaskCommand(RunTaskCommand) - Method in class alluxio.grpc.JobCommand.Builder
optional .alluxio.grpc.job.RunTaskCommand runTaskCommand = 1;
mergeSchema(Schema) - Method in class alluxio.grpc.table.TableInfo.Builder
optional .alluxio.grpc.table.Schema schema = 5;
mergeSchema(Schema) - Method in class alluxio.proto.journal.Table.AddTableEntry.Builder
optional .alluxio.grpc.table.Schema schema = 4;
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;
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;
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
optional .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;
mergeTieredIdentity(TieredIdentity) - Method in class alluxio.grpc.WorkerNetAddress.Builder
optional .alluxio.grpc.TieredIdentity tieredIdentity = 6;
mergeUfsInfo(UfsInfo) - Method in class alluxio.grpc.GetUfsInfoPResponse.Builder
optional .alluxio.grpc.file.UfsInfo ufsInfo = 1;
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.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.BlockStoreLocationProto.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.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.Command.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.CommitBlockInUfsPOptions.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.CommitBlockInUfsPRequest.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.CommitBlockInUfsPResponse.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.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.CreateLocalBlockRequest.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.CreateLocalBlockResponse.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.ExistsPOptions.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.FileBlockInfo.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.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.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.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.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.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.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.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.GetServiceVersionPRequest.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.GetServiceVersionPResponse.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.GetSyncPathListPRequest.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.GetSyncPathListPResponse.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.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.JobServiceSummary.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.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.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.LoadMetadataPOptions.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.LocalityTier.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.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.NetAddress.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.OpenFilePOptions.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.OpenLocalBlockRequest.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.OpenLocalBlockResponse.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.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.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.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.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.ReverseResolvePRequest.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.ReverseResolvePResponse.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.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.StartSyncPOptions.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.StartSyncPRequest.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.StartSyncPResponse.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.StatusSummary.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.StopSyncPOptions.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.StopSyncPRequest.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.StopSyncPResponse.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.StorageList.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.SyncPointInfo.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.TieredIdentity.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.TierList.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.TransportMessage.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.UfsInfo.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.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.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.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.CreateUfsBlockOptions.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class alluxio.proto.dataserver.Protocol.CreateUfsFileOptions.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class alluxio.proto.dataserver.Protocol.OpenUfsBlockOptions.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class alluxio.proto.dataserver.Protocol.Response.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.Journal.JournalEntry.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.Table.AddTableEntry.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class alluxio.proto.journal.Table.AddTransformJobInfoEntry.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class alluxio.proto.journal.Table.AttachDbEntry.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class alluxio.proto.journal.Table.CompleteTransformTableEntry.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class alluxio.proto.journal.Table.DetachDbEntry.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class alluxio.proto.journal.Table.RemoveTableEntry.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class alluxio.proto.journal.Table.RemoveTransformJobInfoEntry.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class alluxio.proto.journal.Table.UpdateDatabaseInfoEntry.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.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
 
mergeUpdateDatabaseInfo(Table.UpdateDatabaseInfoEntry) - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
optional .alluxio.proto.journal.UpdateDatabaseInfoEntry update_database_info = 49;
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;
mergeWorkerAddress(WorkerNetAddress) - Method in class alluxio.grpc.BlockLocation.Builder
optional .alluxio.grpc.WorkerNetAddress workerAddress = 2;
mergeWorkerNetAddress(WorkerNetAddress) - Method in class alluxio.grpc.GetWorkerIdPRequest.Builder
the worker network address
mergeWorkerNetAddress(WorkerNetAddress) - Method in class alluxio.grpc.RegisterJobWorkerPRequest.Builder
optional .alluxio.grpc.WorkerNetAddress workerNetAddress = 1;
MESOS_LOCAL_INSTALL - Static variable in class alluxio.Constants
 
MESOS_RESOURCE_CPUS - Static variable in class alluxio.Constants
 
MESOS_RESOURCE_DISK - Static variable in class alluxio.Constants
 
MESOS_RESOURCE_MEM - Static variable in class alluxio.Constants
 
MESOS_RESOURCE_PORTS - Static variable in class alluxio.Constants
 
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.MessagingServiceBlockingStub - Class in alluxio.grpc
The messaging transport service.
MessagingServiceGrpc.MessagingServiceFutureStub - Class in alluxio.grpc
The messaging transport service.
MessagingServiceGrpc.MessagingServiceImplBase - Class in alluxio.grpc
The messaging transport service.
MessagingServiceGrpc.MessagingServiceStub - Class in alluxio.grpc
The messaging transport service.
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_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.MetaCommand
MetaCommand_Nothing = 1;
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.MetaCommand
MetaCommand_Unknown = 0;
MetadataCache - Class in alluxio.client.file
Cache for metadata of paths.
MetadataCache(int, long) - Constructor for class alluxio.client.file.MetadataCache
 
MetadataCachingBaseFileSystem - Class in alluxio.client.file
FileSystem implementation with the capability of caching metadata of paths.
MetadataCachingBaseFileSystem(FileSystemContext) - Constructor for class alluxio.client.file.MetadataCachingBaseFileSystem
 
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.MetaMasterClientServiceBlockingStub - Class in alluxio.grpc
This interface contains meta master service endpoints for Alluxio clients.
MetaMasterClientServiceGrpc.MetaMasterClientServiceFutureStub - Class in alluxio.grpc
This interface contains meta master service endpoints for Alluxio clients.
MetaMasterClientServiceGrpc.MetaMasterClientServiceImplBase - Class in alluxio.grpc
This interface contains meta master service endpoints for Alluxio clients.
MetaMasterClientServiceGrpc.MetaMasterClientServiceStub - Class in alluxio.grpc
This interface contains meta master service endpoints for Alluxio clients.
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.MetaMasterConfigurationServiceBlockingStub - Class in alluxio.grpc
This interface contains meta master service endpoints for Alluxio clients to query cluster configuration.
MetaMasterConfigurationServiceGrpc.MetaMasterConfigurationServiceFutureStub - Class in alluxio.grpc
This interface contains meta master service endpoints for Alluxio clients to query cluster configuration.
MetaMasterConfigurationServiceGrpc.MetaMasterConfigurationServiceImplBase - Class in alluxio.grpc
This interface contains meta master service endpoints for Alluxio clients to query cluster configuration.
MetaMasterConfigurationServiceGrpc.MetaMasterConfigurationServiceStub - Class in alluxio.grpc
This interface contains meta master service endpoints for Alluxio clients to query cluster configuration.
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.MetaMasterMasterServiceBlockingStub - Class in alluxio.grpc
This interface contains meta master service endpoints for Alluxio standby masters.
MetaMasterMasterServiceGrpc.MetaMasterMasterServiceFutureStub - Class in alluxio.grpc
This interface contains meta master service endpoints for Alluxio standby masters.
MetaMasterMasterServiceGrpc.MetaMasterMasterServiceImplBase - Class in alluxio.grpc
This interface contains meta master service endpoints for Alluxio standby masters.
MetaMasterMasterServiceGrpc.MetaMasterMasterServiceStub - Class in alluxio.grpc
This interface contains meta master service endpoints for Alluxio standby masters.
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
 
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 - Interface in alluxio.client.file.cache
The metadata store for pages stored in cache.
MetastoreType - Enum in alluxio.master.metastore
Metastore types.
meter(String) - Static method in class alluxio.metrics.MetricsSystem
Get or add meter with the given name.
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_CONF_FILE - Static variable in class alluxio.conf.PropertyKey
 
METRICS_CONF_FILE - Static variable in class alluxio.conf.PropertyKey.Name
 
METRICS_CONTEXT_SHUTDOWN_TIMEOUT - Static variable in class alluxio.conf.PropertyKey
 
METRICS_CONTEXT_SHUTDOWN_TIMEOUT - Static variable in class alluxio.conf.PropertyKey.Name
 
METRICS_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_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) - 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.MetricsMasterClientServiceImplBase
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.MetricsMasterClientServiceBlockingStub - Class in alluxio.grpc
This interface contains metrics master service endpoints for Alluxio clients.
MetricsMasterClientServiceGrpc.MetricsMasterClientServiceFutureStub - Class in alluxio.grpc
This interface contains metrics master service endpoints for Alluxio clients.
MetricsMasterClientServiceGrpc.MetricsMasterClientServiceImplBase - Class in alluxio.grpc
This interface contains metrics master service endpoints for Alluxio clients.
MetricsMasterClientServiceGrpc.MetricsMasterClientServiceStub - Class in alluxio.grpc
This interface contains metrics master service endpoints for Alluxio clients.
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.
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.
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.
mExtendedEntries - Variable in class alluxio.security.authorization.AccessControlList
 
mFileSystem - Variable in class alluxio.cli.fs.command.AbstractFileSystemCommand
 
mFileSystem - Variable in class alluxio.hadoop.AbstractFileSystem
 
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.BaseFileSystem
 
mGroup - Variable in class alluxio.master.file.contexts.CreatePathContext
 
mGroup - Variable in class alluxio.underfs.UfsStatus
 
mGrpcServer - Variable in class alluxio.master.MasterProcess
The RPC server.
mHashCode - Variable in class alluxio.uri.StandardURI
 
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
 
MidPartLongRange - Class in alluxio.underfs.swift
A range in a Swift object.
MidPartLongRange(long, long) - Constructor for class alluxio.underfs.swift.MidPartLongRange
Constructor for a range in a Swift object.
migrate(AlluxioURI, long, String, String) - Method in class alluxio.job.plan.replicate.DefaultReplicationHandler
 
migrate(AlluxioURI, long, String, String) - Method in interface alluxio.job.plan.replicate.ReplicationHandler
Migrate blocks to the correctly pinned locations.
MIGRATE_DATA_SESSION_ID - Static variable in class alluxio.Sessions
 
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, String, boolean, boolean) - Constructor for class alluxio.job.plan.migrate.MigrateConfig
 
MigrateDefinition - Class in alluxio.job.plan.migrate
A job that migrates a 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
 
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.
mInodeLocks - Variable in class alluxio.master.file.meta.InodeLockManager
Pool for supplying inode locks.
mInputDir - Variable in class alluxio.master.journal.tool.AbstractJournalDumper
 
MINUTE - Static variable in class alluxio.Constants
 
MINUTE_MS - Static variable in class alluxio.Constants
 
mIsDirectory - Variable in class alluxio.underfs.UfsStatus
 
mJobMaster - Variable in class alluxio.master.AlluxioJobMasterProcess
The master managing all job related metadata.
mJobMasterClient - Variable in class alluxio.cli.fsadmin.command.AbstractFsAdminCommand
 
mJobMasterJournalMasterClient - Variable in class alluxio.cli.fsadmin.command.AbstractFsAdminCommand
 
mJournalEntryFile - Variable in class alluxio.master.journal.tool.AbstractJournalDumper
 
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.
mkdir(String, long) - Method in class alluxio.fuse.AlluxioFuseFileSystem
Creates a new dir.
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.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
 
mkdirs(String, MkdirsOptions) - Method in class alluxio.underfs.web.WebUnderFileSystem
 
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.examples.UnderFileSystemCommonOperations
Test for creating directory.
mKey - Variable in class alluxio.master.metastore.caching.Cache.Entry
 
mLastModifiedTimeMs - Variable in class alluxio.underfs.UfsStatus
Last modified epoch time in ms, or null if it is not available.
mLeft - Variable in class alluxio.examples.Performance.Worker
 
mLocation - Variable in class alluxio.master.journalv0.ufs.UfsJournal
The location where this journal is stored.
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.
mLRUCache - Variable in class alluxio.worker.block.evictor.LRUEvictor
Access-ordered LinkedHashMap from blockId to LRUEvictor.UNUSED_MAP_VALUE(just a placeholder to occupy the value), acts as a LRU double linked list where most recently accessed element is put at the tail while least recently accessed element is put at the head.
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
 
mMaxCapacity - Variable in class alluxio.resource.ResourcePool
 
mMean - Variable in class alluxio.job.util.TimeSeries.Summary
 
mMetaClient - Variable in class alluxio.cli.fsadmin.command.AbstractFsAdminCommand
 
mMetaConfigClient - Variable in class alluxio.cli.fsadmin.command.AbstractFsAdminCommand
 
mMetadataLoad - Variable in class alluxio.master.file.contexts.CreatePathContext
 
mMetadataView - Variable in class alluxio.worker.block.evictor.AbstractEvictor
 
mMetricsClient - Variable in class alluxio.cli.fsadmin.command.AbstractFsAdminCommand
 
mMode - Variable in class alluxio.master.file.contexts.CreatePathContext
 
mMode - Variable in class alluxio.security.authorization.AccessControlList
 
mMode - Variable in class alluxio.underfs.UfsStatus
 
mMountOptions - Variable in class alluxio.table.common.udb.UdbConfiguration
 
mMountPoint - Variable in class alluxio.master.file.contexts.CreatePathContext
 
mName - Variable in class alluxio.table.common.BaseProperty
 
mName - Variable in class alluxio.underfs.UfsStatus
 
mNamedGroupActions - Variable in class alluxio.security.authorization.ExtendedACLEntries
 
mNamedUserActions - Variable in class alluxio.security.authorization.ExtendedACLEntries
 
mObjectMapper - Variable in class alluxio.web.WebInterfaceAbstractMetricsServlet
 
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.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
 
ModeConverter() - Constructor for class alluxio.checker.HiveIntegrationChecker.ModeConverter
 
ModeParser - Class in alluxio.security.authorization
Parser for Mode instances.
ModeUtils - Class in alluxio.util
Utility methods for mode.
MODIFY_VALUE - Static variable in enum alluxio.grpc.SetAclAction
MODIFY = 1;
MODIFY_VALUE - Static variable in enum alluxio.proto.journal.File.PSetAclAction
MODIFY = 1;
mOperationTimeMs - Variable in class alluxio.master.file.contexts.CreatePathContext
 
MostAvailableFirstPolicy - Class in alluxio.client.block.policy
A policy that returns the worker with the most available bytes.
MostAvailableFirstPolicy(AlluxioConfiguration) - Constructor for class alluxio.client.block.policy.MostAvailableFirstPolicy
Constructs a new MostAvailableFirstPolicy.
mount(AlluxioURI, AlluxioURI, MountPOptions) - Method in class alluxio.client.file.BaseFileSystem
 
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(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.FileSystemMasterClientServiceImplBase
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(AlluxioURI, AlluxioURI, MountPOptions) - Method in class alluxio.hadoop.AlluxioHdfsFileSystem
 
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.CreateUfsBlockOptions
 
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
 
MOUNT_PREFIX - Static variable in class alluxio.table.common.ConfigurationUtils
 
MountCommand - Class in alluxio.cli.fs.command
Mounts a UFS path onto an Alluxio path.
MountCommand(FileSystemContext) - Constructor for class alluxio.cli.fs.command.MountCommand
 
MountContext - Class in alluxio.master.file.contexts
Used to merge and wrap MountPOptions.
mountDefaults(AlluxioConfiguration) - Static method in class alluxio.util.FileSystemOptions
 
MOUNTID_FIELD_NUMBER - Static variable in class alluxio.grpc.FileInfo
 
MOUNTID_FIELD_NUMBER - Static variable in class alluxio.grpc.GetUfsInfoPRequest
 
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.
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) - 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
 
move(String, String) - Static method in class alluxio.util.io.FileUtils
Moves file from one place to another, can across storage devices (e.g., from memory to SSD) when File.renameTo(java.io.File) may not work.
moveBlock(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) - 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.BlockWorkerImplBase
 
moveBlock(MoveBlockRequest, StreamObserver<MoveBlockResponse>) - Method in class alluxio.grpc.BlockWorkerGrpc.BlockWorkerStub
 
moveBlock(long, long, BlockStoreLocation) - Method in interface alluxio.worker.block.BlockStore
Moves an existing block to a new location.
moveBlock(long, long, BlockStoreLocation, BlockStoreLocation) - 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.
moveBlock(long, long, String) - Method in class alluxio.worker.block.DefaultBlockWorker
 
moveBlock(long, long, BlockStoreLocation) - Method in class alluxio.worker.block.TieredBlockStore
 
moveBlock(long, long, BlockStoreLocation, BlockStoreLocation) - Method in class alluxio.worker.block.TieredBlockStore
 
moveBlock(MoveBlockRequest, StreamObserver<MoveBlockResponse>) - Method in class alluxio.worker.grpc.BlockWorkerImpl
 
moveBlockMeta(BlockMeta, TempBlockMeta) - Method in class alluxio.worker.block.BlockMetadataManager
Moves an existing block to another location currently hold by a temp block.
moveBlockMeta(BlockMeta, BlockStoreLocation) - Method in class alluxio.worker.block.BlockMetadataManager
Deprecated.
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
 
moveBlockToMedium(long, long, String) - Method in interface alluxio.worker.block.BlockWorker
Moves a block from its current location to a target location, with a specific medium type.
moveBlockToMedium(long, long, String) - Method in class alluxio.worker.block.DefaultBlockWorker
 
MoveConfig - Class in alluxio.job.plan.replicate
Configuration of a job evicting a block.
MoveConfig(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.
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.store.PageStoreOptions
Page size for the data.
mPartitions - Variable in class alluxio.master.table.BasePartitionScheme
 
mPath - Variable in class alluxio.uri.StandardURI
 
mPathComponents - Variable in class alluxio.master.file.meta.LockedInodePath
The components of mUri.
mPeak - Variable in class alluxio.job.util.TimeSeries.Summary
 
mPort - Variable in class alluxio.master.CoreMaster
 
mPos - Variable in class alluxio.underfs.MultiRangeObjectInputStream
The current position of the stream.
mPrintStream - Variable in class alluxio.cli.fsadmin.command.AbstractFsAdminCommand
 
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
 
mRecursive - Variable in class alluxio.master.file.contexts.CreatePathContext
 
mResources - Variable in class alluxio.resource.ResourcePool
 
mRight - Variable in class alluxio.examples.Performance.Worker
 
mRoleClosed - Variable in class alluxio.master.backup.AbstractBackupRole
Whether the role is active.
mRootDir - Variable in class alluxio.client.file.cache.store.PageStoreOptions
Root directory where the data is stored.
mRootKeySupplier - Variable in class alluxio.underfs.ObjectUnderFileSystem
The root key of an object fs.
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
 
mServerUserState - Variable in class alluxio.master.backup.AbstractBackupRole
User information for server.
mServiceVersion - Variable in class alluxio.AbstractClient
Stores the service version; used for detecting incompatible client-server pairs.
mServletContextHandler - Variable in class alluxio.web.WebServer
 
mSpecToPartition - Variable in class alluxio.master.table.BasePartitionScheme
 
mStart - Variable in class alluxio.master.journal.tool.AbstractJournalDumper
 
mStartTimeMs - Variable in class alluxio.master.CoreMaster
 
mStddev - Variable in class alluxio.job.util.TimeSeries.Summary
 
mStream - Variable in class alluxio.underfs.MultiRangeObjectInputStream
The backing input stream.
mSubject - Variable in class alluxio.security.user.BaseUserState
 
mTaskScheduler - Variable in class alluxio.master.backup.AbstractBackupRole
Task scheduler.
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
 
mType - Variable in class alluxio.conf.Source
 
mUfsConf - Variable in class alluxio.underfs.BaseUnderFileSystem
UFS Configuration options.
mUfsManager - Variable in class alluxio.master.backup.AbstractBackupRole
The manager of all ufs.
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
 
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
 
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.
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.
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.
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.
mUri - Variable in class alluxio.client.file.AlluxioFileOutStream
 
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.security.user.BaseUserState
 
MUST_CACHE_VALUE - Static variable in enum alluxio.grpc.WritePType
MUST_CACHE = 1;
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
 
mValues - Variable in class alluxio.table.common.BaseConfiguration
 
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
 
mVersionService - Variable in class alluxio.AbstractClient
Used to query service version for the remote service type.
mWebServer - Variable in class alluxio.master.MasterProcess
The web ui server.
mWorkDirectory - Variable in class alluxio.master.AbstractLocalAlluxioCluster
 
mWorkerId - Variable in class alluxio.examples.Performance.Worker
 
mWorkers - Variable in class alluxio.master.AbstractLocalAlluxioCluster
 
mWorkerThreads - Variable in class alluxio.master.AbstractLocalAlluxioCluster
 
mWorkingDirPath - Variable in class alluxio.cli.bundler.command.AbstractCollectInfoCommand
 
mXAttr - Variable in class alluxio.master.file.contexts.CreatePathContext
 
mXAttr - Variable in class alluxio.underfs.UfsStatus
 

N

NAME - Static variable in class alluxio.job.plan.load.LoadConfig
 
NAME - Static variable in class alluxio.job.plan.persist.PersistConfig
 
NAME - Static variable in class alluxio.job.plan.replicate.EvictConfig
 
NAME - Static variable in class alluxio.job.plan.replicate.MoveConfig
 
NAME - Static variable in class alluxio.job.plan.replicate.ReplicateConfig
 
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.Metric
 
NAME_FIELD_NUMBER - Static variable in class alluxio.grpc.table.FieldSchema
 
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.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_VALUE - Static variable in enum alluxio.grpc.table.TableInfo.TableType
NATIVE = 0;
nearest(TieredIdentity, List<WorkerNetAddress>, AlluxioConfiguration) - Static method in class alluxio.client.block.util.BlockLocationUtils
 
nearest(TieredIdentity, List<TieredIdentity>, AlluxioConfiguration) - Static method in class alluxio.util.TieredIdentityUtils
 
needsNormalization(String) - Static method in class alluxio.util.URIUtils
Returns true if the path requires normalization.
NetAddress - Class in alluxio.grpc
Address information about masters.
NetAddress.Builder - Class in alluxio.grpc
Address information about masters.
NetAddressOrBuilder - Interface in alluxio.grpc
 
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.
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
 
NetworkAddressUtils - Class in alluxio.util.network
Common network address related utilities shared by all components in Alluxio.
NetworkAddressUtils.ServiceType - Enum in alluxio.util.network
Different types of services that client uses to connect.
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
 
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.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.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.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.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.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.BlockStoreLocationProto
 
newBuilder(BlockStoreLocationProto) - Static method in class alluxio.grpc.BlockStoreLocationProto
 
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.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.Command
 
newBuilder(Command) - Static method in class alluxio.grpc.Command
 
newBuilder() - Static method in class alluxio.grpc.CommitBlockInUfsPOptions
 
newBuilder(CommitBlockInUfsPOptions) - Static method in class alluxio.grpc.CommitBlockInUfsPOptions
 
newBuilder() - Static method in class alluxio.grpc.CommitBlockInUfsPRequest
 
newBuilder(CommitBlockInUfsPRequest) - Static method in class alluxio.grpc.CommitBlockInUfsPRequest
 
newBuilder() - Static method in class alluxio.grpc.CommitBlockInUfsPResponse
 
newBuilder(CommitBlockInUfsPResponse) - Static method in class alluxio.grpc.CommitBlockInUfsPResponse
 
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.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.CreateLocalBlockRequest
 
newBuilder(CreateLocalBlockRequest) - Static method in class alluxio.grpc.CreateLocalBlockRequest
 
newBuilder() - Static method in class alluxio.grpc.CreateLocalBlockResponse
 
newBuilder(CreateLocalBlockResponse) - Static method in class alluxio.grpc.CreateLocalBlockResponse
 
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.ExistsPOptions
 
newBuilder(ExistsPOptions) - Static method in class alluxio.grpc.ExistsPOptions
 
newBuilder() - Static method in class alluxio.grpc.FileBlockInfo
 
newBuilder(FileBlockInfo) - Static method in class alluxio.grpc.FileBlockInfo
 
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.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.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.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.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.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.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.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.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.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.GetSyncPathListPRequest
 
newBuilder(GetSyncPathListPRequest) - Static method in class alluxio.grpc.GetSyncPathListPRequest
 
newBuilder() - Static method in class alluxio.grpc.GetSyncPathListPResponse
 
newBuilder(GetSyncPathListPResponse) - Static method in class alluxio.grpc.GetSyncPathListPResponse
 
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() - 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.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.JobServiceSummary
 
newBuilder(JobServiceSummary) - Static method in class alluxio.grpc.JobServiceSummary
 
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.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.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.LoadMetadataPOptions
 
newBuilder(LoadMetadataPOptions) - Static method in class alluxio.grpc.LoadMetadataPOptions
 
newBuilder() - Static method in class alluxio.grpc.LocalityTier
 
newBuilder(LocalityTier) - Static method in class alluxio.grpc.LocalityTier
 
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.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.NetAddress
 
newBuilder(NetAddress) - Static method in class alluxio.grpc.NetAddress
 
newBuilder() - Static method in class alluxio.grpc.OpenFilePOptions
 
newBuilder(OpenFilePOptions) - Static method in class alluxio.grpc.OpenFilePOptions
 
newBuilder() - Static method in class alluxio.grpc.OpenLocalBlockRequest
 
newBuilder(OpenLocalBlockRequest) - Static method in class alluxio.grpc.OpenLocalBlockRequest
 
newBuilder() - Static method in class alluxio.grpc.OpenLocalBlockResponse
 
newBuilder(OpenLocalBlockResponse) - Static method in class alluxio.grpc.OpenLocalBlockResponse
 
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.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.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.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.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.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.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.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.StartSyncPOptions
 
newBuilder(StartSyncPOptions) - Static method in class alluxio.grpc.StartSyncPOptions
 
newBuilder() - Static method in class alluxio.grpc.StartSyncPRequest
 
newBuilder(StartSyncPRequest) - Static method in class alluxio.grpc.StartSyncPRequest
 
newBuilder() - Static method in class alluxio.grpc.StartSyncPResponse
 
newBuilder(StartSyncPResponse) - Static method in class alluxio.grpc.StartSyncPResponse
 
newBuilder() - Static method in class alluxio.grpc.StatusSummary
 
newBuilder(StatusSummary) - Static method in class alluxio.grpc.StatusSummary
 
newBuilder() - Static method in class alluxio.grpc.StopSyncPOptions
 
newBuilder(StopSyncPOptions) - Static method in class alluxio.grpc.StopSyncPOptions
 
newBuilder() - Static method in class alluxio.grpc.StopSyncPRequest
 
newBuilder(StopSyncPRequest) - Static method in class alluxio.grpc.StopSyncPRequest
 
newBuilder() - Static method in class alluxio.grpc.StopSyncPResponse
 
newBuilder(StopSyncPResponse) - Static method in class alluxio.grpc.StopSyncPResponse
 
newBuilder() - Static method in class alluxio.grpc.StorageList
 
newBuilder(StorageList) - Static method in class alluxio.grpc.StorageList
 
newBuilder() - Static method in class alluxio.grpc.SyncPointInfo
 
newBuilder(SyncPointInfo) - Static method in class alluxio.grpc.SyncPointInfo
 
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.TieredIdentity
 
newBuilder(TieredIdentity) - Static method in class alluxio.grpc.TieredIdentity
 
newBuilder() - Static method in class alluxio.grpc.TierList
 
newBuilder(TierList) - Static method in class alluxio.grpc.TierList
 
newBuilder() - Static method in class alluxio.grpc.TransportMessage
 
newBuilder(TransportMessage) - Static method in class alluxio.grpc.TransportMessage
 
newBuilder() - Static method in class alluxio.grpc.UfsInfo
 
newBuilder(UfsInfo) - Static method in class alluxio.grpc.UfsInfo
 
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.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.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.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.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.CreateUfsBlockOptions
 
newBuilder(Protocol.CreateUfsBlockOptions) - Static method in class alluxio.proto.dataserver.Protocol.CreateUfsBlockOptions
 
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.OpenUfsBlockOptions
 
newBuilder(Protocol.OpenUfsBlockOptions) - Static method in class alluxio.proto.dataserver.Protocol.OpenUfsBlockOptions
 
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.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.Journal.JournalEntry
 
newBuilder(Journal.JournalEntry) - Static method in class alluxio.proto.journal.Journal.JournalEntry
 
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.Table.AddTableEntry
 
newBuilder(Table.AddTableEntry) - Static method in class alluxio.proto.journal.Table.AddTableEntry
 
newBuilder() - Static method in class alluxio.proto.journal.Table.AddTransformJobInfoEntry
 
newBuilder(Table.AddTransformJobInfoEntry) - Static method in class alluxio.proto.journal.Table.AddTransformJobInfoEntry
 
newBuilder() - Static method in class alluxio.proto.journal.Table.AttachDbEntry
 
newBuilder(Table.AttachDbEntry) - Static method in class alluxio.proto.journal.Table.AttachDbEntry
 
newBuilder() - Static method in class alluxio.proto.journal.Table.CompleteTransformTableEntry
 
newBuilder(Table.CompleteTransformTableEntry) - Static method in class alluxio.proto.journal.Table.CompleteTransformTableEntry
 
newBuilder() - Static method in class alluxio.proto.journal.Table.DetachDbEntry
 
newBuilder(Table.DetachDbEntry) - Static method in class alluxio.proto.journal.Table.DetachDbEntry
 
newBuilder() - Static method in class alluxio.proto.journal.Table.RemoveTableEntry
 
newBuilder(Table.RemoveTableEntry) - Static method in class alluxio.proto.journal.Table.RemoveTableEntry
 
newBuilder() - Static method in class alluxio.proto.journal.Table.RemoveTransformJobInfoEntry
 
newBuilder(Table.RemoveTransformJobInfoEntry) - Static method in class alluxio.proto.journal.Table.RemoveTransformJobInfoEntry
 
newBuilder() - Static method in class alluxio.proto.journal.Table.UpdateDatabaseInfoEntry
 
newBuilder(Table.UpdateDatabaseInfoEntry) - Static method in class alluxio.proto.journal.Table.UpdateDatabaseInfoEntry
 
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.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.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.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.BlockStoreLocationProto
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class alluxio.grpc.BlockStoreLocationProto
 
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.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.Command
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class alluxio.grpc.Command
 
newBuilderForType() - Method in class alluxio.grpc.CommitBlockInUfsPOptions
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class alluxio.grpc.CommitBlockInUfsPOptions
 
newBuilderForType() - Method in class alluxio.grpc.CommitBlockInUfsPRequest
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class alluxio.grpc.CommitBlockInUfsPRequest
 
newBuilderForType() - Method in class alluxio.grpc.CommitBlockInUfsPResponse
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class alluxio.grpc.CommitBlockInUfsPResponse
 
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.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.CreateLocalBlockRequest
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class alluxio.grpc.CreateLocalBlockRequest
 
newBuilderForType() - Method in class alluxio.grpc.CreateLocalBlockResponse
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class alluxio.grpc.CreateLocalBlockResponse
 
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.ExistsPOptions
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class alluxio.grpc.ExistsPOptions
 
newBuilderForType() - Method in class alluxio.grpc.FileBlockInfo
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class alluxio.grpc.FileBlockInfo
 
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.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.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.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.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.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.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.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.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.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.GetSyncPathListPRequest
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class alluxio.grpc.GetSyncPathListPRequest
 
newBuilderForType() - Method in class alluxio.grpc.GetSyncPathListPResponse
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class alluxio.grpc.GetSyncPathListPResponse
 
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.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.JobServiceSummary
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class alluxio.grpc.JobServiceSummary
 
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.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.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.LoadMetadataPOptions
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class alluxio.grpc.LoadMetadataPOptions
 
newBuilderForType() - Method in class alluxio.grpc.LocalityTier
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class alluxio.grpc.LocalityTier
 
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.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.NetAddress
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class alluxio.grpc.NetAddress
 
newBuilderForType() - Method in class alluxio.grpc.OpenFilePOptions
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class alluxio.grpc.OpenFilePOptions
 
newBuilderForType() - Method in class alluxio.grpc.OpenLocalBlockRequest
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class alluxio.grpc.OpenLocalBlockRequest
 
newBuilderForType() - Method in class alluxio.grpc.OpenLocalBlockResponse
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class alluxio.grpc.OpenLocalBlockResponse
 
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.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.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.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.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.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.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.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.StartSyncPOptions
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class alluxio.grpc.StartSyncPOptions
 
newBuilderForType() - Method in class alluxio.grpc.StartSyncPRequest
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class alluxio.grpc.StartSyncPRequest
 
newBuilderForType() - Method in class alluxio.grpc.StartSyncPResponse
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class alluxio.grpc.StartSyncPResponse
 
newBuilderForType() - Method in class alluxio.grpc.StatusSummary
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class alluxio.grpc.StatusSummary
 
newBuilderForType() - Method in class alluxio.grpc.StopSyncPOptions
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class alluxio.grpc.StopSyncPOptions
 
newBuilderForType() - Method in class alluxio.grpc.StopSyncPRequest
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class alluxio.grpc.StopSyncPRequest
 
newBuilderForType() - Method in class alluxio.grpc.StopSyncPResponse
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class alluxio.grpc.StopSyncPResponse
 
newBuilderForType() - Method in class alluxio.grpc.StorageList
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class alluxio.grpc.StorageList
 
newBuilderForType() - Method in class alluxio.grpc.SyncPointInfo
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class alluxio.grpc.SyncPointInfo
 
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.TieredIdentity
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class alluxio.grpc.TieredIdentity
 
newBuilderForType() - Method in class alluxio.grpc.TierList
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class alluxio.grpc.TierList
 
newBuilderForType() - Method in class alluxio.grpc.TransportMessage
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class alluxio.grpc.TransportMessage
 
newBuilderForType() - Method in class alluxio.grpc.UfsInfo
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class alluxio.grpc.UfsInfo
 
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.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.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.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.CreateUfsBlockOptions
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class alluxio.proto.dataserver.Protocol.CreateUfsBlockOptions
 
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.OpenUfsBlockOptions
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class alluxio.proto.dataserver.Protocol.OpenUfsBlockOptions
 
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.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.Journal.JournalEntry
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class alluxio.proto.journal.Journal.JournalEntry
 
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.Table.AddTableEntry
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class alluxio.proto.journal.Table.AddTableEntry
 
newBuilderForType() - Method in class alluxio.proto.journal.Table.AddTransformJobInfoEntry
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class alluxio.proto.journal.Table.AddTransformJobInfoEntry
 
newBuilderForType() - Method in class alluxio.proto.journal.Table.AttachDbEntry
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class alluxio.proto.journal.Table.AttachDbEntry
 
newBuilderForType() - Method in class alluxio.proto.journal.Table.CompleteTransformTableEntry
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class alluxio.proto.journal.Table.CompleteTransformTableEntry
 
newBuilderForType() - Method in class alluxio.proto.journal.Table.DetachDbEntry
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class alluxio.proto.journal.Table.DetachDbEntry
 
newBuilderForType() - Method in class alluxio.proto.journal.Table.RemoveTableEntry
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class alluxio.proto.journal.Table.RemoveTableEntry
 
newBuilderForType() - Method in class alluxio.proto.journal.Table.RemoveTransformJobInfoEntry
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class alluxio.proto.journal.Table.RemoveTransformJobInfoEntry
 
newBuilderForType() - Method in class alluxio.proto.journal.Table.UpdateDatabaseInfoEntry
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class alluxio.proto.journal.Table.UpdateDatabaseInfoEntry
 
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.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
 
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.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.MetricsMasterClientServiceGrpc
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.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.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.BlockStoreLocationProto
 
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.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.Command
 
newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class alluxio.grpc.CommitBlockInUfsPOptions
 
newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class alluxio.grpc.CommitBlockInUfsPRequest
 
newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class alluxio.grpc.CommitBlockInUfsPResponse
 
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.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.CreateLocalBlockRequest
 
newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class alluxio.grpc.CreateLocalBlockResponse
 
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.ExistsPOptions
 
newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class alluxio.grpc.FileBlockInfo
 
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.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.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.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.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.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.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.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.GetServiceVersionPRequest
 
newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class alluxio.grpc.GetServiceVersionPResponse
 
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.GetSyncPathListPRequest
 
newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class alluxio.grpc.GetSyncPathListPResponse
 
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.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.JobServiceSummary
 
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.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.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.LoadMetadataPOptions
 
newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class alluxio.grpc.LocalityTier
 
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.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.NetAddress
 
newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class alluxio.grpc.OpenFilePOptions
 
newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class alluxio.grpc.OpenLocalBlockRequest
 
newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class alluxio.grpc.OpenLocalBlockResponse
 
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.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.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.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.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.ReverseResolvePRequest
 
newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class alluxio.grpc.ReverseResolvePResponse
 
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.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.StartSyncPOptions
 
newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class alluxio.grpc.StartSyncPRequest
 
newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class alluxio.grpc.StartSyncPResponse
 
newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class alluxio.grpc.StatusSummary
 
newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class alluxio.grpc.StopSyncPOptions
 
newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class alluxio.grpc.StopSyncPRequest
 
newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class alluxio.grpc.StopSyncPResponse
 
newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class alluxio.grpc.StorageList
 
newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class alluxio.grpc.SyncPointInfo
 
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.TieredIdentity
 
newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class alluxio.grpc.TierList
 
newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class alluxio.grpc.TransportMessage
 
newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class alluxio.grpc.UfsInfo
 
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.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.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.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.CreateUfsBlockOptions
 
newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class alluxio.proto.dataserver.Protocol.CreateUfsFileOptions
 
newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class alluxio.proto.dataserver.Protocol.OpenUfsBlockOptions
 
newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class alluxio.proto.dataserver.Protocol.Response
 
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.Journal.JournalEntry
 
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.Table.AddTableEntry
 
newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class alluxio.proto.journal.Table.AddTransformJobInfoEntry
 
newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class alluxio.proto.journal.Table.AttachDbEntry
 
newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class alluxio.proto.journal.Table.CompleteTransformTableEntry
 
newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class alluxio.proto.journal.Table.DetachDbEntry
 
newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class alluxio.proto.journal.Table.RemoveTableEntry
 
newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class alluxio.proto.journal.Table.RemoveTransformJobInfoEntry
 
newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class alluxio.proto.journal.Table.UpdateDatabaseInfoEntry
 
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.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
 
newStorageDir(StorageTier, int, long, String, String) - Static method in class alluxio.worker.block.meta.StorageDir
Factory method to create StorageDir.
newStorageTier(String) - Static method in class alluxio.worker.block.meta.StorageTier
Factory method to create StorageTier.
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.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.MetricsMasterClientServiceGrpc
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 interface alluxio.concurrent.jsr.ForkJoinPool.ForkJoinWorkerThreadFactory
Returns a new worker thread operating in the given pool.
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 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_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.
nextEntry() - Method in class alluxio.master.journal.checkpoint.JournalCheckpointFormat.JournalCheckpointReader
 
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
 
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
 
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_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.proxy.s3.S3ErrorCode.Name
 
NO_SUCH_BUCKET - Static variable in class alluxio.proxy.s3.S3ErrorCode
 
NO_SUCH_KEY - Static variable in class alluxio.proxy.s3.S3ErrorCode.Name
 
NO_SUCH_KEY - Static variable in class alluxio.proxy.s3.S3ErrorCode
 
NO_SUCH_UPLOAD - Static variable in class alluxio.proxy.s3.S3ErrorCode.Name
 
NO_SUCH_UPLOAD - Static variable in class alluxio.proxy.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.
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.
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
 
nonClientScopePropertyException(PropertyKey) - Static method in class alluxio.cli.fsadmin.pathconf.AddCommand
 
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
 
NOOP_TRACKER - Static variable in interface alluxio.master.file.contexts.CallTracker
Used when call tracking is not desired.
NoopBlockDeletionContext - Class in alluxio.master.file
Implementation of DefaultBlockDeletionContext which does nothing.
NoopBlockDeletionContext() - Constructor for class alluxio.master.file.NoopBlockDeletionContext
 
NoopHdfsAclProvider - Class in alluxio.underfs.hdfs
The noop HDFS ACL provider.
NoopHdfsAclProvider() - Constructor for class alluxio.underfs.hdfs.NoopHdfsAclProvider
 
NoopHdfsActiveSyncProvider - Class in alluxio.underfs.hdfs
The noop HDFS Active Sync provider.
NoopHdfsActiveSyncProvider() - Constructor for class alluxio.underfs.hdfs.NoopHdfsActiveSyncProvider
 
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.
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
 
NoopUserState - Class in alluxio.security.user
A UserState implementation which does nothing.
NoopUserState.Factory - Class in alluxio.security.user
Factory class to create the user state.
normalizePath(String) - Static method in class alluxio.AlluxioURI
Normalize the path component of the AlluxioURI, by replacing all "//" and "\\" with "/", and trimming trailing slash from non-root path (ignoring windows drive).
normalizePath(String, String) - Static method in class alluxio.util.io.PathUtils
Adds a trailing separator if it does not exist in path.
NOSASL_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_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
 
Nothing_VALUE - Static variable in enum alluxio.grpc.CommandType
Nothing = 1;
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.
notifySuccess() - Method in class alluxio.multi.process.MultiProcessCluster
Informs the cluster that the test succeeded.
notifySyncedPath(String, DescendantType) - Method in class alluxio.master.file.meta.UfsSyncPathCache
Notifies the cache that the path was synced.
notifyTaskCompletion(long, long, Serializable) - Method in class alluxio.worker.job.task.TaskExecutorManager
Notifies the completion of the task.
notifyTaskFailure(long, long, String) - 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.
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
 

O

OBJECT_PARAM - Static variable in class alluxio.proxy.s3.S3RestServiceHandler
 
objectCommonPrefixesIsDirectoryTest() - Method in class alluxio.examples.UnderFileSystemCommonOperations
Test for checking directory in object storage.
objectCommonPrefixesListStatusNonRecursiveTest() - Method in class alluxio.examples.UnderFileSystemCommonOperations
Test for listing status non recursively in object storage.
objectCommonPrefixesListStatusRecursiveTest() - Method in class alluxio.examples.UnderFileSystemCommonOperations
Test for listing status recursively in object storage.
objectNestedDirsListStatusRecursiveTest() - Method in class alluxio.examples.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.
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.OperationBuffer<T> - Class in alluxio.underfs
Operations added to this buffer are performed concurrently.
ObjectUnderFileSystem.OperationBuffer.OperationThread - Class in alluxio.underfs
Thread class to operate on a batch of objects.
ObjectUnderFileSystem.RenameBuffer - Class in alluxio.underfs
File paths added to a ObjectUnderFileSystem.RenameBuffer will be renamed concurrently.
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(String) - Static method in enum alluxio.job.plan.transform.Format
 
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_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.WriteRequestCommand
 
OFFSET_FIELD_NUMBER - Static variable in class alluxio.grpc.WriteResponse
 
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
 
ofOrdinal(int) - Static method in enum alluxio.security.authorization.AclAction
 
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, long) - Method in class alluxio.worker.block.AbstractBlockStoreEventListener
 
onAbortBlock(long, long) - Method in class alluxio.worker.block.BlockMetricsReporter
 
onAbortBlock(long, long) - Method in interface alluxio.worker.block.BlockStoreEventListener
Actions when aborting a temporary block.
onAccessBlock(long, long) - Method in class alluxio.worker.block.AbstractBlockStoreEventListener
 
onAccessBlock(long, long) - Method in class alluxio.worker.block.BlockMetricsReporter
 
onAccessBlock(long, long) - Method in interface alluxio.worker.block.BlockStoreEventListener
Actions when accessing a block.
onAccessBlock(long, long) - Method in class alluxio.worker.block.evictor.LRFUEvictor
 
onAccessBlock(long, long) - Method in class alluxio.worker.block.evictor.LRUEvictor
 
onBlockLost(long) - Method in class alluxio.worker.block.AbstractBlockStoreEventListener
 
onBlockLost(long) - Method in class alluxio.worker.block.BlockHeartbeatReporter
 
onBlockLost(long) - Method in class alluxio.worker.block.BlockMetricsReporter
 
onBlockLost(long) - Method in interface alluxio.worker.block.BlockStoreEventListener
Actions when a block is lost.
onBlockLost(long) - Method in class alluxio.worker.block.evictor.LRFUEvictor
 
onBlockLost(long) - Method in class alluxio.worker.block.evictor.LRUEvictor
 
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.
onCancel() - Method in class alluxio.worker.grpc.DelegationWriteHandler
Handles cancel event from the client.
ONCE_VALUE - Static variable in enum alluxio.grpc.LoadMetadataPType
Load metadata only once.
OnceSupplier<T> - Class in alluxio.master.journal.raft
Supplier that supplies a value only once, then throws an exception if it is called again.
OnceSupplier(T) - Constructor for class alluxio.master.journal.raft.OnceSupplier
 
onClose(Consumer<Connection>) - Method in class alluxio.master.transport.GrpcMessagingConnection
 
onCommitBlock(long, long, BlockStoreLocation) - Method in class alluxio.worker.block.AbstractBlockStoreEventListener
 
onCommitBlock(long, long, BlockStoreLocation) - Method in interface alluxio.worker.block.BlockStoreEventListener
Actions when committing a temporary block to a BlockStoreLocation.
onCommitBlock(long, long, BlockStoreLocation) - Method in class alluxio.worker.block.evictor.LRFUEvictor
 
onCommitBlock(long, long, BlockStoreLocation) - Method in class alluxio.worker.block.evictor.LRUEvictor
 
onCompleted() - Method in class alluxio.client.block.stream.DataMessageClientResponseObserver
 
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.DelegationWriteHandler
 
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.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.worker.grpc.DataMessageServerRequestObserver
 
onError(Throwable) - Method in class alluxio.worker.grpc.DataMessageServerStreamObserver
 
onError(Throwable) - Method in class alluxio.worker.grpc.DelegationWriteHandler
 
onException(Consumer<Throwable>) - Method in class alluxio.master.transport.GrpcMessagingConnection
 
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.grpc.CreateLocalBlockRequest
 
onMoveBlockByClient(long, long, BlockStoreLocation, BlockStoreLocation) - Method in class alluxio.worker.block.AbstractBlockStoreEventListener
 
onMoveBlockByClient(long, long, BlockStoreLocation, BlockStoreLocation) - Method in class alluxio.worker.block.BlockHeartbeatReporter
 
onMoveBlockByClient(long, long, BlockStoreLocation, BlockStoreLocation) - Method in class alluxio.worker.block.BlockMetricsReporter
 
onMoveBlockByClient(long, 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, long, BlockStoreLocation, BlockStoreLocation) - Method in class alluxio.worker.block.AbstractBlockStoreEventListener
 
onMoveBlockByWorker(long, long, BlockStoreLocation, BlockStoreLocation) - Method in class alluxio.worker.block.BlockHeartbeatReporter
 
onMoveBlockByWorker(long, long, BlockStoreLocation, BlockStoreLocation) - Method in class alluxio.worker.block.BlockMetricsReporter
 
onMoveBlockByWorker(long, long, BlockStoreLocation, BlockStoreLocation) - Method in interface alluxio.worker.block.BlockStoreEventListener
Actions when moving a block by a worker from a BlockStoreLocation to another.
onNext(RespT) - Method in class alluxio.client.block.stream.DataMessageClientResponseObserver
 
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(WriteRequest) - Method in class alluxio.worker.grpc.DelegationWriteHandler
 
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) - Method in class alluxio.master.metastore.caching.Cache
Callback triggered whenever a new key/value pair is added by put(key, value).
onRemove(K) - Method in class alluxio.master.metastore.caching.Cache
Callback triggered whenever a key is removed by remove(key).
onRemoveBlockByClient(long, long) - Method in class alluxio.worker.block.AbstractBlockStoreEventListener
 
onRemoveBlockByClient(long, long) - Method in class alluxio.worker.block.BlockHeartbeatReporter
 
onRemoveBlockByClient(long, long) - Method in class alluxio.worker.block.BlockMetricsReporter
 
onRemoveBlockByClient(long, long) - Method in interface alluxio.worker.block.BlockStoreEventListener
Actions when removing an existing block.
onRemoveBlockByClient(long, long) - Method in class alluxio.worker.block.evictor.LRFUEvictor
 
onRemoveBlockByClient(long, long) - Method in class alluxio.worker.block.evictor.LRUEvictor
 
onRemoveBlockByWorker(long, long) - Method in class alluxio.worker.block.AbstractBlockStoreEventListener
 
onRemoveBlockByWorker(long, long) - Method in class alluxio.worker.block.BlockHeartbeatReporter
 
onRemoveBlockByWorker(long, long) - Method in class alluxio.worker.block.BlockMetricsReporter
 
onRemoveBlockByWorker(long, long) - Method in interface alluxio.worker.block.BlockStoreEventListener
Actions when removing an existing block by worker.
onRemoveBlockByWorker(long, long) - Method in class alluxio.worker.block.evictor.LRFUEvictor
 
onRemoveBlockByWorker(long, long) - Method in class alluxio.worker.block.evictor.LRUEvictor
 
onRemoveBlockFromIterator(long) - Method in class alluxio.worker.block.evictor.AbstractEvictor
Performs additional cleanup when a block is removed from the iterator returned by AbstractEvictor.getBlockIterator().
onRemoveBlockFromIterator(long) - Method in class alluxio.worker.block.evictor.LRFUEvictor
 
onRemoveBlockFromIterator(long) - Method in class alluxio.worker.block.evictor.LRUEvictor
 
onStart() - Method in class alluxio.concurrent.jsr.ForkJoinWorkerThread
Initializes internal state after construction but before processing any tasks.
onStateChange(Consumer<PrimarySelector.State>) - Method in class alluxio.master.AbstractPrimarySelector
 
onStateChange(Consumer<PrimarySelector.State>) - Method in interface alluxio.master.PrimarySelector
Registers a listener to be executed whenever the selector's state updates.
onStorageLost(String, String) - Method in class alluxio.worker.block.AbstractBlockStoreEventListener
 
onStorageLost(String, String) - Method in class alluxio.worker.block.BlockHeartbeatReporter
 
onStorageLost(String, String) - 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.
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(String) - Method in class alluxio.concurrent.ManagedBlockingUfsForwarder
 
open(String, OpenOptions) - Method in class alluxio.concurrent.ManagedBlockingUfsForwarder
 
open(String, FuseFileInfo) - Method in class alluxio.fuse.AlluxioFuseFileSystem
Opens an existing file for reading.
open(Path, int) - Method in class alluxio.hadoop.AbstractFileSystem
Attempts to open the specified file for reading.
open(Path, int) - Method in class alluxio.hadoop.LocalCacheFileSystem
 
open(URIStatus, int) - Method in class alluxio.hadoop.LocalCacheFileSystem
Attempts to open the specified file for reading.
open(String) - Method in class alluxio.underfs.BaseUnderFileSystem
 
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(String, OpenOptions) - Method in class alluxio.underfs.web.WebUnderFileSystem
 
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.ReadRequest
 
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(String, Throwable) - Constructor for exception alluxio.exception.OpenDirectoryException
Constructs a new exception with the specified detail message and cause.
OpenDirectoryException(ExceptionMessage, Object...) - Constructor for exception alluxio.exception.OpenDirectoryException
Constructs a new exception with the specified exception message and multiple parameters.
OpenDirectoryException(ExceptionMessage, Throwable, Object...) - Constructor for exception alluxio.exception.OpenDirectoryException
Constructs a new exception with the specified exception message, the cause and multiple parameters.
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.BaseFileSystem
 
openFile(URIStatus, OpenFilePOptions) - Method in class alluxio.client.file.BaseFileSystem
 
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) - 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.hadoop.AlluxioHdfsFileSystem
 
openFile(URIStatus, OpenFilePOptions) - Method in class alluxio.hadoop.AlluxioHdfsFileSystem
 
openFile(String, OpenFilePOptions) - Method in class alluxio.proxy.PathsRestServiceHandler
 
openFileDefaults(AlluxioConfiguration) - Static method in class alluxio.util.FileSystemOptions
 
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
 
openLocalBlock(StreamObserver<OpenLocalBlockResponse>) - Method in interface alluxio.client.block.stream.BlockWorkerClient
Opens a local block.
openLocalBlock(StreamObserver<OpenLocalBlockResponse>) - Method in class alluxio.client.block.stream.DefaultBlockWorkerClient
 
openLocalBlock(StreamObserver<OpenLocalBlockResponse>) - Method in class alluxio.grpc.BlockWorkerGrpc.BlockWorkerImplBase
Replaces ShortCircuitBlockReadHandler.
openLocalBlock(StreamObserver<OpenLocalBlockResponse>) - Method in class alluxio.grpc.BlockWorkerGrpc.BlockWorkerStub
Replaces ShortCircuitBlockReadHandler.
openLocalBlock(StreamObserver<OpenLocalBlockResponse>) - Method in class alluxio.worker.grpc.BlockWorkerImpl
 
OpenLocalBlockRequest - Class in alluxio.grpc
next available id: 3
OpenLocalBlockRequest.Builder - Class in alluxio.grpc
next available id: 3
OpenLocalBlockRequestOrBuilder - Interface in alluxio.grpc
 
OpenLocalBlockResponse - Class in alluxio.grpc
next available id: 2
OpenLocalBlockResponse.Builder - Class in alluxio.grpc
next available id: 2
OpenLocalBlockResponseOrBuilder - 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.kodo.KodoUnderFileSystem
 
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.oss.OSSUnderFileSystem
 
openObject(String, OpenOptions, RetryPolicy) - Method in class alluxio.underfs.s3a.S3AUnderFileSystem
 
openObject(String, OpenOptions, RetryPolicy) - Method in class alluxio.underfs.swift.SwiftUnderFileSystem
 
OpenOptions - Class in alluxio.underfs.options
Method options for file locations in UnderFileSystem.
openUfsBlock(long, long, Protocol.OpenUfsBlockOptions) - Method in interface alluxio.worker.block.BlockWorker
Opens a UFS block.
openUfsBlock(long, long, Protocol.OpenUfsBlockOptions) - Method in class alluxio.worker.block.DefaultBlockWorker
 
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
 
OperationBuffer() - Constructor for class alluxio.underfs.ObjectUnderFileSystem.OperationBuffer
Construct a new ObjectUnderFileSystem.OperationBuffer instance.
OperationContext<T extends com.google.protobuf.GeneratedMessageV3.Builder<?>> - 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.
OperationContext(T, CallTracker) - Constructor for class alluxio.master.file.contexts.OperationContext
Creates an instance with given proto message.
OperationThread(List<T>) - Constructor for class alluxio.underfs.ObjectUnderFileSystem.OperationBuffer.OperationThread
Operate on a batch of inputs.
OPS - Static variable in class alluxio.master.backcompat.BackwardsCompatibilityJournalGenerator
 
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.CheckConsistencyPRequest
 
OPTIONS_FIELD_NUMBER - Static variable in class alluxio.grpc.CommitBlockInUfsPRequest
 
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.FileSystemHeartbeatPRequest
 
OPTIONS_FIELD_NUMBER - Static variable in class alluxio.grpc.FreePRequest
 
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.GetFileInfoPRequest
 
OPTIONS_FIELD_NUMBER - Static variable in class alluxio.grpc.GetJobServiceSummaryPRequest
 
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.GetQuorumInfoPRequest
 
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.ListAllPRequest
 
OPTIONS_FIELD_NUMBER - Static variable in class alluxio.grpc.ListStatusPRequest
 
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.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.RemoveQuorumServerPRequest
 
OPTIONS_FIELD_NUMBER - Static variable in class alluxio.grpc.RenamePRequest
 
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.StartSyncPRequest
 
OPTIONS_FIELD_NUMBER - Static variable in class alluxio.grpc.StopSyncPRequest
 
OPTIONS_FIELD_NUMBER - Static variable in class alluxio.grpc.table.AttachDatabasePRequest
 
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
 
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_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.
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.
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
 
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_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, ClientContext, AlluxioConfiguration) - Constructor for class alluxio.client.file.options.OutStreamOptions
Creates an OutStreamOptions instance from given options.
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.
OVERWRITE_ACCESS_TIME_FIELD_NUMBER - Static variable in class alluxio.proto.journal.File.UpdateInodeEntry
 
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.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_FIELD_NUMBER - Static variable in class alluxio.proto.journal.Table.AddTableEntry
 
OWNER_NAME_FIELD_NUMBER - Static variable in class alluxio.grpc.table.Database
 
OWNER_NAME_FIELD_NUMBER - Static variable in class alluxio.proto.journal.Table.UpdateDatabaseInfoEntry
 
OWNER_TYPE_FIELD_NUMBER - Static variable in class alluxio.grpc.table.Database
 
OWNER_TYPE_FIELD_NUMBER - Static variable in class alluxio.proto.journal.Table.UpdateDatabaseInfoEntry
 
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
 

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
 
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) - Constructor for class alluxio.client.file.cache.PageInfo
 
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.
pages() - Method in class alluxio.client.file.cache.DefaultMetaStore
 
pages() - Method in interface alluxio.client.file.cache.MetaStore
 
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.
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.
parallelStream() - Method in class alluxio.collections.DelegatingSet
 
PARAMETER_FIELD_NUMBER - Static variable in class alluxio.grpc.table.Database
 
PARAMETER_FIELD_NUMBER - Static variable in class alluxio.proto.journal.Table.UpdateDatabaseInfoEntry
 
PARAMETERS_FIELD_NUMBER - Static variable in class alluxio.grpc.table.layout.hive.PartitionInfo
 
PARAMETERS_FIELD_NUMBER - Static variable in class alluxio.grpc.table.TableInfo
 
PARAMETERS_FIELD_NUMBER - Static variable in class alluxio.proto.journal.Table.AddTableEntry
 
parametersToString(Object...) - Static method in class alluxio.util.FormatUtils
Parses a list of Objects into a String.
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
 
PARQUET_INPUT_FORMAT_CLASS - Static variable in class alluxio.job.plan.transform.HiveConstants
Parquet input format.
PARQUET_OUTPUT_FORMAT_CLASS - Static variable in class alluxio.job.plan.transform.HiveConstants
Parquet output format.
PARQUET_SERDE_CLASS - Static variable in class alluxio.job.plan.transform.HiveConstants
Parquet serde class.
ParquetReader - Class in alluxio.job.plan.transform.format.parquet
A reader for reading ParquetRow.
ParquetRow - Class in alluxio.job.plan.transform.format.parquet
A row in a Parquet table represented in Avro format.
ParquetRow(GenericData.Record) - Constructor for class alluxio.job.plan.transform.format.parquet.ParquetRow
 
ParquetSchema - Class in alluxio.job.plan.transform.format.parquet
Parquet table schema in Avro format.
ParquetSchema(Schema) - Constructor for class alluxio.job.plan.transform.format.parquet.ParquetSchema
 
ParquetWriter - Class in alluxio.job.plan.transform.format.parquet
A writer for writing ParquetRow.
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.table.common.transform.action.TransformAction.Parser
 
parse(String) - Static method in class alluxio.table.common.transform.TransformDefinition
 
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.
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.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.BlockStoreLocationProto
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.BlockStoreLocationProto
 
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.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.Command
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.Command
 
parseDelimitedFrom(InputStream) - Static method in class alluxio.grpc.CommitBlockInUfsPOptions
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.CommitBlockInUfsPOptions
 
parseDelimitedFrom(InputStream) - Static method in class alluxio.grpc.CommitBlockInUfsPRequest
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.CommitBlockInUfsPRequest
 
parseDelimitedFrom(InputStream) - Static method in class alluxio.grpc.CommitBlockInUfsPResponse
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.CommitBlockInUfsPResponse
 
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.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.CreateLocalBlockRequest
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.CreateLocalBlockRequest
 
parseDelimitedFrom(InputStream) - Static method in class alluxio.grpc.CreateLocalBlockResponse
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.CreateLocalBlockResponse
 
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.ExistsPOptions
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.ExistsPOptions
 
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.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.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.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.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.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.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.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.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.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.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.GetSyncPathListPRequest
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.GetSyncPathListPRequest
 
parseDelimitedFrom(InputStream) - Static method in class alluxio.grpc.GetSyncPathListPResponse
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.GetSyncPathListPResponse
 
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.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.JobServiceSummary
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.JobServiceSummary
 
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.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.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.LoadMetadataPOptions
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.LoadMetadataPOptions
 
parseDelimitedFrom(InputStream) - Static method in class alluxio.grpc.LocalityTier
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.LocalityTier
 
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.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.NetAddress
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.NetAddress
 
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.OpenLocalBlockRequest
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.OpenLocalBlockRequest
 
parseDelimitedFrom(InputStream) - Static method in class alluxio.grpc.OpenLocalBlockResponse
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.OpenLocalBlockResponse
 
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.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.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.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.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.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.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.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.StartSyncPOptions
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.StartSyncPOptions
 
parseDelimitedFrom(InputStream) - Static method in class alluxio.grpc.StartSyncPRequest
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.StartSyncPRequest
 
parseDelimitedFrom(InputStream) - Static method in class alluxio.grpc.StartSyncPResponse
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.StartSyncPResponse
 
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.StopSyncPOptions
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.StopSyncPOptions
 
parseDelimitedFrom(InputStream) - Static method in class alluxio.grpc.StopSyncPRequest
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.StopSyncPRequest
 
parseDelimitedFrom(InputStream) - Static method in class alluxio.grpc.StopSyncPResponse
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.StopSyncPResponse
 
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.SyncPointInfo
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.SyncPointInfo
 
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.TieredIdentity
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.TieredIdentity
 
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.TransportMessage
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.TransportMessage
 
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.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.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.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.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.CreateUfsBlockOptions
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.proto.dataserver.Protocol.CreateUfsBlockOptions
 
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.OpenUfsBlockOptions
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.proto.dataserver.Protocol.OpenUfsBlockOptions
 
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.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.Journal.JournalEntry
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.proto.journal.Journal.JournalEntry
 
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.Table.AddTableEntry
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.proto.journal.Table.AddTableEntry
 
parseDelimitedFrom(InputStream) - Static method in class alluxio.proto.journal.Table.AddTransformJobInfoEntry
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.proto.journal.Table.AddTransformJobInfoEntry
 
parseDelimitedFrom(InputStream) - Static method in class alluxio.proto.journal.Table.AttachDbEntry
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.proto.journal.Table.AttachDbEntry
 
parseDelimitedFrom(InputStream) - Static method in class alluxio.proto.journal.Table.CompleteTransformTableEntry
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.proto.journal.Table.CompleteTransformTableEntry
 
parseDelimitedFrom(InputStream) - Static method in class alluxio.proto.journal.Table.DetachDbEntry
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.proto.journal.Table.DetachDbEntry
 
parseDelimitedFrom(InputStream) - Static method in class alluxio.proto.journal.Table.RemoveTableEntry
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.proto.journal.Table.RemoveTableEntry
 
parseDelimitedFrom(InputStream) - Static method in class alluxio.proto.journal.Table.RemoveTransformJobInfoEntry
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.proto.journal.Table.RemoveTransformJobInfoEntry
 
parseDelimitedFrom(InputStream) - Static method in class alluxio.proto.journal.Table.UpdateDatabaseInfoEntry
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.proto.journal.Table.UpdateDatabaseInfoEntry
 
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.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.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.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.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.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.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.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.CommitBlockInUfsPOptions
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class alluxio.grpc.CommitBlockInUfsPOptions
 
parseFrom(ByteString) - Static method in class alluxio.grpc.CommitBlockInUfsPOptions
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class alluxio.grpc.CommitBlockInUfsPOptions
 
parseFrom(byte[]) - Static method in class alluxio.grpc.CommitBlockInUfsPOptions
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class alluxio.grpc.CommitBlockInUfsPOptions
 
parseFrom(InputStream) - Static method in class alluxio.grpc.CommitBlockInUfsPOptions
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.CommitBlockInUfsPOptions
 
parseFrom(CodedInputStream) - Static method in class alluxio.grpc.CommitBlockInUfsPOptions
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.CommitBlockInUfsPOptions
 
parseFrom(ByteBuffer) - Static method in class alluxio.grpc.CommitBlockInUfsPRequest
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class alluxio.grpc.CommitBlockInUfsPRequest
 
parseFrom(ByteString) - Static method in class alluxio.grpc.CommitBlockInUfsPRequest
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class alluxio.grpc.CommitBlockInUfsPRequest
 
parseFrom(byte[]) - Static method in class alluxio.grpc.CommitBlockInUfsPRequest
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class alluxio.grpc.CommitBlockInUfsPRequest
 
parseFrom(InputStream) - Static method in class alluxio.grpc.CommitBlockInUfsPRequest
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.CommitBlockInUfsPRequest
 
parseFrom(CodedInputStream) - Static method in class alluxio.grpc.CommitBlockInUfsPRequest
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.CommitBlockInUfsPRequest
 
parseFrom(ByteBuffer) - Static method in class alluxio.grpc.CommitBlockInUfsPResponse
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class alluxio.grpc.CommitBlockInUfsPResponse
 
parseFrom(ByteString) - Static method in class alluxio.grpc.CommitBlockInUfsPResponse
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class alluxio.grpc.CommitBlockInUfsPResponse
 
parseFrom(byte[]) - Static method in class alluxio.grpc.CommitBlockInUfsPResponse
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class alluxio.grpc.CommitBlockInUfsPResponse
 
parseFrom(InputStream) - Static method in class alluxio.grpc.CommitBlockInUfsPResponse
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.CommitBlockInUfsPResponse
 
parseFrom(CodedInputStream) - Static method in class alluxio.grpc.CommitBlockInUfsPResponse
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.CommitBlockInUfsPResponse
 
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.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.CreateLocalBlockRequest
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class alluxio.grpc.CreateLocalBlockRequest
 
parseFrom(ByteString) - Static method in class alluxio.grpc.CreateLocalBlockRequest
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class alluxio.grpc.CreateLocalBlockRequest
 
parseFrom(byte[]) - Static method in class alluxio.grpc.CreateLocalBlockRequest
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class alluxio.grpc.CreateLocalBlockRequest
 
parseFrom(InputStream) - Static method in class alluxio.grpc.CreateLocalBlockRequest
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.CreateLocalBlockRequest
 
parseFrom(CodedInputStream) - Static method in class alluxio.grpc.CreateLocalBlockRequest
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.CreateLocalBlockRequest
 
parseFrom(ByteBuffer) - Static method in class alluxio.grpc.CreateLocalBlockResponse
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class alluxio.grpc.CreateLocalBlockResponse
 
parseFrom(ByteString) - Static method in class alluxio.grpc.CreateLocalBlockResponse
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class alluxio.grpc.CreateLocalBlockResponse
 
parseFrom(byte[]) - Static method in class alluxio.grpc.CreateLocalBlockResponse
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class alluxio.grpc.CreateLocalBlockResponse
 
parseFrom(InputStream) - Static method in class alluxio.grpc.CreateLocalBlockResponse
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.CreateLocalBlockResponse
 
parseFrom(CodedInputStream) - Static method in class alluxio.grpc.CreateLocalBlockResponse
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.CreateLocalBlockResponse
 
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.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.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.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.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.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.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.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.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.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.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.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.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.GetSyncPathListPRequest
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class alluxio.grpc.GetSyncPathListPRequest
 
parseFrom(ByteString) - Static method in class alluxio.grpc.GetSyncPathListPRequest
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class alluxio.grpc.GetSyncPathListPRequest
 
parseFrom(byte[]) - Static method in class alluxio.grpc.GetSyncPathListPRequest
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class alluxio.grpc.GetSyncPathListPRequest
 
parseFrom(InputStream) - Static method in class alluxio.grpc.GetSyncPathListPRequest
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.GetSyncPathListPRequest
 
parseFrom(CodedInputStream) - Static method in class alluxio.grpc.GetSyncPathListPRequest
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.GetSyncPathListPRequest
 
parseFrom(ByteBuffer) - Static method in class alluxio.grpc.GetSyncPathListPResponse
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class alluxio.grpc.GetSyncPathListPResponse
 
parseFrom(ByteString) - Static method in class alluxio.grpc.GetSyncPathListPResponse
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class alluxio.grpc.GetSyncPathListPResponse
 
parseFrom(byte[]) - Static method in class alluxio.grpc.GetSyncPathListPResponse
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class alluxio.grpc.GetSyncPathListPResponse
 
parseFrom(InputStream) - Static method in class alluxio.grpc.GetSyncPathListPResponse
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.GetSyncPathListPResponse
 
parseFrom(CodedInputStream) - Static method in class alluxio.grpc.GetSyncPathListPResponse
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.GetSyncPathListPResponse
 
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.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.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.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.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.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.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.LocalityTier
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class alluxio.grpc.LocalityTier
 
parseFrom(ByteString) - Static method in class alluxio.grpc.LocalityTier
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class alluxio.grpc.LocalityTier
 
parseFrom(byte[]) - Static method in class alluxio.grpc.LocalityTier
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class alluxio.grpc.LocalityTier
 
parseFrom(InputStream) - Static method in class alluxio.grpc.LocalityTier
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.LocalityTier
 
parseFrom(CodedInputStream) - Static method in class alluxio.grpc.LocalityTier
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.LocalityTier
 
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.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.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.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.OpenLocalBlockRequest
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class alluxio.grpc.OpenLocalBlockRequest
 
parseFrom(ByteString) - Static method in class alluxio.grpc.OpenLocalBlockRequest
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class alluxio.grpc.OpenLocalBlockRequest
 
parseFrom(byte[]) - Static method in class alluxio.grpc.OpenLocalBlockRequest
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class alluxio.grpc.OpenLocalBlockRequest
 
parseFrom(InputStream) - Static method in class alluxio.grpc.OpenLocalBlockRequest
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.OpenLocalBlockRequest
 
parseFrom(CodedInputStream) - Static method in class alluxio.grpc.OpenLocalBlockRequest
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.OpenLocalBlockRequest
 
parseFrom(ByteBuffer) - Static method in class alluxio.grpc.OpenLocalBlockResponse
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class alluxio.grpc.OpenLocalBlockResponse
 
parseFrom(ByteString) - Static method in class alluxio.grpc.OpenLocalBlockResponse
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class alluxio.grpc.OpenLocalBlockResponse
 
parseFrom(byte[]) - Static method in class alluxio.grpc.OpenLocalBlockResponse
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class alluxio.grpc.OpenLocalBlockResponse
 
parseFrom(InputStream) - Static method in class alluxio.grpc.OpenLocalBlockResponse
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.OpenLocalBlockResponse
 
parseFrom(CodedInputStream) - Static method in class alluxio.grpc.OpenLocalBlockResponse
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.OpenLocalBlockResponse
 
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.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.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.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.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.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.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.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.StartSyncPOptions
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class alluxio.grpc.StartSyncPOptions
 
parseFrom(ByteString) - Static method in class alluxio.grpc.StartSyncPOptions
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class alluxio.grpc.StartSyncPOptions
 
parseFrom(byte[]) - Static method in class alluxio.grpc.StartSyncPOptions
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class alluxio.grpc.StartSyncPOptions
 
parseFrom(InputStream) - Static method in class alluxio.grpc.StartSyncPOptions
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.StartSyncPOptions
 
parseFrom(CodedInputStream) - Static method in class alluxio.grpc.StartSyncPOptions
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.StartSyncPOptions
 
parseFrom(ByteBuffer) - Static method in class alluxio.grpc.StartSyncPRequest
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class alluxio.grpc.StartSyncPRequest
 
parseFrom(ByteString) - Static method in class alluxio.grpc.StartSyncPRequest
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class alluxio.grpc.StartSyncPRequest
 
parseFrom(byte[]) - Static method in class alluxio.grpc.StartSyncPRequest
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class alluxio.grpc.StartSyncPRequest
 
parseFrom(InputStream) - Static method in class alluxio.grpc.StartSyncPRequest
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.StartSyncPRequest
 
parseFrom(CodedInputStream) - Static method in class alluxio.grpc.StartSyncPRequest
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.StartSyncPRequest
 
parseFrom(ByteBuffer) - Static method in class alluxio.grpc.StartSyncPResponse
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class alluxio.grpc.StartSyncPResponse
 
parseFrom(ByteString) - Static method in class alluxio.grpc.StartSyncPResponse
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class alluxio.grpc.StartSyncPResponse
 
parseFrom(byte[]) - Static method in class alluxio.grpc.StartSyncPResponse
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class alluxio.grpc.StartSyncPResponse
 
parseFrom(InputStream) - Static method in class alluxio.grpc.StartSyncPResponse
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.StartSyncPResponse
 
parseFrom(CodedInputStream) - Static method in class alluxio.grpc.StartSyncPResponse
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.StartSyncPResponse
 
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.StopSyncPOptions
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class alluxio.grpc.StopSyncPOptions
 
parseFrom(ByteString) - Static method in class alluxio.grpc.StopSyncPOptions
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class alluxio.grpc.StopSyncPOptions
 
parseFrom(byte[]) - Static method in class alluxio.grpc.StopSyncPOptions
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class alluxio.grpc.StopSyncPOptions
 
parseFrom(InputStream) - Static method in class alluxio.grpc.StopSyncPOptions
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.StopSyncPOptions
 
parseFrom(CodedInputStream) - Static method in class alluxio.grpc.StopSyncPOptions
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.StopSyncPOptions
 
parseFrom(ByteBuffer) - Static method in class alluxio.grpc.StopSyncPRequest
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class alluxio.grpc.StopSyncPRequest
 
parseFrom(ByteString) - Static method in class alluxio.grpc.StopSyncPRequest
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class alluxio.grpc.StopSyncPRequest
 
parseFrom(byte[]) - Static method in class alluxio.grpc.StopSyncPRequest
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class alluxio.grpc.StopSyncPRequest
 
parseFrom(InputStream) - Static method in class alluxio.grpc.StopSyncPRequest
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.StopSyncPRequest
 
parseFrom(CodedInputStream) - Static method in class alluxio.grpc.StopSyncPRequest
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.StopSyncPRequest
 
parseFrom(ByteBuffer) - Static method in class alluxio.grpc.StopSyncPResponse
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class alluxio.grpc.StopSyncPResponse
 
parseFrom(ByteString) - Static method in class alluxio.grpc.StopSyncPResponse
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class alluxio.grpc.StopSyncPResponse
 
parseFrom(byte[]) - Static method in class alluxio.grpc.StopSyncPResponse
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class alluxio.grpc.StopSyncPResponse
 
parseFrom(InputStream) - Static method in class alluxio.grpc.StopSyncPResponse
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.StopSyncPResponse
 
parseFrom(CodedInputStream) - Static method in class alluxio.grpc.StopSyncPResponse
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.StopSyncPResponse
 
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.SyncPointInfo
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class alluxio.grpc.SyncPointInfo
 
parseFrom(ByteString) - Static method in class alluxio.grpc.SyncPointInfo
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class alluxio.grpc.SyncPointInfo
 
parseFrom(byte[]) - Static method in class alluxio.grpc.SyncPointInfo
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class alluxio.grpc.SyncPointInfo
 
parseFrom(InputStream) - Static method in class alluxio.grpc.SyncPointInfo
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.SyncPointInfo
 
parseFrom(CodedInputStream) - Static method in class alluxio.grpc.SyncPointInfo
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.SyncPointInfo
 
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.TieredIdentity
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class alluxio.grpc.TieredIdentity
 
parseFrom(ByteString) - Static method in class alluxio.grpc.TieredIdentity
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class alluxio.grpc.TieredIdentity
 
parseFrom(byte[]) - Static method in class alluxio.grpc.TieredIdentity
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class alluxio.grpc.TieredIdentity
 
parseFrom(InputStream) - Static method in class alluxio.grpc.TieredIdentity
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.TieredIdentity
 
parseFrom(CodedInputStream) - Static method in class alluxio.grpc.TieredIdentity
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.TieredIdentity
 
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.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.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.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.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.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.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(Domain) - Static method in class alluxio.master.table.Domain
Parse from protobuf domain to Domain class.
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.CreateUfsBlockOptions
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class alluxio.proto.dataserver.Protocol.CreateUfsBlockOptions
 
parseFrom(ByteString) - Static method in class alluxio.proto.dataserver.Protocol.CreateUfsBlockOptions
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class alluxio.proto.dataserver.Protocol.CreateUfsBlockOptions
 
parseFrom(byte[]) - Static method in class alluxio.proto.dataserver.Protocol.CreateUfsBlockOptions
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class alluxio.proto.dataserver.Protocol.CreateUfsBlockOptions
 
parseFrom(InputStream) - Static method in class alluxio.proto.dataserver.Protocol.CreateUfsBlockOptions
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.proto.dataserver.Protocol.CreateUfsBlockOptions
 
parseFrom(CodedInputStream) - Static method in class alluxio.proto.dataserver.Protocol.CreateUfsBlockOptions
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class alluxio.proto.dataserver.Protocol.CreateUfsBlockOptions
 
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.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.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.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.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.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.Table.AddTableEntry
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class alluxio.proto.journal.Table.AddTableEntry
 
parseFrom(ByteString) - Static method in class alluxio.proto.journal.Table.AddTableEntry
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class alluxio.proto.journal.Table.AddTableEntry
 
parseFrom(byte[]) - Static method in class alluxio.proto.journal.Table.AddTableEntry
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class alluxio.proto.journal.Table.AddTableEntry
 
parseFrom(InputStream) - Static method in class alluxio.proto.journal.Table.AddTableEntry
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.proto.journal.Table.AddTableEntry
 
parseFrom(CodedInputStream) - Static method in class alluxio.proto.journal.Table.AddTableEntry
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class alluxio.proto.journal.Table.AddTableEntry
 
parseFrom(ByteBuffer) - Static method in class alluxio.proto.journal.Table.AddTransformJobInfoEntry
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class alluxio.proto.journal.Table.AddTransformJobInfoEntry
 
parseFrom(ByteString) - Static method in class alluxio.proto.journal.Table.AddTransformJobInfoEntry
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class alluxio.proto.journal.Table.AddTransformJobInfoEntry
 
parseFrom(byte[]) - Static method in class alluxio.proto.journal.Table.AddTransformJobInfoEntry
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class alluxio.proto.journal.Table.AddTransformJobInfoEntry
 
parseFrom(InputStream) - Static method in class alluxio.proto.journal.Table.AddTransformJobInfoEntry
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.proto.journal.Table.AddTransformJobInfoEntry
 
parseFrom(CodedInputStream) - Static method in class alluxio.proto.journal.Table.AddTransformJobInfoEntry
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class alluxio.proto.journal.Table.AddTransformJobInfoEntry
 
parseFrom(ByteBuffer) - Static method in class alluxio.proto.journal.Table.AttachDbEntry
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class alluxio.proto.journal.Table.AttachDbEntry
 
parseFrom(ByteString) - Static method in class alluxio.proto.journal.Table.AttachDbEntry
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class alluxio.proto.journal.Table.AttachDbEntry
 
parseFrom(byte[]) - Static method in class alluxio.proto.journal.Table.AttachDbEntry
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class alluxio.proto.journal.Table.AttachDbEntry
 
parseFrom(InputStream) - Static method in class alluxio.proto.journal.Table.AttachDbEntry
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.proto.journal.Table.AttachDbEntry
 
parseFrom(CodedInputStream) - Static method in class alluxio.proto.journal.Table.AttachDbEntry
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class alluxio.proto.journal.Table.AttachDbEntry
 
parseFrom(ByteBuffer) - Static method in class alluxio.proto.journal.Table.CompleteTransformTableEntry
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class alluxio.proto.journal.Table.CompleteTransformTableEntry
 
parseFrom(ByteString) - Static method in class alluxio.proto.journal.Table.CompleteTransformTableEntry
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class alluxio.proto.journal.Table.CompleteTransformTableEntry
 
parseFrom(byte[]) - Static method in class alluxio.proto.journal.Table.CompleteTransformTableEntry
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class alluxio.proto.journal.Table.CompleteTransformTableEntry
 
parseFrom(InputStream) - Static method in class alluxio.proto.journal.Table.CompleteTransformTableEntry
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.proto.journal.Table.CompleteTransformTableEntry
 
parseFrom(CodedInputStream) - Static method in class alluxio.proto.journal.Table.CompleteTransformTableEntry
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class alluxio.proto.journal.Table.CompleteTransformTableEntry
 
parseFrom(ByteBuffer) - Static method in class alluxio.proto.journal.Table.DetachDbEntry
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class alluxio.proto.journal.Table.DetachDbEntry
 
parseFrom(ByteString) - Static method in class alluxio.proto.journal.Table.DetachDbEntry
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class alluxio.proto.journal.Table.DetachDbEntry
 
parseFrom(byte[]) - Static method in class alluxio.proto.journal.Table.DetachDbEntry
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class alluxio.proto.journal.Table.DetachDbEntry
 
parseFrom(InputStream) - Static method in class alluxio.proto.journal.Table.DetachDbEntry
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.proto.journal.Table.DetachDbEntry
 
parseFrom(CodedInputStream) - Static method in class alluxio.proto.journal.Table.DetachDbEntry
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class alluxio.proto.journal.Table.DetachDbEntry
 
parseFrom(ByteBuffer) - Static method in class alluxio.proto.journal.Table.RemoveTableEntry
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class alluxio.proto.journal.Table.RemoveTableEntry
 
parseFrom(ByteString) - Static method in class alluxio.proto.journal.Table.RemoveTableEntry
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class alluxio.proto.journal.Table.RemoveTableEntry
 
parseFrom(byte[]) - Static method in class alluxio.proto.journal.Table.RemoveTableEntry
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class alluxio.proto.journal.Table.RemoveTableEntry
 
parseFrom(InputStream) - Static method in class alluxio.proto.journal.Table.RemoveTableEntry
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.proto.journal.Table.RemoveTableEntry
 
parseFrom(CodedInputStream) - Static method in class alluxio.proto.journal.Table.RemoveTableEntry
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class alluxio.proto.journal.Table.RemoveTableEntry
 
parseFrom(ByteBuffer) - Static method in class alluxio.proto.journal.Table.RemoveTransformJobInfoEntry
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class alluxio.proto.journal.Table.RemoveTransformJobInfoEntry
 
parseFrom(ByteString) - Static method in class alluxio.proto.journal.Table.RemoveTransformJobInfoEntry
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class alluxio.proto.journal.Table.RemoveTransformJobInfoEntry
 
parseFrom(byte[]) - Static method in class alluxio.proto.journal.Table.RemoveTransformJobInfoEntry
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class alluxio.proto.journal.Table.RemoveTransformJobInfoEntry
 
parseFrom(InputStream) - Static method in class alluxio.proto.journal.Table.RemoveTransformJobInfoEntry
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.proto.journal.Table.RemoveTransformJobInfoEntry
 
parseFrom(CodedInputStream) - Static method in class alluxio.proto.journal.Table.RemoveTransformJobInfoEntry
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class alluxio.proto.journal.Table.RemoveTransformJobInfoEntry
 
parseFrom(ByteBuffer) - Static method in class alluxio.proto.journal.Table.UpdateDatabaseInfoEntry
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class alluxio.proto.journal.Table.UpdateDatabaseInfoEntry
 
parseFrom(ByteString) - Static method in class alluxio.proto.journal.Table.UpdateDatabaseInfoEntry
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class alluxio.proto.journal.Table.UpdateDatabaseInfoEntry
 
parseFrom(byte[]) - Static method in class alluxio.proto.journal.Table.UpdateDatabaseInfoEntry
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class alluxio.proto.journal.Table.UpdateDatabaseInfoEntry
 
parseFrom(InputStream) - Static method in class alluxio.proto.journal.Table.UpdateDatabaseInfoEntry
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.proto.journal.Table.UpdateDatabaseInfoEntry
 
parseFrom(CodedInputStream) - Static method in class alluxio.proto.journal.Table.UpdateDatabaseInfoEntry
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class alluxio.proto.journal.Table.UpdateDatabaseInfoEntry
 
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.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
 
parseInetSocketAddress(String) - Static method in class alluxio.util.network.NetworkAddressUtils
Parses InetSocketAddress from a String.
parseMountInfo(String) - Static method in class alluxio.util.ShellUtils
 
parseQueryString(String) - Static method in class alluxio.util.URIUtils
Parses the given query string, and returns a map of the query parameters.
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.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.BlockStoreLocationProto
Deprecated.
parser() - Static method in class alluxio.grpc.BlockStoreLocationProto
 
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.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.Command
Deprecated.
parser() - Static method in class alluxio.grpc.Command
 
PARSER - Static variable in class alluxio.grpc.CommitBlockInUfsPOptions
Deprecated.
parser() - Static method in class alluxio.grpc.CommitBlockInUfsPOptions
 
PARSER - Static variable in class alluxio.grpc.CommitBlockInUfsPRequest
Deprecated.
parser() - Static method in class alluxio.grpc.CommitBlockInUfsPRequest
 
PARSER - Static variable in class alluxio.grpc.CommitBlockInUfsPResponse
Deprecated.
parser() - Static method in class alluxio.grpc.CommitBlockInUfsPResponse
 
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.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.CreateLocalBlockRequest
Deprecated.
parser() - Static method in class alluxio.grpc.CreateLocalBlockRequest
 
PARSER - Static variable in class alluxio.grpc.CreateLocalBlockResponse
Deprecated.
parser() - Static method in class alluxio.grpc.CreateLocalBlockResponse
 
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.ExistsPOptions
Deprecated.
parser() - Static method in class alluxio.grpc.ExistsPOptions
 
PARSER - Static variable in class alluxio.grpc.FileBlockInfo
Deprecated.
parser() - Static method in class alluxio.grpc.FileBlockInfo
 
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.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.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.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.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.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.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.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.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.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.GetSyncPathListPRequest
Deprecated.
parser() - Static method in class alluxio.grpc.GetSyncPathListPRequest
 
PARSER - Static variable in class alluxio.grpc.GetSyncPathListPResponse
Deprecated.
parser() - Static method in class alluxio.grpc.GetSyncPathListPResponse
 
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.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.JobServiceSummary
Deprecated.
parser() - Static method in class alluxio.grpc.JobServiceSummary
 
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.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.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.LoadMetadataPOptions
Deprecated.
parser() - Static method in class alluxio.grpc.LoadMetadataPOptions
 
PARSER - Static variable in class alluxio.grpc.LocalityTier
Deprecated.
parser() - Static method in class alluxio.grpc.LocalityTier
 
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.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.NetAddress
Deprecated.
parser() - Static method in class alluxio.grpc.NetAddress
 
PARSER - Static variable in class alluxio.grpc.OpenFilePOptions
Deprecated.
parser() - Static method in class alluxio.grpc.OpenFilePOptions
 
PARSER - Static variable in class alluxio.grpc.OpenLocalBlockRequest
Deprecated.
parser() - Static method in class alluxio.grpc.OpenLocalBlockRequest
 
PARSER - Static variable in class alluxio.grpc.OpenLocalBlockResponse
Deprecated.
parser() - Static method in class alluxio.grpc.OpenLocalBlockResponse
 
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.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.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.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.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.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.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.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.StartSyncPOptions
Deprecated.
parser() - Static method in class alluxio.grpc.StartSyncPOptions
 
PARSER - Static variable in class alluxio.grpc.StartSyncPRequest
Deprecated.
parser() - Static method in class alluxio.grpc.StartSyncPRequest
 
PARSER - Static variable in class alluxio.grpc.StartSyncPResponse
Deprecated.
parser() - Static method in class alluxio.grpc.StartSyncPResponse
 
PARSER - Static variable in class alluxio.grpc.StatusSummary
Deprecated.
parser() - Static method in class alluxio.grpc.StatusSummary
 
PARSER - Static variable in class alluxio.grpc.StopSyncPOptions
Deprecated.
parser() - Static method in class alluxio.grpc.StopSyncPOptions
 
PARSER - Static variable in class alluxio.grpc.StopSyncPRequest
Deprecated.
parser() - Static method in class alluxio.grpc.StopSyncPRequest
 
PARSER - Static variable in class alluxio.grpc.StopSyncPResponse
Deprecated.
parser() - Static method in class alluxio.grpc.StopSyncPResponse
 
PARSER - Static variable in class alluxio.grpc.StorageList
Deprecated.
parser() - Static method in class alluxio.grpc.StorageList
 
PARSER - Static variable in class alluxio.grpc.SyncPointInfo
Deprecated.
parser() - Static method in class alluxio.grpc.SyncPointInfo
 
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.TieredIdentity
Deprecated.
parser() - Static method in class alluxio.grpc.TieredIdentity
 
PARSER - Static variable in class alluxio.grpc.TierList
Deprecated.
parser() - Static method in class alluxio.grpc.TierList
 
PARSER - Static variable in class alluxio.grpc.TransportMessage
Deprecated.
parser() - Static method in class alluxio.grpc.TransportMessage
 
PARSER - Static variable in class alluxio.grpc.UfsInfo
Deprecated.
parser() - Static method in class alluxio.grpc.UfsInfo
 
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.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.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.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.CreateUfsBlockOptions
Deprecated.
parser() - Static method in class alluxio.proto.dataserver.Protocol.CreateUfsBlockOptions
 
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.OpenUfsBlockOptions
Deprecated.
parser() - Static method in class alluxio.proto.dataserver.Protocol.OpenUfsBlockOptions
 
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.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.Journal.JournalEntry
Deprecated.
parser() - Static method in class alluxio.proto.journal.Journal.JournalEntry
 
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.Table.AddTableEntry
Deprecated.
parser() - Static method in class alluxio.proto.journal.Table.AddTableEntry
 
PARSER - Static variable in class alluxio.proto.journal.Table.AddTransformJobInfoEntry
Deprecated.
parser() - Static method in class alluxio.proto.journal.Table.AddTransformJobInfoEntry
 
PARSER - Static variable in class alluxio.proto.journal.Table.AttachDbEntry
Deprecated.
parser() - Static method in class alluxio.proto.journal.Table.AttachDbEntry
 
PARSER - Static variable in class alluxio.proto.journal.Table.CompleteTransformTableEntry
Deprecated.
parser() - Static method in class alluxio.proto.journal.Table.CompleteTransformTableEntry
 
PARSER - Static variable in class alluxio.proto.journal.Table.DetachDbEntry
Deprecated.
parser() - Static method in class alluxio.proto.journal.Table.DetachDbEntry
 
PARSER - Static variable in class alluxio.proto.journal.Table.RemoveTableEntry
Deprecated.
parser() - Static method in class alluxio.proto.journal.Table.RemoveTableEntry
 
PARSER - Static variable in class alluxio.proto.journal.Table.RemoveTransformJobInfoEntry
Deprecated.
parser() - Static method in class alluxio.proto.journal.Table.RemoveTransformJobInfoEntry
 
PARSER - Static variable in class alluxio.proto.journal.Table.UpdateDatabaseInfoEntry
Deprecated.
parser() - Static method in class alluxio.proto.journal.Table.UpdateDatabaseInfoEntry
 
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.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
 
Parser() - Constructor for class alluxio.table.common.transform.action.TransformAction.Parser
 
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
 
parseXmlConfiguration(String) - Method in class alluxio.cli.validation.HadoopConfigurationFileParser
Parse an xml configuration file into a map.
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
 
PartialLRUEvictor - Class in alluxio.worker.block.evictor
This class is used to evict old blocks in certain StorageDir by LRU.
PartialLRUEvictor(BlockMetadataEvictorView, Allocator) - Constructor for class alluxio.worker.block.evictor.PartialLRUEvictor
Creates a new instance of PartialLRUEvictor.
Partition - Class in alluxio.grpc.table
next available id: 6
Partition - Class in alluxio.master.table
The table partition class.
Partition(UdbPartition) - Constructor for class alluxio.master.table.Partition
Creates an instance from a udb partition.
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_COLS_FIELD_NUMBER - Static variable in class alluxio.proto.journal.Table.AddTableEntry
 
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
 
PartitionedTableScheme - Class in alluxio.master.table
Partitioned Table Scheme.
PartitionInfo - Class in alluxio.grpc.table.layout.hive
Protobuf type alluxio.grpc.table.layout.PartitionInfo
PartitionInfo - Class in alluxio.job.plan.transform
Metadata about a partition in Alluxio catalog service.
PartitionInfo(String, String, HashMap<String, String>, HashMap<String, String>, ArrayList<FieldSchema>) - Constructor for class alluxio.job.plan.transform.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
 
PARTITIONS_FIELD_NUMBER - Static variable in class alluxio.proto.journal.Table.AddTableEntry
 
PartitionScheme - Interface in alluxio.master.table
Interface of the partition scheme.
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
 
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_DEFAULT - Static variable in class alluxio.conf.Source
 
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.CreateLocalBlockResponse
 
PATH_FIELD_NUMBER - Static variable in class alluxio.grpc.DeletePRequest
 
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.ListStatusPRequest
 
PATH_FIELD_NUMBER - Static variable in class alluxio.grpc.OpenLocalBlockResponse
 
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.grpc.StartSyncPRequest
 
PATH_FIELD_NUMBER - Static variable in class alluxio.grpc.StopSyncPRequest
 
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_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 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.
PathConfCommand - Class in alluxio.cli.fsadmin.command
Manages path level configuration.
PathConfCommand(Context, AlluxioConfiguration) - Constructor for class alluxio.cli.fsadmin.command.PathConfCommand
 
PATHCONFIGHASH_FIELD_NUMBER - Static variable in class alluxio.grpc.GetConfigHashPResponse
 
PATHCONFIGHASH_FIELD_NUMBER - Static variable in class alluxio.grpc.GetConfigurationPResponse
 
PATHCONFIGS_FIELD_NUMBER - Static variable in class alluxio.grpc.GetConfigurationPResponse
 
PathConfiguration - Interface in alluxio.conf.path
Path level configuration.
PathMatcher - Interface in alluxio.conf.path
Matches a path against a set of path patterns.
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) - 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.
PathTranslator - Class in alluxio.table.under.hive.util
Utilities to convert to and from ufs paths and alluxio paths.
PathTranslator() - Constructor for class alluxio.table.under.hive.util.PathTranslator
Construct a path translator.
PathUtils - Class in alluxio.util.io
Utilities related to both Alluxio paths like AlluxioURI and local file paths.
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.worker.job.task.PausableThreadPoolExecutor
Pause all threads from executing new tasks.
PB - Static variable in class alluxio.Constants
 
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.
performIntegrationChecks() - Static method in class alluxio.checker.CheckerUtils
 
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
 
persist(AlluxioURI, ScheduleAsyncPersistencePOptions) - Method in class alluxio.client.file.BaseFileSystem
 
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.hadoop.AlluxioHdfsFileSystem
 
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
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.
PersistCommand - Class in alluxio.cli.fs.command
Persists files or directories currently stored only in Alluxio to the UnderFileSystem.
PersistCommand(FileSystemContext) - Constructor for class alluxio.cli.fs.command.PersistCommand
 
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
 
PIN_ON_CREATE_FIELD_NUMBER - Static variable in class alluxio.grpc.CreateLocalBlockRequest
 
PIN_ON_CREATE_FIELD_NUMBER - Static variable in class alluxio.grpc.WriteRequestCommand
 
PinCommand - Class in alluxio.cli.fs.command
Pins the given file or folder (recursively pinning all children if a folder).
PinCommand(FileSystemContext) - Constructor for class alluxio.cli.fs.command.PinCommand
 
pingService(InetSocketAddress, ServiceType, AlluxioConfiguration, UserState) - Static method in class alluxio.util.network.NetworkAddressUtils
Test if the input address is serving an Alluxio service.
PinListSync - Class in alluxio.worker.block
PinListSync periodically syncs the set of pinned inodes from master, and saves the new pinned inodes to the BlockWorker.
PinListSync(BlockWorker, FileSystemMasterClient) - Constructor for class alluxio.worker.block.PinListSync
Creates a new instance of PinListSync.
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
 
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
 
pollEvent(DFSInotifyEventInputStream) - Method in class alluxio.underfs.hdfs.activesync.SupportedHdfsActiveSyncProvider
Fetch and process events.
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) - Constructor for class alluxio.master.PollingMasterInquireClient
 
PollingMasterInquireClient(List<InetSocketAddress>, Supplier<RetryPolicy>, AlluxioConfiguration) - Constructor for class alluxio.master.PollingMasterInquireClient
 
PollingMasterInquireClient(List<InetSocketAddress>, Supplier<RetryPolicy>, AlluxioConfiguration, UserState) - 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.
pop() - Method in class alluxio.util.executor.ControllableQueue
 
populateCounterValues(Map<String, Metric>, Map<String, Counter>, HttpServletRequest) - Method in class alluxio.web.WebInterfaceAbstractMetricsServlet
Populates operation metrics for displaying in the UI.
PortAvailabilityValidationTask - Class in alluxio.cli.validation
Task for validating whether a specific port is available.
PortAvailabilityValidationTask(NetworkAddressUtils.ServiceType, String) - Constructor for class alluxio.cli.validation.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 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.LocalFileDataReader
 
pos() - Method in class alluxio.client.block.stream.LocalFileDataWriter
 
pos() - Method in class alluxio.client.block.stream.UfsFallbackLocalFileDataWriter
 
POSITION_SHORT_FIELD_NUMBER - Static variable in class alluxio.grpc.ReadRequest
 
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.block.stream.BlockInStream
 
positionedRead(long, byte[], int, int) - Method in class alluxio.client.file.AlluxioFileInStream
 
positionedRead(long, byte[], int, int) - Method in class alluxio.client.file.cache.LocalCacheFileInStream
 
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.
post(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.
PRECONDITION_FAILED - Static variable in class alluxio.proxy.s3.S3ErrorCode.Name
 
PRECONDITION_FAILED - Static variable in class alluxio.proxy.s3.S3ErrorCode
 
PreconditionMessage - Enum in alluxio.exception
Precondition messages used across Alluxio.
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.
PrefixPathConfiguration - Class in alluxio.conf.path
Configurations for path prefixes.
PrefixPathConfiguration() - Constructor for class alluxio.conf.path.PrefixPathConfiguration
Constructs an empty path level configuration.
PrefixPathConfiguration(Map<String, AlluxioConfiguration>) - Constructor for class alluxio.conf.path.PrefixPathConfiguration
Constructs a new path level configuration.
PrefixPathMatcher - Class in alluxio.conf.path
A PathMatcher to match a path against a set of paths.
PrefixPathMatcher(Set<String>) - Constructor for class alluxio.conf.path.PrefixPathMatcher
Builds internal trie based on paths.
PREVIOUS_VERSION_FIELD_NUMBER - Static variable in class alluxio.grpc.table.TableInfo
 
PREVIOUS_VERSION_FIELD_NUMBER - Static variable in class alluxio.proto.journal.Table.AddTableEntry
 
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.
PrimarySelector.State - Enum in alluxio.master
The state for the primary selector.
PrimarySelectorClient - Class in alluxio.master
Masters use this client to elect a leader.
PrimarySelectorClient(String, String, String) - Constructor for class alluxio.master.PrimarySelectorClient
Constructs a new PrimarySelectorClient.
PrimarySelectorClient.ZookeeperConnectionErrorPolicy - Enum in alluxio.master
Defines supported connection error policies for leader election.
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.
printCommandInfo(Command, PrintWriter) - Static method in class alluxio.cli.fs.command.HelpCommand
Prints the info about a command to the given print writer.
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.
printMountInfo(Map<String, MountPointInfo>) - Static method in class alluxio.cli.fsadmin.report.UfsCommand
Prints mount information for a mount table.
printNodesResults(Map<CheckerUtils.Status, List<String>>, PrintWriter) - Static method in class alluxio.checker.CheckerUtils
Collects and saves the Status of checked nodes.
printPassInfo(boolean) - Static method in class alluxio.cli.CliUtils
Prints information of the test result.
printSyncStatus(SyncStatus, Logger, int) - Static method in class alluxio.cli.table.TableShellUtils
Prints out the sync status.
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.
process(List<Long>) - Method in interface alluxio.master.file.BlockDeletionContext.BlockDeletionListener
Processes block deletion.
process(AlluxioURI, List<Inode>) - Method in class alluxio.master.file.meta.AsyncUfsAbsentPathCache
 
process(AlluxioURI, List<Inode>) - Method in class alluxio.master.file.meta.NoopUfsAbsentPathCache
 
process(AlluxioURI, List<Inode>) - Method in interface alluxio.master.file.meta.UfsAbsentPathCache
Processes the given path for the cache.
Process - Interface in alluxio
Interface representing an Alluxio process.
process(InputStream) - Method in interface alluxio.util.network.HttpUtils.IProcessInputStream
 
PROCESS_TYPE - Static variable in class alluxio.util.CommonUtils
Represents the type of Alluxio process running in this JVM.
PROCESS_TYPE_OPTION - Static variable in class alluxio.AlluxioRemoteLogFilter
Deprecated.
Option name to configure this AlluxioRemoteLogFilter in log4j.properties.
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.
processHeader(CommandLine) - Method in class alluxio.cli.fs.command.AbstractFileSystemCommand
Processes the header of the command.
processHeader(CommandLine) - Method in class alluxio.cli.fs.command.DuCommand
 
processJournalEntry(Journal.JournalEntry) - Method in class alluxio.master.block.DefaultBlockMaster
 
processJournalEntry(Journal.JournalEntry) - Method in class alluxio.master.file.activesync.ActiveSyncManager
 
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.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.table.AlluxioCatalog
 
processJournalEntry(Journal.JournalEntry) - Method in class alluxio.master.table.Database
 
PROCESSOR_BIT - Static variable in class alluxio.util.OSUtils
The processor bit.
ProcessUtils - Class in alluxio
Utility methods for Alluxio Processes.
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.
PROMOTE_FIELD_NUMBER - Static variable in class alluxio.grpc.OpenLocalBlockRequest
 
PROMOTE_FIELD_NUMBER - Static variable in class alluxio.grpc.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.proto.journal.File.AddMountPointEntry
 
PROPERTIES_FIELD_NUMBER - Static variable in class alluxio.proto.journal.Meta.PathPropertiesEntry
 
Property - Class in alluxio.table.under.hive
This contains all the properties for this UDB.
Property() - Constructor for class alluxio.table.under.hive.Property
 
Property - Class in alluxio.wire
Wire representation of a configuration property.
Property(String, String, Source) - Constructor for class alluxio.wire.Property
Creates a new property.
PROPERTY_OPTION_NAME - Static variable in class alluxio.cli.fsadmin.pathconf.AddCommand
 
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.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.CreateUfsBlockOptions - Class in alluxio.proto.dataserver
Options to create a block file in UFS.
Protocol.CreateUfsBlockOptions.Builder - Class in alluxio.proto.dataserver
Options to create a block file in UFS.
Protocol.CreateUfsBlockOptionsOrBuilder - 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.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.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
 
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() - Constructor for class alluxio.job.ProtoUtils
 
ProtoUtils - Class in alluxio.table
Protobuf related utils.
ProtoUtils() - Constructor for class alluxio.table.ProtoUtils
 
ProtoUtils - Class in alluxio.util.proto
Protobuf related utils.
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_MULTIPART_TEMPORARY_DIR_SUFFIX - Static variable in class alluxio.conf.PropertyKey.Name
 
PROXY_S3_MULTIPART_TEMPORARY_DIR_SUFFIX - 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
 
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.
ProxyProcess - Interface in alluxio.proxy
A proxy in the Alluxio system.
ProxyProcess.Factory - Class in alluxio.proxy
Factory for creating ProxyProcess.
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, byte[]) - Method in class alluxio.client.file.cache.LocalCacheManager
 
put(PageId, byte[]) - 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[]) - Method in class alluxio.client.file.cache.store.LocalPageStore
 
put(PageId, byte[]) - Method in class alluxio.client.file.cache.store.RocksPageStore
 
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, String, 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(Access, String) - Static method in class alluxio.underfs.swift.http.SwiftDirectClient
Swift HTTP PUT request.
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
putAllConfig(Map<String, String>) - Method in class alluxio.proto.journal.Table.AttachDbEntry.Builder
map<string, string> config = 5;
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
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;
putAllParameter(Map<String, String>) - Method in class alluxio.proto.journal.Table.UpdateDatabaseInfoEntry.Builder
map<string, string> parameter = 3;
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;
putAllParameters(Map<String, String>) - Method in class alluxio.proto.journal.Table.AddTableEntry.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.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;
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
putAllTransformedLayouts(Map<String, Layout>) - Method in class alluxio.proto.journal.Table.AddTransformJobInfoEntry.Builder
map<string, .alluxio.grpc.table.Layout> transformed_layouts = 5;
putAllTransformedLayouts(Map<String, Layout>) - Method in class alluxio.proto.journal.Table.CompleteTransformTableEntry.Builder
Map from partition spec to transformed layout
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.FileInfo.Builder
map<string, bytes> xattr = 32;
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.BlockStore
Adds block metadata to the block store.
putBlock(long, Block.BlockMeta) - Method in class alluxio.master.metastore.heap.HeapBlockStore
 
putBlock(long, Block.BlockMeta) - Method in class alluxio.master.metastore.rocks.RocksBlockStore
 
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
putConfig(String, String) - Method in class alluxio.proto.journal.Table.AttachDbEntry.Builder
map<string, string> config = 5;
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
putErrors(String, InconsistentProperties) - Method in class alluxio.grpc.ConfigCheckReport.Builder
Scope name as key
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;
putOptions(String, String) - Method in class alluxio.grpc.table.AttachDatabasePRequest.Builder
map<string, string> options = 5;
putParameter(String, String) - Method in class alluxio.grpc.table.Database.Builder
map<string, string> parameter = 4;
putParameter(String, String) - Method in class alluxio.proto.journal.Table.UpdateDatabaseInfoEntry.Builder
map<string, string> parameter = 3;
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;
putParameters(String, String) - Method in class alluxio.proto.journal.Table.AddTableEntry.Builder
map<string, string> parameters = 7;
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.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;
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;
putTotalBytesOnTiers(String, long) - Method in class alluxio.grpc.RegisterWorkerPRequest.Builder
the map of total bytes on each tier
putTransformedLayouts(String, Layout) - Method in class alluxio.proto.journal.Table.AddTransformJobInfoEntry.Builder
map<string, .alluxio.grpc.table.Layout> transformed_layouts = 5;
putTransformedLayouts(String, Layout) - Method in class alluxio.proto.journal.Table.CompleteTransformTableEntry.Builder
Map from partition spec to transformed layout
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.FileInfo.Builder
map<string, bytes> xattr = 32;
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

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_RAW_CONFIGURATION - Static variable in class alluxio.worker.AlluxioWorkerRestServiceHandler
 
QUERY_SEPARATOR - Static variable in class alluxio.util.URIUtils
 
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
 
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
quoteETag(String) - Static method in class alluxio.proxy.s3.S3RestUtils
 

R

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
 
RaftJournalConfiguration - Class in alluxio.master.journal.raft
Configuration for the Raft journal system.
RaftJournalConfiguration() - Constructor for class alluxio.master.journal.raft.RaftJournalConfiguration
 
RaftJournalConfiguration.StorageLevel - Enum in alluxio.master.journal.raft
Enum corresponding to io.atomix.copycat.server.storage.StorageLevel.
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.
RaftJournalSystem - Class in alluxio.master.journal.raft
System for multiplexing many logical journals into a single raft-based journal.
RaftJournalWriter - Class in alluxio.master.journal.raft
Class for writing entries to the Raft journal.
RaftJournalWriter(long, CopycatClient) - 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
 
RamDiskMountPrivilegeValidationTask - Class in alluxio.cli.validation
Task for validating whether worker has enough privilege to mount RAM disk.
RamDiskMountPrivilegeValidationTask() - Constructor for class alluxio.cli.validation.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
 
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
 
RAWVALUE_FIELD_NUMBER - Static variable in class alluxio.grpc.GetConfigurationPOptions
 
read() - Method in class alluxio.client.block.stream.BlockInStream
 
read(byte[]) - Method in class alluxio.client.block.stream.BlockInStream
 
read(byte[], int, int) - Method in class alluxio.client.block.stream.BlockInStream
 
read() - Method in class alluxio.client.file.AlluxioFileInStream
 
read(byte[]) - Method in class alluxio.client.file.AlluxioFileInStream
 
read(byte[], int, int) - Method in class alluxio.client.file.AlluxioFileInStream
 
read() - Method in class alluxio.client.file.cache.LocalCacheFileInStream
 
read(byte[]) - Method in class alluxio.client.file.cache.LocalCacheFileInStream
 
read(byte[], int, int) - Method in class alluxio.client.file.cache.LocalCacheFileInStream
 
read(String, Pointer, long, long, FuseFileInfo) - Method in class alluxio.fuse.AlluxioFuseFileSystem
Reads data from an open file.
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() - Method in class alluxio.hadoop.HdfsFileInputStream
 
read(byte[]) - Method in class alluxio.hadoop.HdfsFileInputStream
 
read(byte[], int, int) - Method in class alluxio.hadoop.HdfsFileInputStream
 
read(long, byte[], int, int) - Method in class alluxio.hadoop.HdfsFileInputStream
 
read() - Method in class alluxio.job.plan.transform.format.csv.CsvReader
 
read() - Method in class alluxio.job.plan.transform.format.parquet.ParquetReader
 
read() - Method in interface alluxio.job.plan.transform.format.TableReader
 
read() - Method in class alluxio.master.journal.raft.SnapshotReaderStream
 
read(byte[], int, int) - Method in class alluxio.master.journal.raft.SnapshotReaderStream
 
read() - Method in interface alluxio.master.journalv0.JournalInputStream
Reads the next journal entry.
READ - Static variable in class alluxio.proxy.StreamsRestServiceHandler
 
read(Integer) - Method in class alluxio.proxy.StreamsRestServiceHandler
 
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.hdfs.HdfsPositionedUnderFileInputStream
 
read(byte[]) - Method in class alluxio.underfs.hdfs.HdfsPositionedUnderFileInputStream
 
read(byte[], int, int) - Method in class alluxio.underfs.hdfs.HdfsPositionedUnderFileInputStream
 
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(long, long) - Method in interface alluxio.worker.block.io.BlockReader
Reads data from the block.
read(long, long) - Method in class alluxio.worker.block.io.LocalFileBlockReader
 
read(long, long) - Method in class alluxio.worker.block.RemoteBlockReader
 
read(long, long) - Method in class alluxio.worker.block.UnderFileSystemBlockReader
 
READ_EXECUTE_VALUE - Static variable in enum alluxio.grpc.Bits
READ_EXECUTE = 6;
READ_ONLY_OPTION - Static variable in class alluxio.table.common.udb.UdbConfiguration
 
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_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 interface alluxio.network.protocol.databuffer.DataBuffer
 
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 class alluxio.grpc.BlockWorkerGrpc.BlockWorkerImplBase
 
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(long, long, long) - Method in class alluxio.worker.block.DefaultBlockWorker
 
readBlock(StreamObserver<ReadResponse>) - Method in class alluxio.worker.grpc.BlockWorkerImpl
 
readBlockRemote(long, long, long) - Method in interface alluxio.worker.block.BlockWorker
Gets the block reader for the block for non short-circuit reads.
readBlockRemote(long, long, long) - Method in class alluxio.worker.block.DefaultBlockWorker
 
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 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.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
 
readCheckpoint(CheckpointInputStream, Path) - Method in class alluxio.master.journal.tool.AbstractJournalDumper
Used to read checkpoint streams.
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.LocalFileDataReader
 
readdir(String, Pointer, FuseFillDir, long, FuseFileInfo) - Method in class alluxio.fuse.AlluxioFuseFileSystem
Reads the contents of a directory.
readEntry() - Method in class alluxio.master.journal.JournalEntryStreamReader
Reads a journal entry from the input stream.
readFully(long, byte[]) - Method in class alluxio.hadoop.HdfsFileInputStream
 
readFully(long, byte[], int, int) - Method in class alluxio.hadoop.HdfsFileInputStream
 
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.
readLock() - Method in class alluxio.concurrent.WeakSafeReentrantReadWriteLock
 
readLock() - Method in class alluxio.worker.block.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.
readNoCacheConf() - Static method in class alluxio.job.plan.transform.format.ReadWriterUtils
 
readNodeList(String, String) - Static method in class alluxio.cli.CommandUtils
Reads a list of nodes from given file name ignoring comments and empty lines.
readNodeList(String) - Static method in class alluxio.cli.validation.Utils
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
 
readObject(BufferInput<?>, Serializer) - Method in class alluxio.master.journal.raft.JournalEntryCommand
 
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.Builder - Class in alluxio.grpc
The read request.
ReadRequestContext<T extends alluxio.worker.grpc.ReadRequest> - Class in alluxio.worker.grpc
Represents the context of a read request received from gRPC stream.
ReadRequestContext(T) - Constructor for class alluxio.worker.grpc.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) - 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.TableMasterClientServiceImplBase
 
readTable(ReadTablePRequest, StreamObserver<ReadTablePResponse>) - Method in class alluxio.grpc.table.TableMasterClientServiceGrpc.TableMasterClientServiceStub
 
readTable(String, String, Constraint) - Method in class alluxio.master.table.AlluxioCatalog
Returns the partitions based on a constraint for the specified table.
readTable(String, String, Constraint) - Method in class alluxio.master.table.DefaultTableMaster
 
readTable(String, String, Constraint) - Method in interface alluxio.master.table.TableMaster
Returns metadata for reading a table given constraints.
readTable(ReadTablePRequest, StreamObserver<ReadTablePResponse>) - Method in class alluxio.master.table.TableMasterClientServiceHandler
 
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
 
readTarGz(Path, InputStream) - Static method in class alluxio.util.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, boolean) - Method in interface alluxio.worker.block.BlockWorker
Gets a block reader to read a UFS block for non short-circuit reads.
readUfsBlock(long, long, long, boolean) - Method in class alluxio.worker.block.DefaultBlockWorker
 
ReadWriterUtils - Class in alluxio.job.plan.transform.format
Utilities for implementing TableReader and TableWriter.
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
 
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.
recordActiveSyncTxid(long, long) - Method in class alluxio.master.file.DefaultFileSystemMaster
 
recordActiveSyncTxid(long, long) - Method in interface alluxio.master.file.FileSystemMaster
Journal the active sync transaction id so that we can restart more efficiently.
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
 
recoverFromStartSync(AlluxioURI, long) - Method in class alluxio.master.file.activesync.ActiveSyncManager
Recover from start sync operation.
recoverFromStopSync(AlluxioURI) - Method in class alluxio.master.file.activesync.ActiveSyncManager
Recover from a stop sync operation.
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
 
reduce(Text, Iterable<Text>, Reducer<Text, Text, Text, Text>.Context) - Method in class alluxio.checker.MapReduceIntegrationChecker.CheckerReducer
Merges the IP addresses of same Status.
RefCountLockResource - Class in alluxio.resource
Reference counted Lock resource, automatically unlocks and decrements the reference count.
RefCountLockResource(Lock, boolean, AtomicInteger) - Constructor for class alluxio.resource.RefCountLockResource
Creates a new instance of LockResource using the given lock and reference counter.
refresh() - Method in class alluxio.table.common.LayoutRegistry
Refreshes the registry by service loading classes.
refresh() - Method in class alluxio.table.common.udb.UnderDatabaseRegistry
Refreshes the registry by service loading classes.
RefreshPolicy - Interface in alluxio.refresh
Policy for determining whether a refresh should be performed.
regenerateReport() - Method in class alluxio.master.meta.checkconf.ServerConfigurationChecker
Checks the server-side configurations and records the check results.
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(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, 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.
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.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.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.Table
 
registerAllExtensions(ExtensionRegistry) - Static method in class alluxio.proto.journal.Table
 
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.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
 
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.
registerBlockStoreEventListener(BlockStoreEventListener) - Method in class alluxio.worker.block.TieredBlockStore
 
registerChangeListener(Runnable) - Method in class alluxio.master.meta.checkconf.ServerConfigurationStore
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(BlockMaster) - Static method in class alluxio.master.block.DefaultBlockMaster.Metrics
Registers metric gauges.
registerGauges(FileSystemMaster, UfsManager) - Static method in class alluxio.master.file.DefaultFileSystemMaster.Metrics
Register some file system master related gauges.
registerGauges(BlockWorker) - Static method in class alluxio.worker.block.DefaultBlockWorker.Metrics
Registers metric gauges.
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.JobMasterWorkerServiceImplBase
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
 
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(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.MetaMasterMasterServiceImplBase
Registers a master.
registerMaster(RegisterMasterPRequest, StreamObserver<RegisterMasterPResponse>) - Method in class alluxio.grpc.MetaMasterMasterServiceGrpc.MetaMasterMasterServiceStub
Registers a master.
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
 
registerNewConf(Address, List<ConfigProperty>) - Method in class alluxio.master.meta.checkconf.ServerConfigurationStore
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
 
registerThroughputGauge(String, String) - Method in class alluxio.master.metrics.DefaultMetricsMaster
Registers the corresponding throughput of the given counter.
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.BlockMasterWorkerServiceImplBase
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) - 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.
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
 
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, 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.
RejectingServer - Class in alluxio.network
A server which listens on a socket and closes all connections.
RejectingServer(InetSocketAddress) - Constructor for class alluxio.network.RejectingServer
 
RelatedS3Operations - Annotation Type in alluxio.examples
An annotation for methods with related S3 operations.
release() - Method in class alluxio.concurrent.CountingLatch
Unblocks threads blocked on calling CountingLatch.inc().
release(String, FuseFileInfo) - Method in class alluxio.fuse.AlluxioFuseFileSystem
Releases the resources associated to an open file.
release() - Method in class alluxio.grpc.ReadableDataBuffer
 
release() - Method in interface alluxio.network.protocol.databuffer.DataBuffer
Releases the underlying buffer of this DataBuffer if no longer needed.
release() - Method in class alluxio.network.protocol.databuffer.NettyDataBuffer
Release the Netty ByteBuf.
release() - Method in class alluxio.network.protocol.databuffer.NioDataBuffer
 
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(InputStream) - Method in class alluxio.worker.block.UfsInputStreamManager
Releases an input stream.
releaseAccess(long, long) - Method in class alluxio.worker.block.UnderFileSystemBlockStore
Releases the access token of this block by removing this (sessionId, blockId) pair from the store.
releaseConnection(GrpcConnectionKey, AlluxioConfiguration) - Method in class alluxio.grpc.GrpcConnectionPool
Decreases the ref-count of the ManagedChannel for the given address.
releaseMasterClient(JobMasterClient) - Method in class alluxio.client.job.JobContext
Releases a job master client into the job master client pool.
reloadProperties() - Static method in class alluxio.util.ConfigurationUtils
Reloads site properties from disk.
relogin() - Method in class alluxio.security.user.BaseUserState
 
relogin() - Method in interface alluxio.security.user.UserState
Attempts to log in again, and returns the new User.
remaining() - Method in class alluxio.client.block.stream.BlockInStream
 
remaining() - Method in class alluxio.client.block.stream.BlockOutStream
 
remaining() - Method in interface alluxio.client.BoundedStream
 
remaining() - Method in class alluxio.client.file.AlluxioFileInStream
 
remaining() - Method in class alluxio.client.file.cache.LocalCacheFileInStream
 
remaining() - Method in class alluxio.hadoop.AlluxioHdfsInputStream
 
REMOTE_LOG_MDC_PROCESS_TYPE_KEY - Static variable in class alluxio.AlluxioRemoteLogFilter
Name (Key) of the MDC info.
RemoteBlockReader - Class in alluxio.worker.block
Reads a block from a remote worker node.
RemoteBlockReader(FileSystemContext, long, long, InetSocketAddress, Protocol.OpenUfsBlockOptions) - Constructor for class alluxio.worker.block.RemoteBlockReader
Constructs a remote block reader.
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(PropertyKey) - Method in class alluxio.conf.AlluxioProperties
Remove the value set for key.
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.FileSystemMasterClientServiceImplBase
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 a 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() - Static method in class alluxio.security.authentication.AuthenticatedClientUser
Removes the User from the ThreadLocal variable.
remove(T) - Method in class alluxio.util.executor.ControllableQueue
Removes an element.
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_TABLE_FIELD_NUMBER - Static variable in class alluxio.proto.journal.Journal.JournalEntry
 
REMOVE_TRANSFORM_JOB_INFO_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(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) - 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.BlockWorkerImplBase
 
removeBlock(RemoveBlockRequest, StreamObserver<RemoveBlockResponse>) - Method in class alluxio.grpc.BlockWorkerGrpc.BlockWorkerStub
 
removeBlock(long) - Method in class alluxio.master.block.meta.MasterWorkerInfo
Removes a block from the worker.
removeBlock(long) - Method in interface alluxio.master.metastore.BlockStore
Removes a block, or does nothing if the block does not exist.
removeBlock(long) - Method in class alluxio.master.metastore.heap.HeapBlockStore
 
removeBlock(long) - Method in class alluxio.master.metastore.rocks.RocksBlockStore
 
removeBlock(long, long) - Method in interface alluxio.worker.block.BlockStore
Removes an existing block.
removeBlock(long, long, BlockStoreLocation) - 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.
removeBlock(long, long) - Method in class alluxio.worker.block.DefaultBlockWorker
 
removeBlock(long, long) - Method in class alluxio.worker.block.TieredBlockStore
 
removeBlock(long, long, BlockStoreLocation) - Method in class alluxio.worker.block.TieredBlockStore
 
removeBlock(RemoveBlockRequest, StreamObserver<RemoveBlockResponse>) - Method in class alluxio.worker.grpc.BlockWorkerImpl
 
removeBlockMeta(BlockMeta) - Method in class alluxio.worker.block.BlockMetadataManager
Removes the metadata of a specific block.
removeBlockMeta(BlockMeta) - Method in class 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(List<Long>, boolean) - Method in interface alluxio.master.block.BlockMaster
Removes blocks from workers.
removeBlocks(List<Long>, boolean) - Method in class alluxio.master.block.DefaultBlockMaster
 
removeBuckets(Set<TtlBucket>) - Method in class alluxio.master.file.meta.TtlBucketList
Removes all buckets in the set.
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;
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
RemoveCommand - Class in alluxio.cli.fsadmin.pathconf
Removes path level configurations.
RemoveCommand(Context, AlluxioConfiguration) - Constructor for class alluxio.cli.fsadmin.pathconf.RemoveCommand
 
removeCommands(int) - Method in class alluxio.grpc.JobHeartbeatPResponse.Builder
repeated .alluxio.grpc.job.JobCommand commands = 1;
removeConfig(String) - Method in class alluxio.proto.journal.Table.AttachDbEntry.Builder
map<string, string> config = 5;
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
 
removeDir(StorageDir) - Method in class alluxio.worker.block.TieredBlockStore
Removes a storage directory.
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.
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
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.
removeFileBlockInfos(int) - Method in class alluxio.grpc.FileInfo.Builder
repeated .alluxio.grpc.file.FileBlockInfo fileBlockInfos = 21;
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.
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
 
removeInfo(int) - Method in class alluxio.grpc.table.GetTransformJobInfoPResponse.Builder
repeated .alluxio.grpc.table.TransformJobInfo info = 1;
removeInnerValue(K1, K2) - Method in class alluxio.collections.TwoKeyConcurrentMap
 
removeInode(InodeView) - Method in class alluxio.master.file.meta.TtlBucket
Removes a 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;
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.
removeLocation(long, long) - Method in interface alluxio.master.metastore.BlockStore
Removes a block location.
removeLocation(long, long) - Method in class alluxio.master.metastore.heap.HeapBlockStore
 
removeLocation(long, long) - Method in class alluxio.master.metastore.rocks.RocksBlockStore
 
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;
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;
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) - Method in class alluxio.client.file.cache.DefaultMetaStore
 
removePage(PageId) - Method in interface alluxio.client.file.cache.MetaStore
Removes a page.
removeParameter(String) - Method in class alluxio.grpc.table.Database.Builder
map<string, string> parameter = 4;
removeParameter(String) - Method in class alluxio.proto.journal.Table.UpdateDatabaseInfoEntry.Builder
map<string, string> parameter = 3;
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;
removeParameters(String) - Method in class alluxio.proto.journal.Table.AddTableEntry.Builder
map<string, string> parameters = 7;
removePartitionCols(int) - Method in class alluxio.grpc.table.TableInfo.Builder
partitioning scheme
removePartitionCols(int) - Method in class alluxio.proto.journal.Table.AddTableEntry.Builder
partitioning scheme
removePartitions(int) - Method in class alluxio.grpc.table.ReadTablePResponse.Builder
repeated .alluxio.grpc.table.Partition partitions = 1;
removePartitions(int) - Method in class alluxio.proto.journal.Table.AddTableEntry.Builder
repeated .alluxio.grpc.table.Partition partitions = 9;
removePartitionStatistics(String) - Method in class alluxio.grpc.table.GetPartitionColumnStatisticsPResponse.Builder
map<string, .alluxio.grpc.table.ColumnStatisticsList> partition_statistics = 1;
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) - 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.MetaMasterConfigurationServiceImplBase
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;
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(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;
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) - 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.JournalMasterClientServiceImplBase
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;
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;
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;
removeStorageDir(StorageDir) - Method in class alluxio.worker.block.meta.StorageTier
Removes a directory.
removeSummaryPerStatus(int) - Method in class alluxio.grpc.JobServiceSummary.Builder
repeated .alluxio.grpc.job.StatusSummary summaryPerStatus = 1;
removeSyncPaths(int) - Method in class alluxio.grpc.GetSyncPathListPResponse.Builder
repeated .alluxio.grpc.file.SyncPointInfo syncPaths = 1;
removeTablesErrors(String) - Method in class alluxio.grpc.table.SyncStatus.Builder
map<string, string> tables_errors = 1;
removeTableStats(int) - Method in class alluxio.proto.journal.Table.AddTableEntry.Builder
repeated .alluxio.grpc.table.ColumnStatisticsInfo table_stats = 6;
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 class alluxio.worker.block.meta.StorageDir
Removes a temp block from this storage dir.
removeTiers(int) - Method in class alluxio.grpc.TieredIdentity.Builder
repeated .alluxio.grpc.LocalityTier tiers = 1;
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.
removeTransformedLayouts(String) - Method in class alluxio.proto.journal.Table.AddTransformJobInfoEntry.Builder
map<string, .alluxio.grpc.table.Layout> transformed_layouts = 5;
removeTransformedLayouts(String) - Method in class alluxio.proto.journal.Table.CompleteTransformTableEntry.Builder
Map from partition spec to transformed layout
removeUfsLocations(int) - Method in class alluxio.grpc.FileBlockInfo.Builder
deprecated since 1.1 will be removed in 2.0 (replaced by ufsStringLocations)
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
removeWorker(long) - Method in class alluxio.master.block.meta.MasterBlockInfo
Removes the worker from the locations of this block.
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.FileInfo.Builder
map<string, bytes> xattr = 32;
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.
rename(AlluxioURI, AlluxioURI, RenamePOptions) - Method in class alluxio.client.file.BaseFileSystem
 
rename(AlluxioURI, AlluxioURI, RenamePOptions) - Method in class alluxio.client.file.DelegatingFileSystem
 
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) - Method in class alluxio.client.file.RetryHandlingFileSystemMasterClient
 
rename(AlluxioURI, AlluxioURI, RenamePOptions) - Method in class alluxio.client.file.RetryHandlingFileSystemMasterClient
 
rename(String, String) - Method in class alluxio.fuse.AlluxioFuseFileSystem
Renames a path.
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.FileSystemMasterClientServiceImplBase
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(AlluxioURI, AlluxioURI, RenamePOptions) - Method in class alluxio.hadoop.AlluxioHdfsFileSystem
 
rename(Path, Path) - Method in class alluxio.hadoop.LocalCacheFileSystem
 
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_FIELD_NUMBER - Static variable in class alluxio.proto.journal.Journal.JournalEntry
 
RenameBuffer() - Constructor for class alluxio.underfs.ObjectUnderFileSystem.RenameBuffer
Construct a new ObjectUnderFileSystem.RenameBuffer instance.
RenameContext - Class in alluxio.master.file.contexts
Used to merge and wrap RenamePOptions.
renameDefaults(AlluxioConfiguration) - Static method in class alluxio.util.FileSystemOptions
 
renameDirectory(String, String) - Method in class alluxio.concurrent.ManagedBlockingUfsForwarder
 
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 interface alluxio.underfs.UnderFileSystem
Renames a directory from src to dst in under file system.
renameDirectory(String, String) - Method in class alluxio.underfs.UnderFileSystemWithLogging
 
renameDirectory(String, String) - Method in class alluxio.underfs.web.WebUnderFileSystem
 
renameDirectoryDeepTest() - Method in class alluxio.examples.UnderFileSystemCommonOperations
Test for renaming deep directory.
renameDirectoryTest() - Method in class alluxio.examples.UnderFileSystemCommonOperations
Test for renaming directory.
renameFile(String, String) - Method in class alluxio.concurrent.ManagedBlockingUfsForwarder
 
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
 
renameFile(String, String) - Method in class alluxio.underfs.web.WebUnderFileSystem
 
renameFileTest() - Method in class alluxio.examples.UnderFileSystemCommonOperations
Test for renaming file.
renameLargeDirectoryTest() - Method in class alluxio.examples.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.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.examples.UnderFileSystemCommonOperations
Test for renaming renamable directory.
renameRenamableFile(String, String) - Method in class alluxio.concurrent.ManagedBlockingUfsForwarder
 
renameRenamableFile(String, String) - Method in class alluxio.underfs.ConsistentUnderFileSystem
 
renameRenamableFile(String, String) - Method in class alluxio.underfs.ObjectUnderFileSystem
 
renameRenamableFile(String, String) - Method in interface alluxio.underfs.UnderFileSystem
Renames a file from src to dst in under file system.
renameRenamableFile(String, String) - Method in class alluxio.underfs.UnderFileSystemWithLogging
 
renameRenamableFileTest() - Method in class alluxio.examples.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.
replayJournalEntryFromJournal(Journal.JournalEntry) - Method in interface alluxio.master.journal.JournalEntryReplayable
Applies a journal entry, returning false if the journal entry is not recognized.
replicate(AlluxioURI, long, int) - Method in class alluxio.job.plan.replicate.DefaultReplicationHandler
 
replicate(AlluxioURI, long, int) - Method in interface alluxio.job.plan.replicate.ReplicationHandler
Increases the block replication level by a target number of replicas.
ReplicateConfig - Class in alluxio.job.plan.replicate
Configuration of a job replicating a block.
ReplicateConfig(String, long, int) - Constructor for class alluxio.job.plan.replicate.ReplicateConfig
Creates a new instance of ReplicateConfig.
ReplicateDefinition - Class in alluxio.job.plan.replicate
A job to replicate a block.
ReplicateDefinition() - Constructor for class alluxio.job.plan.replicate.ReplicateDefinition
Constructs a new ReplicateDefinition.
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
 
ReplicationChecker - Class in alluxio.master.file.replication
The executor to check block replication level periodically and handle over-replicated and under-replicated blocks correspondingly.
ReplicationChecker(InodeTree, BlockMaster, SafeModeManager, JobMasterClientPool) - Constructor for class alluxio.master.file.replication.ReplicationChecker
Constructs a new ReplicationChecker using default (job service) handler to replicate and evict blocks.
ReplicationChecker(InodeTree, BlockMaster, SafeModeManager, ReplicationHandler) - Constructor for class alluxio.master.file.replication.ReplicationChecker
Constructs a new ReplicationChecker with specified replicate and evict handlers (for unit testing).
REPLICATIONDURABLE_FIELD_NUMBER - Static variable in class alluxio.grpc.CreateFilePOptions
 
ReplicationHandler - Interface in alluxio.job.plan.replicate
Interface for adjusting the replication level of blocks.
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
 
reportWorkerMetrics() - Static method in class alluxio.metrics.MetricsSystem
 
request(int) - Method in class alluxio.worker.grpc.DataMessageServerStreamObserver
 
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
 
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.
requestSpace(long, long, long) - Method in class alluxio.worker.block.DefaultBlockWorker
 
requestSpace(long, long, long) - Method in class alluxio.worker.block.TieredBlockStore
 
RequestType - Enum in alluxio.grpc
The read/write request type.
reset() - Method in interface alluxio.client.file.cache.CacheEvictor
Resets the evictor.
reset() - Method in class alluxio.client.file.cache.DefaultMetaStore
 
reset() - Method in class alluxio.client.file.cache.evictor.LFUCacheEvictor
 
reset() - Method in class alluxio.client.file.cache.evictor.LRUCacheEvictor
 
reset() - Method in interface alluxio.client.file.cache.MetaStore
Resets the meta store.
reset() - Static method in class alluxio.conf.ServerConfiguration
Resets the AlluxioConfiguration back the defaults and values from alluxio-site properties.
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.ServerConfigurationStore
Resets the default ServerConfigurationStore.
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
reset() - Method in class alluxio.util.JvmPauseMonitor
Resets value of mJvmMonitorThread.
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.
resetState() - Method in class alluxio.master.block.DefaultBlockMaster
 
resetState() - Method in class alluxio.master.file.activesync.ActiveSyncManager
Resets the object's journaled state.
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.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.table.AlluxioCatalog
 
resetState() - Method in class alluxio.master.table.Database
 
resizeTempBlockMeta(TempBlockMeta, long) - Method in class alluxio.worker.block.BlockMetadataManager
Modifies the size of a temp block.
resizeTempBlockMeta(TempBlockMeta, long) - Method in class 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
 
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.
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.
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(CheckpointInputStream) - Method in class alluxio.master.file.meta.CheckpointedIdHashSet
 
restoreFromCheckpoint(CheckpointInputStream) - Method in class alluxio.master.file.meta.InodeCounter
 
restoreFromCheckpoint(CheckpointInputStream) - Method in class alluxio.master.file.meta.InodeTreePersistentState
 
restoreFromCheckpoint(CheckpointInputStream) - Method in class alluxio.master.file.meta.TtlBucketList
 
restoreFromCheckpoint(CheckpointInputStream) - Method in interface alluxio.master.journal.checkpoint.Checkpointed
Restores state from a checkpoint.
restoreFromCheckpoint(CheckpointInputStream) - Method in interface alluxio.master.journal.DelegatingJournaled
 
restoreFromCheckpoint(CheckpointInputStream) - Method in interface alluxio.master.journal.Journaled
 
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(CheckpointInputStream) - Method in interface alluxio.master.journal.NoopJournaled
 
restoreFromCheckpoint(CheckpointInputStream) - Method in class alluxio.master.metastore.caching.CachingInodeStore
 
restoreFromCheckpoint(CheckpointInputStream) - Method in class alluxio.master.metastore.heap.HeapInodeStore
 
restoreFromCheckpoint(CheckpointInputStream) - Method in class alluxio.master.metastore.rocks.RocksInodeStore
 
restoreFromCheckpoint(CheckpointInputStream) - Method in class alluxio.master.metastore.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
 
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.
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.
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.
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
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.
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>) - Method in class alluxio.AbstractClient
Tries to execute an RPC defined as a AbstractClient.RpcCallable.
retryRPC(AbstractClient.RpcCallable<V>, String) - Method in class alluxio.AbstractClient
Tries to execute an RPC defined as a AbstractClient.RpcCallable.
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.BaseFileSystem
 
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(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.FileSystemMasterClientServiceImplBase
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.hadoop.AlluxioHdfsFileSystem
 
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
 
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.AlluxioFuseFileSystem
Deletes an empty directory.
RocksBlockStore - Class in alluxio.master.metastore.rocks
Block store backed by RocksDB.
RocksBlockStore(String) - Constructor for class alluxio.master.metastore.rocks.RocksBlockStore
Creates and initializes a rocks block store.
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.
RocksPageStore - Class in alluxio.client.file.cache.store
A page store implementation which utilizes rocksDB to persist the data.
RocksPageStoreOptions - Class in alluxio.client.file.cache.store
Options used to instantiate RocksPageStore.
RocksPageStoreOptions() - Constructor for class alluxio.client.file.cache.store.RocksPageStoreOptions
Creates a new instance of RocksPageStoreOptions.
RocksStore - Class in alluxio.master.metastore.rocks
Class for managing a rocksdb database.
RocksStore(String, String, Collection<ColumnFamilyDescriptor>, DBOptions, List<AtomicReference<ColumnFamilyHandle>>) - Constructor for class alluxio.master.metastore.rocks.RocksStore
 
RocksUtils - Class in alluxio.master.metastore.rocks
Convenience methods for working with RocksDB.
ROLE_VALUE - Static variable in enum alluxio.grpc.table.PrincipalType
ROLE = 1;
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.
RoundRobinAllocator - Class in alluxio.worker.block.allocator
A round-robin allocator that allocates a block in the storage dir.
RoundRobinAllocator(BlockMetadataView) - Constructor for class alluxio.worker.block.allocator.RoundRobinAllocator
Creates a new instance of RoundRobinAllocator.
RoundRobinPolicy - Class in alluxio.client.block.policy
A policy that chooses the worker for the next block in a round-robin manner and skips workers that do not have enough space.
RoundRobinPolicy(AlluxioConfiguration) - Constructor for class alluxio.client.block.policy.RoundRobinPolicy
Constructs a new RoundRobinPolicy.
RowsCommitter - Class in alluxio.job.plan.transform.format.tables
Determines whether to commit based on the number of rows that have been written.
RowsCommitter(int) - Constructor for class alluxio.job.plan.transform.format.tables.RowsCommitter
 
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) - Constructor for class alluxio.master.file.RpcContext
Creates an RpcContext.
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.
RpcUtils - Class in alluxio
Utilities for handling server RPC calls.
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.
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(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.CheckConsistencyCommand
 
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.CopyFromLocalCommand
 
run(CommandLine) - Method in class alluxio.cli.fs.command.CopyToLocalCommand
 
run(CommandLine) - Method in class alluxio.cli.fs.command.CountCommand
 
run(CommandLine) - Method in class alluxio.cli.fs.command.CpCommand
 
run(CommandLine) - Method in class alluxio.cli.fs.command.DistributedCpCommand
 
run(CommandLine) - Method in class alluxio.cli.fs.command.DistributedLoadCommand
 
run(CommandLine) - Method in class alluxio.cli.fs.command.DistributedMvCommand
 
run(CommandLine) - Method in class alluxio.cli.fs.command.DuCommand
 
run(CommandLine) - Method in class alluxio.cli.fs.command.FreeCommand
 
run(CommandLine) - Method in class alluxio.cli.fs.command.GetCapacityBytesCommand
 
run(CommandLine) - Method in class alluxio.cli.fs.command.GetFaclCommand
 
run(CommandLine) - Method in class alluxio.cli.fs.command.GetSyncPathListCommand
 
run(CommandLine) - Method in class alluxio.cli.fs.command.GetUsedBytesCommand
 
run(CommandLine) - Method in class alluxio.cli.fs.command.HeadCommand
 
run(CommandLine) - Method in class alluxio.cli.fs.command.HelpCommand
 
run(CommandLine) - Method in class alluxio.cli.fs.command.LeaderCommand
 
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.MasterInfoCommand
 
run(CommandLine) - Method in class alluxio.cli.fs.command.MkdirCommand
 
run(CommandLine) - Method in class alluxio.cli.fs.command.MountCommand
 
run(CommandLine) - Method in class alluxio.cli.fs.command.MvCommand
 
run(CommandLine) - Method in class alluxio.cli.fs.command.PersistCommand
 
run(CommandLine) - Method in class alluxio.cli.fs.command.PinCommand
 
run(CommandLine) - Method in class alluxio.cli.fs.command.RmCommand
 
run(CommandLine) - Method in class alluxio.cli.fs.command.SetFaclCommand
 
run(CommandLine) - Method in class alluxio.cli.fs.command.SetReplicationCommand
 
run(CommandLine) - Method in class alluxio.cli.fs.command.SetTtlCommand
 
run(CommandLine) - Method in class alluxio.cli.fs.command.StartSyncCommand
 
run(CommandLine) - Method in class alluxio.cli.fs.command.StatCommand
 
run(CommandLine) - Method in class alluxio.cli.fs.command.StopSyncCommand
 
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.fs.command.UnmountCommand
 
run(CommandLine) - Method in class alluxio.cli.fs.command.UnpinCommand
 
run(CommandLine) - Method in class alluxio.cli.fs.command.UnsetTtlCommand
 
run(CommandLine) - Method in class alluxio.cli.fs.command.UpdateMountCommand
 
run(CommandLine) - Method in class alluxio.cli.fsadmin.command.BackupCommand
 
run(CommandLine) - Method in class alluxio.cli.fsadmin.command.DoctorCommand
 
run(CommandLine) - Method in class alluxio.cli.fsadmin.command.GetBlockInfoCommand
 
run(CommandLine) - Method in class alluxio.cli.fsadmin.command.ReportCommand
 
run(CommandLine) - Method in class alluxio.cli.fsadmin.command.UfsCommand
 
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.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.pathconf.AddCommand
 
run(CommandLine) - Method in class alluxio.cli.fsadmin.pathconf.ListCommand
 
run(CommandLine) - Method in class alluxio.cli.fsadmin.pathconf.RemoveCommand
 
run(CommandLine) - Method in class alluxio.cli.fsadmin.pathconf.ShowCommand
 
run(CommandLine) - Method in class alluxio.cli.fsadmin.report.CapacityCommand
Runs report capacity command.
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.SummaryCommand
Runs report summary command.
run() - Method in class alluxio.cli.fsadmin.report.UfsCommand
Runs report ufs command.
run(CommandLine) - Method in class alluxio.cli.job.command.CancelCommand
 
run(CommandLine) - Method in class alluxio.cli.job.command.LeaderCommand
 
run(CommandLine) - Method in class alluxio.cli.job.command.ListCommand
 
run(CommandLine) - Method in class alluxio.cli.job.command.StatCommand
 
run(String[]) - Method in class alluxio.cli.RunOperation
 
run(CommandLine) - Method in class alluxio.cli.table.command.AbstractTableCommand
 
run(CommandLine) - Method in class alluxio.cli.table.command.AttachDatabaseCommand
 
run(CommandLine) - Method in class alluxio.cli.table.command.DetachDatabaseCommand
 
run(CommandLine) - Method in class alluxio.cli.table.command.ListDatabasesCommand
 
run(CommandLine) - Method in class alluxio.cli.table.command.SyncDatabaseCommand
 
run(CommandLine) - Method in class alluxio.cli.table.command.TransformStatusCommand
 
run(CommandLine) - Method in class alluxio.cli.table.command.TransformTableCommand
 
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) - 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.JobMasterClientServiceImplBase
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() - Method in class alluxio.logserver.AlluxioLog4jSocketNode
 
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(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(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 interface alluxio.retry.RetryUtils.RunnableThrowsIOException
Runs the runnable.
run() - Method in class alluxio.shell.ShellCommand
Runs a command and returns its stdout on success.
run() - Method in class alluxio.worker.job.task.TaskExecutor
 
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.
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.
runExample(Callable<Boolean>) - Static method in class alluxio.cli.CliUtils
Runs an example.
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.
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.CheckConsistencyCommand
 
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.DuCommand
 
runPlainPath(AlluxioURI, CommandLine) - Method in class alluxio.cli.fs.command.FreeCommand
 
runPlainPath(AlluxioURI, CommandLine) - Method in class alluxio.cli.fs.command.GetFaclCommand
 
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.PinCommand
 
runPlainPath(AlluxioURI, CommandLine) - Method in class alluxio.cli.fs.command.RmCommand
 
runPlainPath(AlluxioURI, CommandLine) - Method in class alluxio.cli.fs.command.SetFaclCommand
 
runPlainPath(AlluxioURI, CommandLine) - Method in class alluxio.cli.fs.command.SetTtlCommand
 
runPlainPath(AlluxioURI, CommandLine) - Method in class alluxio.cli.fs.command.StartSyncCommand
 
runPlainPath(AlluxioURI, CommandLine) - Method in class alluxio.cli.fs.command.StatCommand
 
runPlainPath(AlluxioURI, CommandLine) - Method in class alluxio.cli.fs.command.StopSyncCommand
 
runPlainPath(AlluxioURI, CommandLine) - Method in class alluxio.cli.fs.command.TailCommand
 
runPlainPath(AlluxioURI, CommandLine) - Method in class alluxio.cli.fs.command.TouchCommand
 
runPlainPath(AlluxioURI, CommandLine) - Method in class alluxio.cli.fs.command.UnmountCommand
 
runPlainPath(AlluxioURI, CommandLine) - Method in class alluxio.cli.fs.command.UnpinCommand
 
runPlainPath(AlluxioURI, CommandLine) - Method in class alluxio.cli.fs.command.UnsetTtlCommand
 
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
 
runTask(LoadConfig, ArrayList<LoadDefinition.LoadTask>, RunTaskContext) - Method in class alluxio.job.plan.load.LoadDefinition
 
runTask(MigrateConfig, ArrayList<MigrateCommand>, RunTaskContext) - Method in class alluxio.job.plan.migrate.MigrateDefinition
Runs the task in the executor.
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(EvictConfig, SerializableVoid, RunTaskContext) - Method in class alluxio.job.plan.replicate.EvictDefinition
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(ReplicateConfig, SerializableVoid, RunTaskContext) - Method in class alluxio.job.plan.replicate.ReplicateDefinition
Runs the task in the executor.
runTask(CompactConfig, ArrayList<CompactTask>, RunTaskContext) - Method in class alluxio.job.plan.transform.CompactDefinition
 
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.
RUNTIME - Static variable in class alluxio.conf.Source
 
RuntimeConstants - Class in alluxio
System constants that are determined during runtime.
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.

S

S3_CONTENT_LENGTH_HEADER - Static variable in class alluxio.proxy.s3.S3Constants
 
S3_DATE_FORMAT_REGEXP - Static variable in class alluxio.proxy.s3.S3Constants
 
S3_DEFAULT_MAX_KEYS - Static variable in class alluxio.proxy.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_EMPTY_ETAG - Static variable in class alluxio.proxy.s3.S3Constants
 
S3_MULTIPART_TEMPORARY_DIR_SUFFIX - Static variable in class alluxio.Constants
 
S3_STANDARD_STORAGE_CLASS - Static variable in class alluxio.proxy.s3.S3Constants
 
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
A wrapper around an S3ObjectInputStream which handles skips efficiently.
S3AInputStream(String, String, AmazonS3, 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.
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
[Experimental] A stream for writing a file into S3 using streaming upload.
S3ALowLevelOutputStream(String, String, AmazonS3, ListeningExecutorService, long, List<String>, boolean) - Constructor for class alluxio.underfs.s3a.S3ALowLevelOutputStream
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.
S3ASpecificOperations - Class in alluxio.examples
Examples for S3A specific under filesystem operations.
S3ASpecificOperations(String, UnderFileSystem, InstancedConfiguration) - Constructor for class alluxio.examples.S3ASpecificOperations
 
S3AUnderFileSystem - Class in alluxio.underfs.s3a
S3 UnderFileSystem implementation based on the aws-java-sdk-s3 library.
S3AUnderFileSystem(AlluxioURI, AmazonS3Client, String, ExecutorService, TransferManager, UnderFileSystemConfiguration, boolean) - Constructor for class alluxio.underfs.s3a.S3AUnderFileSystem
Constructor for S3AUnderFileSystem.
S3AUnderFileSystemFactory - Class in alluxio.underfs.s3a
Factory for creating S3AUnderFileSystem.
S3AUnderFileSystemFactory() - Constructor for class alluxio.underfs.s3a.S3AUnderFileSystemFactory
Constructs a new S3AUnderFileSystemFactory.
S3AUtils - Class in alluxio.underfs.s3a
Util functions for S3A under file system.
S3Constants - Class in alluxio.proxy.s3
Constants for S3 northbound API.
S3Error - Class in alluxio.proxy.s3
Error response defined in http://docs.aws.amazon.com/AmazonS3/latest/API/ErrorResponses.html.
S3Error() - Constructor for class alluxio.proxy.s3.S3Error
Creates an S3Error.
S3Error(String, S3ErrorCode) - Constructor for class alluxio.proxy.s3.S3Error
Creates a new Error.
S3ErrorCode - Class in alluxio.proxy.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.proxy.s3.S3ErrorCode
Constructs a new S3ErrorCode.
S3ErrorCode.Name - Class in alluxio.proxy.s3
Error code names used in S3ErrorCode.
S3Exception - Exception in alluxio.proxy.s3
An exception thrown during processing S3 REST requests.
S3Exception(String, S3ErrorCode) - Constructor for exception alluxio.proxy.s3.S3Exception
Constructs a new S3Exception.
S3Exception(Exception, String, S3ErrorCode) - Constructor for exception alluxio.proxy.s3.S3Exception
Derives a new S3Exception from an existing exception.
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.
S_CLIENT_ID_KEY - Static variable in class alluxio.security.authentication.ChannelIdInjector
Metadata key for the channel Id.
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.SaslAuthenticationServiceBlockingStub - Class in alluxio.grpc
 
SaslAuthenticationServiceGrpc.SaslAuthenticationServiceFutureStub - Class in alluxio.grpc
 
SaslAuthenticationServiceGrpc.SaslAuthenticationServiceImplBase - Class in alluxio.grpc
 
SaslAuthenticationServiceGrpc.SaslAuthenticationServiceStub - Class in alluxio.grpc
 
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.
SCALE_FIELD_NUMBER - Static variable in class alluxio.grpc.table.Decimal
 
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(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.FileSystemOptions
 
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.FileSystemMasterClientServiceImplBase
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.FileSystemOptions
 
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, long) - Constructor for class alluxio.heartbeat.ScheduledTimer
Creates a new instance of ScheduledTimer.
schedulerIsIdle() - Method in class alluxio.util.executor.ControllableScheduler
Reports whether scheduler has no commands/tasks pending immediate execution.
scheduleWithFixedDelay(Runnable, long, long, TimeUnit) - Method in class alluxio.util.executor.ControllableScheduler
 
Schema - 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
 
SCHEMA_FIELD_NUMBER - Static variable in class alluxio.proto.journal.Table.AddTableEntry
 
SchemaOrBuilder - Interface in alluxio.grpc.table
 
SCHEME - Static variable in class alluxio.Constants
 
SCHEME_INSECURE - Static variable in class alluxio.underfs.wasb.WasbUnderFileSystem
Constant for the wasb URI scheme.
SCHEME_SECURE - Static variable in class alluxio.underfs.wasb.WasbUnderFileSystem
Constant for the wasbs URI scheme.
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.
ScpCommand - Class in alluxio.shell
Object representation of a remote scp command.
ScpCommand(String, String, String) - Constructor for class alluxio.shell.ScpCommand
Creates a remote scp command to copy a file to local.
ScpCommand(String, String, String, boolean) - Constructor for class alluxio.shell.ScpCommand
Creates a remote scp command to copy a file/dir to local.
scpCommandWithOutput(String, String, String, boolean) - Static method in class alluxio.util.ShellUtils
Static method to execute an scp command to copy a remote file/dir to local.
search(String) - Method in class alluxio.conf.path.TrieNode
Traverses the trie along the path components until the traversal cannot proceed any more.
searchPropertiesFile(String, String[]) - Static method in class alluxio.util.ConfigurationUtils
Searches the given properties file from a list of paths.
SECOND - Static variable in class alluxio.Constants
 
SECOND_MS - Static variable in class alluxio.Constants
 
SECOND_NANO - Static variable in class alluxio.Constants
 
SECOND_TIER - Static variable in class alluxio.Constants
 
SECONDARY_MASTER_METASTORE_DIR - Static variable in class alluxio.conf.PropertyKey.Name
 
SECONDARY_MASTER_METASTORE_DIR - Static variable in class alluxio.conf.PropertyKey
 
SecureHdfsValidationTask - Class in alluxio.cli.validation
Task for validating security configurations.
SecureHdfsValidationTask(String) - Constructor for class alluxio.cli.validation.SecureHdfsValidationTask
Constructor of SecureHdfsValidationTask.
SECURITY_AUTHENTICATION_CUSTOM_PROVIDER_CLASS - Static variable in class alluxio.conf.PropertyKey.Name
 
SECURITY_AUTHENTICATION_CUSTOM_PROVIDER_CLASS - Static variable in class alluxio.conf.PropertyKey
 
SECURITY_AUTHENTICATION_TYPE - Static variable in class alluxio.conf.PropertyKey.Name
 
SECURITY_AUTHENTICATION_TYPE - Static variable in class alluxio.conf.PropertyKey
 
SECURITY_AUTHORIZATION_PERMISSION_ENABLED - Static variable in class alluxio.conf.PropertyKey.Name
 
SECURITY_AUTHORIZATION_PERMISSION_ENABLED - Static variable in class alluxio.conf.PropertyKey
 
SECURITY_AUTHORIZATION_PERMISSION_SUPERGROUP - Static variable in class alluxio.conf.PropertyKey.Name
 
SECURITY_AUTHORIZATION_PERMISSION_SUPERGROUP - Static variable in class alluxio.conf.PropertyKey
 
SECURITY_AUTHORIZATION_PERMISSION_UMASK - Static variable in class alluxio.conf.PropertyKey.Name
 
SECURITY_AUTHORIZATION_PERMISSION_UMASK - Static variable in class alluxio.conf.PropertyKey
 
SECURITY_GROUP_MAPPING_CACHE_TIMEOUT_MS - Static variable in class alluxio.conf.PropertyKey.Name
 
SECURITY_GROUP_MAPPING_CACHE_TIMEOUT_MS - Static variable in class alluxio.conf.PropertyKey
 
SECURITY_GROUP_MAPPING_CLASS - Static variable in class alluxio.conf.PropertyKey.Name
 
SECURITY_GROUP_MAPPING_CLASS - Static variable in class alluxio.conf.PropertyKey
 
SECURITY_LOGIN_IMPERSONATION_USERNAME - Static variable in class alluxio.conf.PropertyKey.Name
 
SECURITY_LOGIN_IMPERSONATION_USERNAME - Static variable in class alluxio.conf.PropertyKey
 
SECURITY_LOGIN_USERNAME - Static variable in class alluxio.conf.PropertyKey.Name
 
SECURITY_LOGIN_USERNAME - Static variable in class alluxio.conf.PropertyKey
 
SecurityUtils - Class in alluxio.util
Utility methods for security.
seek(long) - Method in class alluxio.client.block.stream.BlockInStream
 
seek(long) - Method in class alluxio.client.file.AlluxioFileInStream
 
seek(long) - Method in class alluxio.client.file.cache.LocalCacheFileInStream
 
seek(long) - Method in class alluxio.hadoop.AlluxioHdfsInputStream
 
seek(long) - Method in class alluxio.hadoop.HdfsFileInputStream
 
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.hdfs.HdfsPositionedUnderFileInputStream
 
seek(long) - Method in class alluxio.underfs.hdfs.HdfsUnderFileInputStream
 
Seekable - Interface in alluxio
This interface should be implemented by all Alluxio streams which support moving the read position to a specific byte offset.
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.HdfsFileInputStream
This method is not supported in HdfsFileInputStream.
selectDirWithRequestedSpace(long, BlockStoreLocation, BlockMetadataEvictorView) - Static method in class alluxio.worker.block.evictor.EvictorUtils
Finds a directory in the given location range with capacity upwards of the given bound.
selectExecutors(LoadConfig, List<WorkerInfo>, SelectExecutorsContext) - Method in class alluxio.job.plan.load.LoadDefinition
 
selectExecutors(MigrateConfig, List<WorkerInfo>, SelectExecutorsContext) - Method in class alluxio.job.plan.migrate.MigrateDefinition
Selects the workers to run the task.
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(EvictConfig, List<WorkerInfo>, SelectExecutorsContext) - Method in class alluxio.job.plan.replicate.EvictDefinition
 
selectExecutors(MoveConfig, List<WorkerInfo>, SelectExecutorsContext) - Method in class alluxio.job.plan.replicate.MoveDefinition
 
selectExecutors(ReplicateConfig, List<WorkerInfo>, SelectExecutorsContext) - Method in class alluxio.job.plan.replicate.ReplicateDefinition
 
selectExecutors(CompactConfig, List<WorkerInfo>, SelectExecutorsContext) - Method in class alluxio.job.plan.transform.CompactDefinition
 
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.
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
 
sendAndReceive(T) - Method in class alluxio.master.transport.GrpcMessagingConnection
 
sendDataMessage(DataMessage<ReqT, DataBuffer>, long) - Method in class alluxio.client.block.stream.GrpcDataMessageBlockingStream
Sends a request.
sendMessageBlocking(Connection, Object) - Method in class alluxio.master.backup.AbstractBackupRole
Used to send message via connection and wait until response is received.
SEPARATOR - Static variable in class alluxio.AlluxioURI
 
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.
SERIALIZATION_FORMAT - Static variable in class alluxio.job.plan.transform.HiveConstants
Serialization format.
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(AccessControlList, JsonGenerator, SerializerProvider) - Method in class alluxio.security.authorization.AccessControlList.AccessControlListSerializer
Serialize an AccessControlList object.
serialize() - Method in class alluxio.underfs.Fingerprint
 
server() - Method in class alluxio.master.transport.GrpcMessagingTransport
 
Server<T> - Interface in alluxio
Interface representing an Alluxio server.
SERVER_VALUE - Static variable in enum alluxio.grpc.Scope
SERVER = 3;
SERVERADDRESS_FIELD_NUMBER - Static variable in class alluxio.grpc.QuorumServerInfo
 
SERVERADDRESS_FIELD_NUMBER - Static variable in class alluxio.grpc.RemoveQuorumServerPRequest
 
ServerConfiguration - Class in alluxio.conf
Global configuration properties of Alluxio.
ServerConfigurationChecker - Class in alluxio.master.meta.checkconf
This class is responsible for checking server-side configuration.
ServerConfigurationChecker(ServerConfigurationStore, ServerConfigurationStore) - Constructor for class alluxio.master.meta.checkconf.ServerConfigurationChecker
Constructs a new ServerConfigurationChecker.
ServerConfigurationStore - Class in alluxio.master.meta.checkconf
This class is responsible for recording server-side configuration.
ServerConfigurationStore() - Constructor for class alluxio.master.meta.checkconf.ServerConfigurationStore
Constructs a new ServerConfigurationStore.
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_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.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.MetricsMasterClientServiceGrpc
 
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_NAME - Static variable in class alluxio.master.block.BlockMasterClientRestServiceHandler
Deprecated.
 
SERVICE_PREFIX - Static variable in class alluxio.master.AlluxioJobMasterRestServiceHandler
 
SERVICE_PREFIX - Static variable in class alluxio.master.block.BlockMasterClientRestServiceHandler
Deprecated.
 
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.S3RestServiceHandler
 
SERVICE_PREFIX - Static variable in class alluxio.proxy.StreamsRestServiceHandler
 
SERVICE_PREFIX - Static variable in class alluxio.worker.AlluxioJobWorkerRestServiceHandler
 
SERVICE_PREFIX - Static variable in class alluxio.worker.AlluxioWorkerRestServiceHandler
 
SERVICE_VERSION - Static variable in class alluxio.job.ServiceConstants
 
SERVICE_VERSION - Static variable in class alluxio.master.block.BlockMasterClientRestServiceHandler
Deprecated.
 
ServiceConstants - Class in alluxio.job
Alluxio job service constants.
ServiceNotFoundException - Exception in alluxio.exception
Exception used when the service is not provided by the server.
ServiceNotFoundException(String) - Constructor for exception alluxio.exception.ServiceNotFoundException
Constructs a new exception with the specified detail message.
ServiceNotFoundException(String, Throwable) - Constructor for exception alluxio.exception.ServiceNotFoundException
Constructs a new exception with the specified detail message and cause.
ServiceNotFoundException(ExceptionMessage, Object...) - Constructor for exception alluxio.exception.ServiceNotFoundException
Constructs a new exception with the specified exception message and multiple parameters.
ServiceNotFoundException(ExceptionMessage, Throwable, Object...) - Constructor for exception alluxio.exception.ServiceNotFoundException
Constructs a new exception with the specified exception message, the cause and multiple parameters.
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.ServiceVersionClientServiceBlockingStub - Class in alluxio.grpc
 
ServiceVersionClientServiceGrpc.ServiceVersionClientServiceFutureStub - Class in alluxio.grpc
 
ServiceVersionClientServiceGrpc.ServiceVersionClientServiceImplBase - Class in alluxio.grpc
 
ServiceVersionClientServiceGrpc.ServiceVersionClientServiceStub - Class in alluxio.grpc
 
ServiceVersionClientServiceHandler - Class in alluxio.grpc
This class is a gRPC handler that serves Alluxio service versions.
ServiceVersionClientServiceHandler(Set<ServiceType>) - Constructor for class alluxio.grpc.ServiceVersionClientServiceHandler
Creates service version handler that allows given services.
ServiceVersionClientServiceImplBase() - Constructor for class alluxio.grpc.ServiceVersionClientServiceGrpc.ServiceVersionClientServiceImplBase
 
serving() - Method in class alluxio.master.MasterHealthCheckClient.MasterServingHealthCheck
 
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.
sessionHeartbeat(long) - Method in class alluxio.Sessions
Performs session heartbeat.
sessionHeartbeat(long) - Method in interface alluxio.worker.block.BlockWorker
Handles the heartbeat from a client.
sessionHeartbeat(long) - Method in class alluxio.worker.block.DefaultBlockWorker
 
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(PropertyKey, String) - Method in class alluxio.conf.AlluxioProperties
Puts the key value pair specified by users.
set(PropertyKey, Object) - Method in class alluxio.conf.InstancedConfiguration
Sets the value for the appropriate key in the Properties.
set(PropertyKey, Object, Source) - Method in class alluxio.conf.InstancedConfiguration
Sets the value for the appropriate key in the Properties by source.
set(PropertyKey, Object) - Static method in class alluxio.conf.ServerConfiguration
Sets the value for the appropriate key in the Properties.
set(PropertyKey, Object, Source) - Static method in class alluxio.conf.ServerConfiguration
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.BaseFileSystem
 
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(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) - 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.FileSystemMasterClientServiceImplBase
Sets ACL for the path.
setAcl(SetAclPRequest, StreamObserver<SetAclPResponse>) - Method in class alluxio.grpc.FileSystemMasterClientServiceGrpc.FileSystemMasterClientServiceStub
Sets ACL for the path.
setAcl(AlluxioURI, SetAclAction, List<AclEntry>, SetAclPOptions) - Method in class alluxio.hadoop.AlluxioHdfsFileSystem
 
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.FileSystemOptions
 
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;
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.
setActiveSyncTxId(File.ActiveSyncTxIdEntry) - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
optional .alluxio.proto.journal.ActiveSyncTxIdEntry active_sync_tx_id = 34;
setActiveSyncTxId(File.ActiveSyncTxIdEntry.Builder) - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
optional .alluxio.proto.journal.ActiveSyncTxIdEntry active_sync_tx_id = 34;
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;
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(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
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;
setAddTable(Table.AddTableEntry) - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
optional .alluxio.proto.journal.AddTableEntry add_table = 43;
setAddTable(Table.AddTableEntry.Builder) - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
optional .alluxio.proto.journal.AddTableEntry add_table = 43;
setAddTransformJobInfo(Table.AddTransformJobInfoEntry) - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
optional .alluxio.proto.journal.AddTransformJobInfoEntry add_transform_job_info = 46;
setAddTransformJobInfo(Table.AddTransformJobInfoEntry.Builder) - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
optional .alluxio.proto.journal.AddTransformJobInfoEntry add_transform_job_info = 46;
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
optional .alluxio.grpc.table.AllOrNoneSet all_or_none = 3;
setAllOrNone(AllOrNoneSet.Builder) - Method in class alluxio.grpc.table.Domain.Builder
optional .alluxio.grpc.table.AllOrNoneSet all_or_none = 3;
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
 
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;
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.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;
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.
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;
setAttachDb(Table.AttachDbEntry) - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
optional .alluxio.proto.journal.AttachDbEntry attach_db = 44;
setAttachDb(Table.AttachDbEntry.Builder) - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
optional .alluxio.proto.journal.AttachDbEntry attach_db = 44;
setAttribute(AlluxioURI, SetAttributePOptions) - Method in class alluxio.client.file.BaseFileSystem
 
setAttribute(AlluxioURI, SetAttributePOptions) - Method in class alluxio.client.file.DelegatingFileSystem
 
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(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.FileSystemMasterClientServiceImplBase
Sets file or directory attributes.
setAttribute(SetAttributePRequest, StreamObserver<SetAttributePResponse>) - Method in class alluxio.grpc.FileSystemMasterClientServiceGrpc.FileSystemMasterClientServiceStub
Sets file or directory attributes.
setAttribute(AlluxioURI, SetAttributePOptions) - Method in class alluxio.hadoop.AlluxioHdfsFileSystem
 
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
 
setAttributeClientDefaults(AlluxioConfiguration) - Static method in class alluxio.util.FileSystemOptions
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.FileSystemOptions
 
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
 
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.
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;
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;
setBinaryStats(BinaryColumnStatsData) - Method in class alluxio.grpc.table.ColumnStatisticsData.Builder
optional .alluxio.grpc.table.BinaryColumnStatsData binary_stats = 5;
setBinaryStats(BinaryColumnStatsData.Builder) - Method in class alluxio.grpc.table.ColumnStatisticsData.Builder
optional .alluxio.grpc.table.BinaryColumnStatsData binary_stats = 5;
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;
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;
setBlockId(long) - Method in class alluxio.grpc.AsyncCacheRequest.Builder
optional 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.CommitBlockInUfsPRequest.Builder
the id of the worker
setBlockId(long) - Method in class alluxio.grpc.CommitBlockPRequest.Builder
the id of the block being committed
setBlockId(long) - Method in class alluxio.grpc.CreateLocalBlockRequest.Builder
optional int64 block_id = 1;
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.OpenLocalBlockRequest.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.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.client.block.policy.options.GetWorkerOptions
 
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
 
setBlockInUfsTier(boolean) - Method in class alluxio.proto.dataserver.Protocol.OpenUfsBlockOptions.Builder
If set to true, the block is possibly stored as a UFS block.
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
 
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.proto.dataserver.Protocol.OpenUfsBlockOptions.Builder
The block size.
setBlockSize(long) - Method in class 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.
setBlockStoreFactory(BlockStore.Factory) - Method in class alluxio.master.CoreMasterContext.Builder
 
setBlockWorkerInfos(List<BlockWorkerInfo>) - Method in class alluxio.client.block.policy.options.GetWorkerOptions
 
setBlockWriter(BlockWriter) - Method in class alluxio.worker.grpc.BlockWriteRequestContext
 
setBooleanStats(BooleanColumnStatsData) - Method in class alluxio.grpc.table.ColumnStatisticsData.Builder
optional .alluxio.grpc.table.BooleanColumnStatsData boolean_stats = 1;
setBooleanStats(BooleanColumnStatsData.Builder) - Method in class alluxio.grpc.table.ColumnStatisticsData.Builder
optional .alluxio.grpc.table.BooleanColumnStatsData boolean_stats = 1;
setBooleanType(boolean) - Method in class alluxio.grpc.table.Value.Builder
optional 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.ListPartsResult
 
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;
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;
setBufferPoolSize(int) - Method in class alluxio.client.file.cache.store.LocalPageStoreOptions
 
setBufferSize(int) - Method in class alluxio.client.file.cache.store.LocalPageStoreOptions
 
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;
setBytesInBlockStore(long) - Method in class alluxio.proto.dataserver.Protocol.CreateUfsBlockOptions.Builder
the number of bytes previously written to block store zero if no previous temp block created
setBytesReserved(long) - Method in class alluxio.worker.grpc.BlockWriteRequestContext
 
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
 
setCacheHitLocal(String) - Method in class alluxio.wire.MasterWebUIMetrics
Sets cache hit local.
setCacheHitRemote(String) - Method in class alluxio.wire.MasterWebUIMetrics
Sets cache hit remote.
setCacheMiss(String) - Method in class alluxio.wire.MasterWebUIMetrics
Sets cache miss.
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.worker.grpc.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;
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
 
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;
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(Chunk) - Method in class alluxio.grpc.WriteRequest.Builder
optional .alluxio.grpc.block.Chunk chunk = 2;
setChunk(Chunk.Builder) - Method in class alluxio.grpc.WriteRequest.Builder
optional .alluxio.grpc.block.Chunk chunk = 2;
setChunkSize(long) - Method in class alluxio.grpc.ReadRequest.Builder
optional int64 chunk_size = 5;
setCleanupOnFailure(boolean) - Method in class alluxio.grpc.CreateLocalBlockRequest.Builder
optional bool cleanup_on_failure = 6;
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.
setClientType(String) - Method in class alluxio.grpc.GrpcChannelBuilder
Sets human readable name for the channel's client.
setClientType(String) - Method in class alluxio.grpc.GrpcChannelKey
 
setClusterAddresses(List<InetSocketAddress>) - Method in class alluxio.master.journal.raft.RaftJournalConfiguration
 
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;
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;
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;
setClusterId(String) - Method in class alluxio.proto.journal.Meta.ClusterInfoEntry.Builder
optional string cluster_id = 1;
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
 
setCode(String) - Method in class alluxio.proxy.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(MetaCommand) - Method in class alluxio.grpc.MasterHeartbeatPResponse.Builder
optional .alluxio.grpc.meta.MetaCommand command = 1;
setCommand(WriteRequestCommand) - Method in class alluxio.grpc.WriteRequest.Builder
optional .alluxio.grpc.block.WriteRequestCommand command = 1;
setCommand(WriteRequestCommand.Builder) - Method in class alluxio.grpc.WriteRequest.Builder
optional .alluxio.grpc.block.WriteRequestCommand command = 1;
setCommand(String) - Method in class alluxio.master.file.FileSystemMasterAuditContext
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;
setComment(String) - Method in class alluxio.proto.journal.Table.UpdateDatabaseInfoEntry.Builder
optional string comment = 6;
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;
setCommentBytes(ByteString) - Method in class alluxio.proto.journal.Table.UpdateDatabaseInfoEntry.Builder
optional string comment = 6;
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.StartSyncPOptions.Builder
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 1;
setCommonOptions(FileSystemMasterCommonPOptions.Builder) - Method in class alluxio.grpc.StartSyncPOptions.Builder
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 1;
setCommonOptions(FileSystemMasterCommonPOptions) - Method in class alluxio.grpc.StopSyncPOptions.Builder
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 1;
setCommonOptions(FileSystemMasterCommonPOptions.Builder) - Method in class alluxio.grpc.StopSyncPOptions.Builder
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 1;
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;
setCompleteTransformTable(Table.CompleteTransformTableEntry) - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
optional .alluxio.proto.journal.CompleteTransformTableEntry complete_transform_table = 48;
setCompleteTransformTable(Table.CompleteTransformTableEntry.Builder) - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
optional .alluxio.proto.journal.CompleteTransformTableEntry complete_transform_table = 48;
setCompressionType(CompressionType) - Method in class alluxio.client.file.cache.store.RocksPageStoreOptions
 
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.
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, String>) - Method in class alluxio.wire.AlluxioJobMasterInfo
 
setConfiguration(Map<String, String>) - Method in class alluxio.wire.AlluxioJobWorkerInfo
 
setConfiguration(Map<String, String>) - Method in class alluxio.wire.AlluxioMasterInfo
 
setConfiguration(Map<String, String>) - Method in class alluxio.wire.AlluxioProxyInfo
 
setConfiguration(Map<String, String>) - Method in class alluxio.wire.AlluxioWorkerInfo
 
setConfiguration(TreeSet<Triple<String, String, String>>) - Method in class alluxio.wire.MasterWebUIConfiguration
Sets configuration.
setConnection(Connection) - 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;
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;
setContent(List<ListBucketResult.Content>) - Method in class alluxio.proxy.s3.ListBucketResult
 
setContinuationToken(String) - Method in class alluxio.proxy.s3.ListBucketOptions
 
setContinuationToken(String) - Method in class alluxio.proxy.s3.ListBucketResult
 
setCount(long) - Method in class alluxio.grpc.StatusSummary.Builder
optional int64 count = 2;
setCounter(Counter) - Method in class alluxio.worker.grpc.ReadRequestContext
 
setCounter(Counter) - Method in class alluxio.worker.grpc.WriteRequestContext
 
setCreateAncestors(boolean) - Method in class alluxio.grpc.LoadMetadataPOptions.Builder
optional bool createAncestors = 2;
setCreateOptions(CreateOptions) - Method in class alluxio.worker.grpc.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.
setCreateUfsBlockOptions(Protocol.CreateUfsBlockOptions) - Method in class alluxio.grpc.WriteRequestCommand.Builder
optional .alluxio.proto.dataserver.CreateUfsBlockOptions create_ufs_block_options = 7;
setCreateUfsBlockOptions(Protocol.CreateUfsBlockOptions.Builder) - Method in class alluxio.grpc.WriteRequestCommand.Builder
optional .alluxio.proto.dataserver.CreateUfsBlockOptions create_ufs_block_options = 7;
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.
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
 
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
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(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;
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;
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.ReadRequestContext
 
setDateStats(DateColumnStatsData) - Method in class alluxio.grpc.table.ColumnStatisticsData.Builder
optional .alluxio.grpc.table.DateColumnStatsData date_stats = 7;
setDateStats(DateColumnStatsData.Builder) - Method in class alluxio.grpc.table.ColumnStatisticsData.Builder
optional .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;
setDbName(String) - Method in class alluxio.proto.journal.Table.AddTableEntry.Builder
optional string db_name = 1;
setDbName(String) - Method in class alluxio.proto.journal.Table.AddTransformJobInfoEntry.Builder
optional string db_name = 1;
setDbName(String) - Method in class alluxio.proto.journal.Table.AttachDbEntry.Builder
optional string db_name = 4;
setDbName(String) - Method in class alluxio.proto.journal.Table.CompleteTransformTableEntry.Builder
optional string db_name = 1;
setDbName(String) - Method in class alluxio.proto.journal.Table.DetachDbEntry.Builder
optional string db_name = 1;
setDbName(String) - Method in class alluxio.proto.journal.Table.RemoveTableEntry.Builder
optional string db_name = 1;
setDbName(String) - Method in class alluxio.proto.journal.Table.RemoveTransformJobInfoEntry.Builder
optional string db_name = 1;
setDbName(String) - Method in class alluxio.proto.journal.Table.UpdateDatabaseInfoEntry.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;
setDbNameBytes(ByteString) - Method in class alluxio.proto.journal.Table.AddTableEntry.Builder
optional string db_name = 1;
setDbNameBytes(ByteString) - Method in class alluxio.proto.journal.Table.AddTransformJobInfoEntry.Builder
optional string db_name = 1;
setDbNameBytes(ByteString) - Method in class alluxio.proto.journal.Table.AttachDbEntry.Builder
optional string db_name = 4;
setDbNameBytes(ByteString) - Method in class alluxio.proto.journal.Table.CompleteTransformTableEntry.Builder
optional string db_name = 1;
setDbNameBytes(ByteString) - Method in class alluxio.proto.journal.Table.DetachDbEntry.Builder
optional string db_name = 1;
setDbNameBytes(ByteString) - Method in class alluxio.proto.journal.Table.RemoveTableEntry.Builder
optional string db_name = 1;
setDbNameBytes(ByteString) - Method in class alluxio.proto.journal.Table.RemoveTransformJobInfoEntry.Builder
optional string db_name = 1;
setDbNameBytes(ByteString) - Method in class alluxio.proto.journal.Table.UpdateDatabaseInfoEntry.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.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
optional .alluxio.grpc.table.DecimalColumnStatsData decimal_stats = 6;
setDecimalStats(DecimalColumnStatsData.Builder) - Method in class alluxio.grpc.table.ColumnStatisticsData.Builder
optional .alluxio.grpc.table.DecimalColumnStatsData decimal_stats = 6;
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;
setDefinition(String) - Method in class alluxio.proto.journal.Table.AddTransformJobInfoEntry.Builder
optional string definition = 3;
setDefinition(String) - Method in class alluxio.proto.journal.Table.CompleteTransformTableEntry.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;
setDefinitionBytes(ByteString) - Method in class alluxio.proto.journal.Table.AddTransformJobInfoEntry.Builder
optional string definition = 3;
setDefinitionBytes(ByteString) - Method in class alluxio.proto.journal.Table.CompleteTransformTableEntry.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
 
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;
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;
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.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;
setDetachDb(Table.DetachDbEntry) - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
optional .alluxio.proto.journal.DetachDbEntry detach_db = 45;
setDetachDb(Table.DetachDbEntry.Builder) - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
optional .alluxio.proto.journal.DetachDbEntry detach_db = 45;
setDeviceSpec(String) - Method in class alluxio.util.UnixMountInfo.Builder
 
setDirectChildrenLoaded(Supplier<JournalContext>, InodeDirectory) - Method in class alluxio.master.file.meta.InodeTree
Marks an inode directory as having its direct children loaded.
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;
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.ReadRequestContext
 
setDoneUnsafe(boolean) - Method in class alluxio.worker.grpc.WriteRequestContext
 
setDoubleStats(DoubleColumnStatsData) - Method in class alluxio.grpc.table.ColumnStatisticsData.Builder
optional .alluxio.grpc.table.DoubleColumnStatsData double_stats = 3;
setDoubleStats(DoubleColumnStatsData.Builder) - Method in class alluxio.grpc.table.ColumnStatisticsData.Builder
optional .alluxio.grpc.table.DoubleColumnStatsData double_stats = 3;
setDoubleType(double) - Method in class alluxio.grpc.table.Value.Builder
optional double double_type = 2;
setDoubleValue(double) - Method in class alluxio.grpc.MetricValue.Builder
optional double doubleValue = 1;
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.RenamePRequest.Builder
the destination path
setDstPathBytes(ByteString) - Method in class alluxio.proto.journal.File.RenameEntry.Builder
Deprecated, use new_parent_id/new_name instead
setElectionTimeoutMs(long) - Method in class alluxio.master.journal.raft.RaftJournalConfiguration
 
setEmpty(boolean) - Method in class alluxio.security.authorization.DefaultAccessControlList
 
setEnsureAtomic(boolean) - Method in class alluxio.underfs.options.CreateOptions
Set atomicity guarantees.
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.worker.grpc.ReadRequestContext
 
setEquatable(EquatableValueSet) - Method in class alluxio.grpc.table.Domain.Builder
optional .alluxio.grpc.table.EquatableValueSet equatable = 2;
setEquatable(EquatableValueSet.Builder) - Method in class alluxio.grpc.table.Domain.Builder
optional .alluxio.grpc.table.EquatableValueSet equatable = 2;
setError(AlluxioException) - Method in class alluxio.wire.BackupStatus
Fails the backup with given error.
setError(Error) - Method in class alluxio.worker.grpc.ReadRequestContext
 
setError(Error) - Method in class alluxio.worker.grpc.WriteRequestContext
 
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.JobInfo.Builder
optional string errorMessage = 2;
setETag(String) - Method in class alluxio.proxy.s3.CompleteMultipartUploadResult
 
setETag(String) - Method in class alluxio.proxy.s3.ListBucketResult.Content
 
setETag(String) - Method in class alluxio.proxy.s3.ListPartsResult.Part
 
setEvictBatchSize(int) - Method in class alluxio.master.metastore.caching.CacheConfiguration.Builder
 
SetFaclCommand - Class in alluxio.cli.fs.command
Displays ACL info of a path.
SetFaclCommand(FileSystemContext) - Constructor for class alluxio.cli.fs.command.SetFaclCommand
 
setFailedNodeInfos(NodeInfo[]) - Method in class alluxio.wire.MasterWebUIWorkers
Sets failed node infos.
setFallback(boolean) - Method in class alluxio.proto.dataserver.Protocol.CreateUfsBlockOptions.Builder
true if the write request is already a fallback from a failed short-circuit write.
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.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.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.BlockStoreLocationProto.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.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.Command.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.CommitBlockInUfsPOptions.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.CommitBlockInUfsPRequest.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.CommitBlockInUfsPResponse.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.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.CreateLocalBlockRequest.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.CreateLocalBlockResponse.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.ExistsPOptions.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.FileBlockInfo.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.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.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.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.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.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.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.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.GetServiceVersionPRequest.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.GetServiceVersionPResponse.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.GetSyncPathListPRequest.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.GetSyncPathListPResponse.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.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.JobServiceSummary.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.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.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.LoadMetadataPOptions.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.LocalityTier.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.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.NetAddress.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.OpenFilePOptions.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.OpenLocalBlockRequest.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.OpenLocalBlockResponse.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.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.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.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.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.ReverseResolvePRequest.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.ReverseResolvePResponse.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.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.StartSyncPOptions.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.StartSyncPRequest.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.StartSyncPResponse.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.StatusSummary.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.StopSyncPOptions.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.StopSyncPRequest.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.StopSyncPResponse.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.StorageList.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.SyncPointInfo.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.TieredIdentity.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.TierList.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.TransportMessage.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.UfsInfo.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.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.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.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.CreateUfsBlockOptions.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.OpenUfsBlockOptions.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.proto.dataserver.Protocol.Response.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.Journal.JournalEntry.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.Table.AddTableEntry.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.proto.journal.Table.AddTransformJobInfoEntry.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.proto.journal.Table.AttachDbEntry.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.proto.journal.Table.CompleteTransformTableEntry.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.proto.journal.Table.DetachDbEntry.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.proto.journal.Table.RemoveTableEntry.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.proto.journal.Table.RemoveTransformJobInfoEntry.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.proto.journal.Table.UpdateDatabaseInfoEntry.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.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;
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.LocalPageStoreOptions
 
setFileData(String) - Method in class alluxio.wire.MasterWebUIBrowse
Sets file data.
setFileData(String) - Method in class alluxio.wire.MasterWebUILogs
Sets file data.
setFileData(String) - Method in class alluxio.wire.WorkerWebUILogs
Sets file data.
setFileDoesNotExistException(String) - Method in class alluxio.wire.MasterWebUIBrowse
Sets file does not exist exception.
setFileId(long) - Method in class alluxio.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.
setFileIdentifier(String) - Method in class alluxio.wire.FileInfo
 
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;
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.
setFileLocations(List<String>) - Method in class alluxio.util.webui.UIFileInfo
Sets file locations.
setFilesToPersist(List<PersistFile>) - Method in class alluxio.wire.PersistCommandOptions
Set the list of files to persist.
setFilter(int, MasterInfoField) - Method in class alluxio.grpc.GetMasterInfoPOptions.Builder
repeated .alluxio.grpc.meta.MasterInfoField filter = 1;
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;
setForkJoinTaskTag(short) - Method in class alluxio.concurrent.jsr.ForkJoinTask
Atomically sets the tag value for this task and returns the old value.
setFreeBytes(long) - Method in class alluxio.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.
setFsType(String) - Method in class alluxio.util.UnixMountInfo.Builder
 
setGcExecutor(ScheduledExecutorService) - Method in class alluxio.resource.DynamicResourcePool.Options
 
setGcIntervalMs(long) - Method in class alluxio.resource.DynamicResourcePool.Options
 
setGroup(String) - Method in class alluxio.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.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.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;
setHeartbeatIntervalMs(long) - Method in class alluxio.master.journal.raft.RaftJournalConfiguration
 
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
 
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.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.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.meta.InodeMeta.Inode.Builder
optional int64 id = 1;
setId(long) - Method in class alluxio.wire.WorkerInfo
 
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
 
setInconsistentPaths(int, String) - Method in class alluxio.grpc.CheckConsistencyPResponse.Builder
repeated string inconsistentPaths = 1;
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;
setInitialDelayMs(long) - Method in class alluxio.resource.DynamicResourcePool.Options
 
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.
setIp(String) - Method in class alluxio.master.file.FileSystemMasterAuditContext
Sets mIp field.
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.proto.meta.InodeMeta.Inode.Builder
optional bool is_directory = 3;
setIsEmpty(boolean) - Method in class alluxio.proto.shared.Acl.AccessControlList.Builder
optional bool isEmpty = 8;
setIsHidden(boolean) - Method in class alluxio.conf.PropertyKey.Builder
 
setIsMountPoint(boolean) - Method in class alluxio.proto.meta.InodeMeta.Inode.Builder
directory only
setIsPinned(boolean) - Method in class alluxio.proto.meta.InodeMeta.Inode.Builder
optional bool is_pinned = 9;
setIsThrowable(boolean) - Method in class alluxio.grpc.MessagingResponseHeader.Builder
optional bool isThrowable = 2;
setIsTruncated(boolean) - Method in class alluxio.proxy.s3.ListBucketResult
 
setIsTruncated(boolean) - Method in class alluxio.proxy.s3.ListPartsResult
 
setJobAsFailed(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;
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;
setJobErrorMessage(String) - Method in class alluxio.master.table.transform.TransformJobInfo
Sets the job error message.
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.GetJobStatusPRequest.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(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.proto.journal.Table.AddTransformJobInfoEntry.Builder
optional int64 job_id = 4;
setJobIds(int, long) - Method in class alluxio.grpc.ListAllPResponse.Builder
repeated int64 jobIds = 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;
setJobStatus(Status) - Method in class alluxio.grpc.table.TransformJobInfo.Builder
optional .alluxio.grpc.job.Status job_status = 5;
setJobStatus(Status) - Method in class alluxio.master.table.transform.TransformJobInfo
Sets the job status.
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;
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.
setJournalSystem(JournalSystem) - Method in class alluxio.master.CoreMasterContext.Builder
 
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.CompleteMultipartUploadResult
 
setKey(String) - Method in class alluxio.proxy.s3.InitiateMultipartUploadResult
 
setKey(String) - Method in class alluxio.proxy.s3.ListBucketResult.Content
 
setKey(String) - Method in class alluxio.proxy.s3.ListPartsResult
 
setKeyBytes(ByteString) - Method in class alluxio.proto.journal.File.StringPairEntry.Builder
optional string key = 1;
setKeyCount(int) - Method in class alluxio.proxy.s3.ListBucketResult
 
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
 
setLastContactSec(int) - Method in class alluxio.grpc.WorkerInfo.Builder
optional int32 lastContactSec = 3;
setLastContactSec(int) - Method in class alluxio.wire.WorkerInfo
 
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.ListBucketResult.Content
 
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;
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;
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;
setLayout(Layout) - Method in class alluxio.proto.journal.Table.AddTableEntry.Builder
optional .alluxio.grpc.table.Layout layout = 5;
setLayout(Layout.Builder) - Method in class alluxio.proto.journal.Table.AddTableEntry.Builder
optional .alluxio.grpc.table.Layout layout = 5;
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;
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;
setLength(long) - Method in class alluxio.grpc.AsyncCacheRequest.Builder
optional int64 length = 5;
setLength(long) - Method in class alluxio.grpc.BlockInfo.Builder
optional int64 length = 2;
setLength(long) - Method in class alluxio.grpc.CommitBlockInUfsPRequest.Builder
the space used in bytes on the target tier
setLength(long) - Method in class alluxio.grpc.CommitBlockPRequest.Builder
the length of the block being committed
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.master.file.meta.MutableInodeFile
 
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
 
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
 
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.
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;
setLocalAddress(InetSocketAddress) - Method in class alluxio.master.journal.raft.RaftJournalConfiguration
 
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.proto.journal.Table.UpdateDatabaseInfoEntry.Builder
optional string location = 2;
setLocation(String) - Method in class alluxio.proxy.s3.CompleteMultipartUploadResult
 
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;
setLocationBytes(ByteString) - Method in class alluxio.proto.journal.Table.UpdateDatabaseInfoEntry.Builder
optional string location = 2;
setLocationPolicy(BlockLocationPolicy) - Method in class alluxio.client.file.options.OutStreamOptions
 
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;
setLongStats(LongColumnStatsData) - Method in class alluxio.grpc.table.ColumnStatisticsData.Builder
optional .alluxio.grpc.table.LongColumnStatsData long_stats = 2;
setLongStats(LongColumnStatsData.Builder) - Method in class alluxio.grpc.table.ColumnStatisticsData.Builder
optional .alluxio.grpc.table.LongColumnStatsData long_stats = 2;
setLongType(long) - Method in class alluxio.grpc.table.Value.Builder
optional int64 long_type = 1;
setLostWorkerNum(int) - Method in class alluxio.grpc.BlockMasterInfo.Builder
optional int32 lostWorkerNum = 5;
setLostWorkerNum(int) - Method in class alluxio.wire.BlockMasterInfo
 
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
 
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(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;
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.GetMasterIdPResponse.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.
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.
setMaxBufferPoolSize(int) - Method in class alluxio.client.file.cache.store.RocksPageStoreOptions
 
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;
setMaxKeys(String) - Method in class alluxio.proxy.s3.ListBucketOptions
 
setMaxKeys(int) - Method in class alluxio.proxy.s3.ListBucketResult
 
setMaxLogSize(long) - Method in class alluxio.master.journal.raft.RaftJournalConfiguration
 
setMaxPageSize(int) - Method in class alluxio.client.file.cache.store.RocksPageStoreOptions
 
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;
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(String) - Method in class alluxio.grpc.CreateLocalBlockRequest.Builder
optional string medium_type = 7;
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.CreateLocalBlockRequest.Builder
optional string medium_type = 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(Set<String>) - Method in class alluxio.master.file.meta.MutableInode
 
setMediumTypes(Set<String>) - Method in class alluxio.wire.FileInfo
 
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.S3Error
 
setMessage(String) - Method in class alluxio.wire.LogInfo
 
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;
setMetadataLoad(boolean) - Method in class alluxio.master.file.contexts.CreatePathContext
 
setMeter(Meter) - Method in class alluxio.worker.grpc.ReadRequestContext
 
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
 
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(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.cos.COSUnderFileSystem
 
setMode(String, short) - Method in class alluxio.underfs.gcs.GCSUnderFileSystem
 
setMode(String, short) - Method in class alluxio.underfs.hdfs.HdfsUnderFileSystem
 
setMode(String, short) - Method in class alluxio.underfs.kodo.KodoUnderFileSystem
 
setMode(String, short) - Method in class alluxio.underfs.local.LocalUnderFileSystem
 
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 class alluxio.underfs.swift.SwiftUnderFileSystem
 
setMode(String, short) - Method in interface alluxio.underfs.UnderFileSystem
Changes posix file mode.
setMode(String, short) - Method in class alluxio.underfs.UnderFileSystemWithLogging
 
setMode(String, short) - Method in class alluxio.underfs.web.WebUnderFileSystem
 
setMode(int) - Method in class alluxio.wire.FileInfo
 
setMountId(long) - Method in class alluxio.client.file.options.OutStreamOptions
 
setMountId(long) - Method in class alluxio.grpc.FileInfo.Builder
optional int64 mountId = 23;
setMountId(long) - Method in class alluxio.grpc.GetUfsInfoPRequest.Builder
the id of the ufs
setMountId(long) - Method in class alluxio.proto.dataserver.Protocol.CreateUfsBlockOptions.Builder
mount ID of the UFS to write to
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
 
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
 
setMountPoints(Map<String, MountPointInfo>) - Method in class alluxio.wire.AlluxioMasterInfo
 
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 do not have these
setName(String) - Method in class alluxio.grpc.Metric.Builder
optional string name = 3;
setName(String) - Method in class alluxio.grpc.table.FieldSchema.Builder
optional string name = 2;
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.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.proxy.s3.ListBucketResult
 
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 do not have these
setNameBytes(ByteString) - Method in class alluxio.grpc.Metric.Builder
optional string name = 3;
setNameBytes(ByteString) - Method in class alluxio.grpc.table.FieldSchema.Builder
optional string name = 2;
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.meta.InodeMeta.Inode.Builder
optional string name = 6;
setNameBytes(ByteString) - Method in class alluxio.proto.shared.Acl.NamedAclActions.Builder
optional string name = 1;
setNetworkGroup(GrpcNetworkGroup) - Method in class alluxio.grpc.GrpcChannelBuilder
Sets the pooling strategy.
setNetworkGroup(GrpcNetworkGroup) - Method in class alluxio.grpc.GrpcChannelKey
 
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;
setNextContinuationToken(String) - Method in class alluxio.proxy.s3.ListBucketResult
 
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.
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;
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
 
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.WriteRequestCommand.Builder
optional int64 offset = 3;
setOffset(long) - Method in class alluxio.grpc.WriteResponse.Builder
Errors will be handled by standard gRPC stream APIs.
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
 
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.ReadRequest.Builder
Read receipt
setOnlyReserveSpace(boolean) - Method in class alluxio.grpc.CreateLocalBlockRequest.Builder
If set, only reserve space for the block.
setOnReadyHandler(Runnable) - Method in class alluxio.worker.grpc.DataMessageServerStreamObserver
 
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.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.
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.
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;
setOption(String, String) - Method in class alluxio.AlluxioRemoteLogFilter
Deprecated.
Sets option value use key=value format. The log4j.properties file uses this to set options. See the log4j.properties for more details.
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(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(CommitBlockInUfsPOptions) - Method in class alluxio.grpc.CommitBlockInUfsPRequest.Builder
optional .alluxio.grpc.block.CommitBlockInUfsPOptions options = 3;
setOptions(CommitBlockInUfsPOptions.Builder) - Method in class alluxio.grpc.CommitBlockInUfsPRequest.Builder
optional .alluxio.grpc.block.CommitBlockInUfsPOptions options = 3;
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(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(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(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(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(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(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(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(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(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(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(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(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(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(StartSyncPOptions) - Method in class alluxio.grpc.StartSyncPRequest.Builder
optional .alluxio.grpc.file.StartSyncPOptions options = 2;
setOptions(StartSyncPOptions.Builder) - Method in class alluxio.grpc.StartSyncPRequest.Builder
optional .alluxio.grpc.file.StartSyncPOptions options = 2;
setOptions(StopSyncPOptions) - Method in class alluxio.grpc.StopSyncPRequest.Builder
optional .alluxio.grpc.file.StopSyncPOptions options = 2;
setOptions(StopSyncPOptions.Builder) - Method in class alluxio.grpc.StopSyncPRequest.Builder
optional .alluxio.grpc.file.StopSyncPOptions options = 2;
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(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.
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.
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.BlockWriteRequestContext
 
setOutputStream(OutputStream) - Method in class alluxio.worker.grpc.UfsFileWriteRequestContext
 
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(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) - Method in class alluxio.proto.journal.Table.AddTableEntry.Builder
optional string owner = 3;
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.hdfs.HdfsUnderFileSystem
 
setOwner(String, String, String) - Method in class alluxio.underfs.kodo.KodoUnderFileSystem
 
setOwner(String, String, String) - Method in class alluxio.underfs.local.LocalUnderFileSystem
 
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 class alluxio.underfs.swift.SwiftUnderFileSystem
 
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, String, String) - Method in class alluxio.underfs.web.WebUnderFileSystem
 
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.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;
setOwnerBytes(ByteString) - Method in class alluxio.proto.journal.Table.AddTableEntry.Builder
optional string owner = 3;
setOwnerName(String) - Method in class alluxio.grpc.table.Database.Builder
optional string owner_name = 5;
setOwnerName(String) - Method in class alluxio.proto.journal.Table.UpdateDatabaseInfoEntry.Builder
optional string owner_name = 4;
setOwnerNameBytes(ByteString) - Method in class alluxio.grpc.table.Database.Builder
optional string owner_name = 5;
setOwnerNameBytes(ByteString) - Method in class alluxio.proto.journal.Table.UpdateDatabaseInfoEntry.Builder
optional string owner_name = 4;
setOwnerType(PrincipalType) - Method in class alluxio.grpc.table.Database.Builder
optional .alluxio.grpc.table.PrincipalType owner_type = 6;
setOwnerType(PrincipalType) - Method in class alluxio.proto.journal.Table.UpdateDatabaseInfoEntry.Builder
optional .alluxio.grpc.table.PrincipalType owner_type = 5;
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;
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;
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;
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
setPartitionCols(int, FieldSchema) - Method in class alluxio.proto.journal.Table.AddTableEntry.Builder
partitioning scheme
setPartitionCols(int, FieldSchema.Builder) - Method in class alluxio.proto.journal.Table.AddTableEntry.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;
setPartitions(int, Partition) - Method in class alluxio.proto.journal.Table.AddTableEntry.Builder
repeated .alluxio.grpc.table.Partition partitions = 9;
setPartitions(int, Partition.Builder) - Method in class alluxio.proto.journal.Table.AddTableEntry.Builder
repeated .alluxio.grpc.table.Partition partitions = 9;
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<ListPartsResult.Part>) - Method in class alluxio.proxy.s3.ListPartsResult
 
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.CreateLocalBlockResponse.Builder
optional string path = 1;
setPath(String) - Method in class alluxio.grpc.DeletePRequest.Builder
the path of the file or directory
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.ListStatusPRequest.Builder
the path of the file or directory
setPath(String) - Method in class alluxio.grpc.OpenLocalBlockResponse.Builder
optional 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.grpc.StartSyncPRequest.Builder
optional string path = 1;
setPath(String) - Method in class alluxio.grpc.StopSyncPRequest.Builder
optional string path = 1;
setPath(File) - Method in class alluxio.master.journal.raft.RaftJournalConfiguration
 
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.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.CreateLocalBlockResponse.Builder
optional string path = 1;
setPathBytes(ByteString) - Method in class alluxio.grpc.DeletePRequest.Builder
the path of the file or directory
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.ListStatusPRequest.Builder
the path of the file or directory
setPathBytes(ByteString) - Method in class alluxio.grpc.OpenLocalBlockResponse.Builder
optional 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.grpc.StartSyncPRequest.Builder
optional string path = 1;
setPathBytes(ByteString) - Method in class alluxio.grpc.StopSyncPRequest.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;
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;
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) - 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.MetaMasterConfigurationServiceImplBase
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
 
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;
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.CreateLocalBlockRequest.Builder
optional bool pin_on_create = 8;
setPinOnCreate(boolean) - Method in class alluxio.grpc.WriteRequestCommand.Builder
optional bool pin_on_create = 9;
setPort(int) - Method in class alluxio.master.CoreMasterContext.Builder
 
setPos(long) - Method in class alluxio.worker.grpc.WriteRequestContext
 
setPositionShort(boolean) - Method in class alluxio.client.file.options.InStreamOptions
Sets whether the operation is positioned read to a small buffer.
setPositionShort(boolean) - Method in class alluxio.grpc.ReadRequest.Builder
Is position read to a small buffer
setPositionShort(boolean) - Method in class alluxio.underfs.options.OpenOptions
 
setPosReceived(long) - Method in class alluxio.worker.grpc.ReadRequestContext
 
setPosToQueue(long) - Method in class alluxio.worker.grpc.ReadRequestContext
 
setPreferredRegion(String) - Method in class alluxio.underfs.swift.KeystoneV3Access
 
setPrefix(String) - Method in class alluxio.proxy.s3.ListBucketOptions
 
setPrefix(String) - Method in class alluxio.proxy.s3.ListBucketResult
 
setPreviousVersion(long) - Method in class alluxio.grpc.table.TableInfo.Builder
optional int64 previous_version = 9;
setPreviousVersion(long) - Method in class alluxio.proto.journal.Table.AddTableEntry.Builder
optional int64 previous_version = 10;
setPrimary(boolean) - Method in class alluxio.master.journal.options.JournalReaderOptions
 
setPrimary(boolean) - Method in class alluxio.master.journal.options.JournalWriterOptions
 
setProcessType(String) - Method in class alluxio.AlluxioRemoteLogFilter
Sets mProcessType to be the type of the process generating this log message.
setPromote(boolean) - Method in class alluxio.grpc.OpenLocalBlockRequest.Builder
optional bool promote = 2;
setPromote(boolean) - Method in class alluxio.grpc.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.
setProxyDownloadFileApiUrl(Map<String, String>) - Method in class alluxio.wire.MasterWebUIInit
Sets proxy download file api url.
setQuietTimeMs(long) - Method in class alluxio.master.journal.JournalSystem.Builder
 
setRange(RangeSet) - Method in class alluxio.grpc.table.Domain.Builder
optional .alluxio.grpc.table.RangeSet range = 1;
setRange(RangeSet.Builder) - Method in class alluxio.grpc.table.Domain.Builder
optional .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;
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.underfs.UnderFileSystemConfiguration
 
setReadOnly(boolean) - Method in class alluxio.wire.MountPointInfo
 
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;
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;
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;
setRemoveTable(Table.RemoveTableEntry) - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
optional .alluxio.proto.journal.RemoveTableEntry remove_table = 50;
setRemoveTable(Table.RemoveTableEntry.Builder) - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
optional .alluxio.proto.journal.RemoveTableEntry remove_table = 50;
setRemoveTransformJobInfo(Table.RemoveTransformJobInfoEntry) - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
optional .alluxio.proto.journal.RemoveTransformJobInfoEntry remove_transform_job_info = 47;
setRemoveTransformJobInfo(Table.RemoveTransformJobInfoEntry.Builder) - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
optional .alluxio.proto.journal.RemoveTransformJobInfoEntry remove_transform_job_info = 47;
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.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.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.BlockStoreLocationProto.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.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.Command.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.CommitBlockInUfsPOptions.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.CommitBlockInUfsPRequest.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.CommitBlockInUfsPResponse.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.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.CreateLocalBlockRequest.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.CreateLocalBlockResponse.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.ExistsPOptions.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.FileBlockInfo.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.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.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.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.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.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.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.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.GetServiceVersionPRequest.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.GetServiceVersionPResponse.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.GetSyncPathListPRequest.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.GetSyncPathListPResponse.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.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.JobServiceSummary.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.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.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.LoadMetadataPOptions.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.LocalityTier.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.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.NetAddress.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.OpenFilePOptions.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.OpenLocalBlockRequest.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.OpenLocalBlockResponse.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.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.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.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.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.ReverseResolvePRequest.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.ReverseResolvePResponse.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.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.StartSyncPOptions.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.StartSyncPRequest.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.StartSyncPResponse.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.StatusSummary.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.StopSyncPOptions.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.StopSyncPRequest.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.StopSyncPResponse.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.StorageList.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.SyncPointInfo.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.TieredIdentity.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.TierList.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.TransportMessage.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.UfsInfo.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.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.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.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.CreateUfsBlockOptions.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.OpenUfsBlockOptions.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.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.Journal.JournalEntry.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.Table.AddTableEntry.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.proto.journal.Table.AddTransformJobInfoEntry.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.proto.journal.Table.AttachDbEntry.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.proto.journal.Table.CompleteTransformTableEntry.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.proto.journal.Table.DetachDbEntry.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.proto.journal.Table.RemoveTableEntry.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.proto.journal.Table.RemoveTransformJobInfoEntry.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.proto.journal.Table.UpdateDatabaseInfoEntry.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.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
 
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.
SetReplicationCommand - Class in alluxio.cli.fs.command
Changes the replication level of a file or directory specified by args.
SetReplicationCommand(FileSystemContext) - Constructor for class alluxio.cli.fs.command.SetReplicationCommand
 
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;
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.proxy.s3.S3Error
 
setResource(String) - Method in class alluxio.proxy.s3.S3Error
 
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(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
 
setRootDir(String) - Method in class alluxio.client.file.cache.store.PageStoreOptions
 
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.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
 
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;
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
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;
setSchema(Schema) - Method in class alluxio.proto.journal.Table.AddTableEntry.Builder
optional .alluxio.grpc.table.Schema schema = 4;
setSchema(Schema.Builder) - Method in class alluxio.proto.journal.Table.AddTableEntry.Builder
optional .alluxio.grpc.table.Schema schema = 4;
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
 
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.
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
optional int64 sequence_number = 1;
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(GrpcServerAddress) - Method in class alluxio.grpc.GrpcChannelKey
 
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;
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;
setServiceType(ServiceType) - Method in class alluxio.grpc.GetServiceVersionPRequest.Builder
optional .alluxio.grpc.version.ServiceType serviceType = 1;
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.underfs.UnderFileSystemConfiguration
 
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(String) - Method in class alluxio.proxy.s3.ListBucketResult.Content
 
setSize(long) - Method in class alluxio.proxy.s3.ListPartsResult.Part
 
setSize(Long) - Method in class alluxio.util.UnixMountInfo.Options.Builder
 
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.
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
setSourceHostBytes(ByteString) - Method in class alluxio.grpc.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;
setSpaceToReserve(long) - Method in class alluxio.grpc.CreateLocalBlockRequest.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;
setSrcInode(Inode) - Method in class alluxio.master.file.FileSystemMasterAuditContext
Sets mSrcInode field.
setSrcPath(AlluxioURI) - Method in class alluxio.master.file.FileSystemMasterAuditContext
Sets mSrcPath field.
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.WorkerInfo.Builder
optional int64 startTimeMs = 7;
setStartTimeMs(long) - Method in class alluxio.master.CoreMasterContext.Builder
 
setStartTimeMs(long) - Method in class alluxio.wire.AlluxioJobMasterInfo
 
setStartTimeMs(long) - Method in class alluxio.wire.AlluxioJobWorkerInfo
 
setStartTimeMs(long) - Method in class alluxio.wire.AlluxioMasterInfo
 
setStartTimeMs(long) - Method in class alluxio.wire.AlluxioProxyInfo
 
setStartTimeMs(long) - Method in class alluxio.wire.AlluxioWorkerInfo
 
setStartTimeMs(long) - Method in class alluxio.wire.WorkerInfo
 
setState(String) - Method in class alluxio.grpc.WorkerInfo.Builder
optional string state = 4;
setState(PrimarySelector.State) - Method in class alluxio.master.AbstractPrimarySelector
 
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.WorkerInfo.Builder
optional string state = 4;
setStateLockSleepDurationMs(long) - Method in class alluxio.grpc.BackupPOptions.Builder
optional int64 stateLockSleepDurationMs = 5;
setStateLockTimeoutMs(long) - Method in class alluxio.grpc.BackupPOptions.Builder
optional int64 stateLockTimeoutMs = 6;
setStateLockTryDurationMs(long) - Method in class alluxio.grpc.BackupPOptions.Builder
optional int64 stateLockTryDurationMs = 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(ConfigStatus) - Method in class alluxio.grpc.ConfigCheckReport.Builder
optional .alluxio.grpc.meta.ConfigStatus status = 3;
setStatus(Status) - Method in class alluxio.grpc.JobInfo.Builder
optional .alluxio.grpc.job.Status status = 4;
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;
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.ListBucketResult.Content
 
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;
setStorageLevel(RaftJournalConfiguration.StorageLevel) - Method in class alluxio.master.journal.raft.RaftJournalConfiguration
 
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
setStringStats(StringColumnStatsData) - Method in class alluxio.grpc.table.ColumnStatisticsData.Builder
optional .alluxio.grpc.table.StringColumnStatsData string_stats = 4;
setStringStats(StringColumnStatsData.Builder) - Method in class alluxio.grpc.table.ColumnStatisticsData.Builder
optional .alluxio.grpc.table.StringColumnStatsData string_stats = 4;
setStringType(String) - Method in class alluxio.grpc.table.Value.Builder
optional string string_type = 3;
setStringTypeBytes(ByteString) - Method in class alluxio.grpc.table.Value.Builder
optional 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;
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
 
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;
setSyncPaths(int, SyncPointInfo) - Method in class alluxio.grpc.GetSyncPathListPResponse.Builder
repeated .alluxio.grpc.file.SyncPointInfo syncPaths = 1;
setSyncPaths(int, SyncPointInfo.Builder) - Method in class alluxio.grpc.GetSyncPathListPResponse.Builder
repeated .alluxio.grpc.file.SyncPointInfo syncPaths = 1;
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;
setSyncPointUri(String) - Method in class alluxio.grpc.SyncPointInfo.Builder
optional string syncPointUri = 1;
setSyncPointUriBytes(ByteString) - Method in class alluxio.grpc.SyncPointInfo.Builder
optional string syncPointUri = 1;
setSyncStatus(SyncPointStatus) - Method in class alluxio.grpc.SyncPointInfo.Builder
optional .alluxio.grpc.file.SyncPointStatus syncStatus = 2;
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;
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;
setTableName(String) - Method in class alluxio.proto.journal.Table.AddTableEntry.Builder
optional string table_name = 2;
setTableName(String) - Method in class alluxio.proto.journal.Table.AddTransformJobInfoEntry.Builder
optional string table_name = 2;
setTableName(String) - Method in class alluxio.proto.journal.Table.CompleteTransformTableEntry.Builder
optional string table_name = 2;
setTableName(String) - Method in class alluxio.proto.journal.Table.RemoveTableEntry.Builder
optional string table_name = 2;
setTableName(String) - Method in class alluxio.proto.journal.Table.RemoveTransformJobInfoEntry.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;
setTableNameBytes(ByteString) - Method in class alluxio.proto.journal.Table.AddTableEntry.Builder
optional string table_name = 2;
setTableNameBytes(ByteString) - Method in class alluxio.proto.journal.Table.AddTransformJobInfoEntry.Builder
optional string table_name = 2;
setTableNameBytes(ByteString) - Method in class alluxio.proto.journal.Table.CompleteTransformTableEntry.Builder
optional string table_name = 2;
setTableNameBytes(ByteString) - Method in class alluxio.proto.journal.Table.RemoveTableEntry.Builder
optional string table_name = 2;
setTableNameBytes(ByteString) - Method in class alluxio.proto.journal.Table.RemoveTransformJobInfoEntry.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;
setTableStats(int, ColumnStatisticsInfo) - Method in class alluxio.proto.journal.Table.AddTableEntry.Builder
repeated .alluxio.grpc.table.ColumnStatisticsInfo table_stats = 6;
setTableStats(int, ColumnStatisticsInfo.Builder) - Method in class alluxio.proto.journal.Table.AddTableEntry.Builder
repeated .alluxio.grpc.table.ColumnStatisticsInfo table_stats = 6;
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;
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
 
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;
setTier(int) - Method in class alluxio.grpc.CreateLocalBlockRequest.Builder
optional int32 tier = 3;
setTier(int) - Method in class alluxio.grpc.WriteRequestCommand.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
 
setTieredIdentity(TieredIdentity) - Method in class alluxio.grpc.WorkerNetAddress.Builder
optional .alluxio.grpc.TieredIdentity tieredIdentity = 6;
setTieredIdentity(TieredIdentity.Builder) - Method in class alluxio.grpc.WorkerNetAddress.Builder
optional .alluxio.grpc.TieredIdentity tieredIdentity = 6;
setTieredIdentity(TieredIdentity) - Method in class alluxio.wire.WorkerNetAddress
 
setTierName(String) - Method in class alluxio.grpc.LocalityTier.Builder
optional string tierName = 1;
setTierNameBytes(ByteString) - Method in class alluxio.grpc.LocalityTier.Builder
optional string tierName = 1;
setTierPaths(Map<String, List<String>>) - Method in class alluxio.wire.AlluxioWorkerInfo
 
setTiers(int, LocalityTier) - Method in class alluxio.grpc.TieredIdentity.Builder
repeated .alluxio.grpc.LocalityTier tiers = 1;
setTiers(int, LocalityTier.Builder) - Method in class alluxio.grpc.TieredIdentity.Builder
repeated .alluxio.grpc.LocalityTier tiers = 1;
setTiers(int, long) - Method in class alluxio.grpc.TierList.Builder
repeated int64 tiers = 1;
setTimeoutMs(int) - Method in class alluxio.util.WaitForOptions
 
setTimeSeriesMetrics(List<TimeSeries>) - Method in class alluxio.wire.MasterWebUIMetrics
 
setTotal(long) - Method in class alluxio.wire.Capacity
 
setTotalBytesReadDomainSocket(String) - Method in class alluxio.wire.MasterWebUIMetrics
Sets total bytes read from domain socket.
setTotalBytesReadDomainSocketThroughput(String) - Method in class alluxio.wire.MasterWebUIMetrics
Sets total bytes read domain socket throughput.
setTotalBytesReadLocal(String) - Method in class alluxio.wire.MasterWebUIMetrics
Sets total bytes read local.
setTotalBytesReadLocalThroughput(String) - Method in class alluxio.wire.MasterWebUIMetrics
Sets total bytes read local throughput.
setTotalBytesReadRemote(String) - Method in class alluxio.wire.MasterWebUIMetrics
Sets total bytes read remote.
setTotalBytesReadRemoteThroughput(String) - Method in class alluxio.wire.MasterWebUIMetrics
Sets total bytes read remote throughput.
setTotalBytesReadUfs(String) - Method in class alluxio.wire.MasterWebUIMetrics
Sets total bytes read ufs.
setTotalBytesReadUfsThroughput(String) - Method in class alluxio.wire.MasterWebUIMetrics
Sets total bytes read ufs throughput.
setTotalBytesWrittenAlluxio(String) - Method in class alluxio.wire.MasterWebUIMetrics
Sets total bytes written alluxio.
setTotalBytesWrittenAlluxioThroughput(String) - Method in class alluxio.wire.MasterWebUIMetrics
Sets total bytes written alluxio throughput.
setTotalBytesWrittenDomainSocket(String) - Method in class alluxio.wire.MasterWebUIMetrics
Sets total bytes written through domain socket.
setTotalBytesWrittenDomainSocketThroughput(String) - Method in class alluxio.wire.MasterWebUIMetrics
Sets total bytes written domain socket throughput.
setTotalBytesWrittenLocal(String) - Method in class alluxio.wire.MasterWebUIMetrics
Sets total bytes written local.
setTotalBytesWrittenLocalThroughput(String) - Method in class alluxio.wire.MasterWebUIMetrics
Sets total bytes written local throughput.
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.
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.
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
 
SetTtlCommand - Class in alluxio.cli.fs.command
Sets a new TTL value for the file at path both of the TTL value and the path are specified by args.
SetTtlCommand(FileSystemContext) - Constructor for class alluxio.cli.fs.command.SetTtlCommand
 
setTxId(long, long) - Method in class alluxio.master.file.activesync.ActiveSyncManager
Set the transaction id for a particular mountId.
setTxId(long) - Method in class alluxio.proto.journal.File.ActiveSyncTxIdEntry.Builder
optional int64 tx_id = 2;
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(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.table.FieldSchema.Builder
optional string type = 3;
setUdbConnectionUri(String) - Method in class alluxio.grpc.table.AttachDatabasePRequest.Builder
optional string udb_connection_uri = 2;
setUdbConnectionUri(String) - Method in class alluxio.proto.journal.Table.AttachDbEntry.Builder
optional string udb_connection_uri = 2;
setUdbConnectionUriBytes(ByteString) - Method in class alluxio.grpc.table.AttachDatabasePRequest.Builder
optional string udb_connection_uri = 2;
setUdbConnectionUriBytes(ByteString) - Method in class alluxio.proto.journal.Table.AttachDbEntry.Builder
optional string udb_connection_uri = 2;
setUdbDbName(String) - Method in class alluxio.grpc.table.AttachDatabasePRequest.Builder
optional string udb_db_name = 3;
setUdbDbName(String) - Method in class alluxio.proto.journal.Table.AttachDbEntry.Builder
optional string udb_db_name = 3;
setUdbDbNameBytes(ByteString) - Method in class alluxio.grpc.table.AttachDatabasePRequest.Builder
optional string udb_db_name = 3;
setUdbDbNameBytes(ByteString) - Method in class alluxio.proto.journal.Table.AttachDbEntry.Builder
optional string udb_db_name = 3;
setUdbType(String) - Method in class alluxio.grpc.table.AttachDatabasePRequest.Builder
optional string udb_type = 1;
setUdbType(String) - Method in class alluxio.proto.journal.Table.AttachDbEntry.Builder
optional string udb_type = 1;
setUdbTypeBytes(ByteString) - Method in class alluxio.grpc.table.AttachDatabasePRequest.Builder
optional string udb_type = 1;
setUdbTypeBytes(ByteString) - Method in class alluxio.proto.journal.Table.AttachDbEntry.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
 
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;
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.
setUfsPath(String) - Method in class alluxio.client.file.options.OutStreamOptions
 
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
 
setUfsPath(String) - Method in class alluxio.worker.grpc.BlockWriteRequestContext
 
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;
setUfsReadLocationPolicy(BlockLocationPolicy) - Method in class alluxio.client.file.options.InStreamOptions
Sets block read location policy.
setUfsReadSize(Map<String, String>) - Method in class alluxio.wire.MasterWebUIMetrics
Sets ufs read size.
setUfsResource(CloseableResource<UnderFileSystem>) - Method in class alluxio.worker.grpc.BlockWriteRequestContext
 
setUfsResource(CloseableResource<UnderFileSystem>) - Method in class alluxio.worker.grpc.UfsFileWriteRequestContext
 
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.MountPointInfo.Builder
optional string ufsType = 2;
setUfsType(String) - Method in class alluxio.wire.MountPointInfo
 
setUfsTypeBytes(ByteString) - Method in class alluxio.grpc.MountPointInfo.Builder
optional string ufsType = 2;
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.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.
setUnchecked(boolean) - Method in class alluxio.grpc.DeletePOptions.Builder
optional bool unchecked = 3;
setUnfinishedTasks(int) - Method in class alluxio.grpc.JobWorkerHealth.Builder
optional int32 unfinishedTasks = 7;
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.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.BlockStoreLocationProto.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.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.Command.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.CommitBlockInUfsPOptions.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.CommitBlockInUfsPRequest.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.CommitBlockInUfsPResponse.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.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.CreateLocalBlockRequest.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.CreateLocalBlockResponse.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.ExistsPOptions.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.FileBlockInfo.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.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.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.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.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.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.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.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.GetServiceVersionPRequest.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.GetServiceVersionPResponse.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.GetSyncPathListPRequest.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.GetSyncPathListPResponse.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.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.JobServiceSummary.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.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.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.LoadMetadataPOptions.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.LocalityTier.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.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.NetAddress.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.OpenFilePOptions.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.OpenLocalBlockRequest.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.OpenLocalBlockResponse.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.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.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.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.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.ReverseResolvePRequest.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.ReverseResolvePResponse.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.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.StartSyncPOptions.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.StartSyncPRequest.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.StartSyncPResponse.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.StatusSummary.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.StopSyncPOptions.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.StopSyncPRequest.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.StopSyncPResponse.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.StorageList.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.SyncPointInfo.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.TieredIdentity.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.TierList.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.TransportMessage.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.UfsInfo.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.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.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.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.CreateUfsBlockOptions.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class alluxio.proto.dataserver.Protocol.CreateUfsFileOptions.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class alluxio.proto.dataserver.Protocol.OpenUfsBlockOptions.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class alluxio.proto.dataserver.Protocol.Response.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.Journal.JournalEntry.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.Table.AddTableEntry.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class alluxio.proto.journal.Table.AddTransformJobInfoEntry.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class alluxio.proto.journal.Table.AttachDbEntry.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class alluxio.proto.journal.Table.CompleteTransformTableEntry.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class alluxio.proto.journal.Table.DetachDbEntry.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class alluxio.proto.journal.Table.RemoveTableEntry.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class alluxio.proto.journal.Table.RemoveTransformJobInfoEntry.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class alluxio.proto.journal.Table.UpdateDatabaseInfoEntry.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.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
setUpdateDatabaseInfo(Table.UpdateDatabaseInfoEntry) - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
optional .alluxio.proto.journal.UpdateDatabaseInfoEntry update_database_info = 49;
setUpdateDatabaseInfo(Table.UpdateDatabaseInfoEntry.Builder) - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
optional .alluxio.proto.journal.UpdateDatabaseInfoEntry update_database_info = 49;
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;
setUploadId(String) - Method in class alluxio.proxy.s3.InitiateMultipartUploadResult
 
setUploadId(String) - Method in class alluxio.proxy.s3.ListPartsResult
 
setupTest() - Method in class alluxio.master.AbstractLocalAlluxioCluster
Sets up corresponding directories for tests.
setUptime(String) - Method in class alluxio.wire.MasterWebUIOverview
Sets uptime.
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
 
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.
setUser(String) - Method in class alluxio.proto.dataserver.Protocol.OpenUfsBlockOptions.Builder
The client does not need to set this.
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;
setUserBytes(ByteString) - Method in class alluxio.proto.dataserver.Protocol.OpenUfsBlockOptions.Builder
The client does not need to set this.
setUserState(UserState) - Method in class alluxio.master.CoreMasterContext.Builder
 
setValue(String) - Method in class alluxio.grpc.ConfigProperty.Builder
optional string value = 3;
setValue(String) - Method in class alluxio.grpc.LocalityTier.Builder
optional string value = 2;
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;
setValueBytes(ByteString) - Method in class alluxio.grpc.ConfigProperty.Builder
optional string value = 3;
setValueBytes(ByteString) - Method in class alluxio.grpc.LocalityTier.Builder
optional string value = 2;
setValueBytes(ByteString) - Method in class alluxio.proto.journal.File.StringPairEntry.Builder
optional string value = 2;
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
 
setVersion(long) - Method in class alluxio.grpc.GetServiceVersionPResponse.Builder
optional int64 version = 1;
setVersion(String) - Method in class alluxio.grpc.MasterInfo.Builder
optional string version = 7;
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(long) - Method in class alluxio.proto.journal.Table.AddTableEntry.Builder
optional int64 version = 11;
setVersion(long) - Method in class alluxio.proto.journal.Table.RemoveTableEntry.Builder
optional int64 version = 4;
setVersion(String) - Method in class alluxio.wire.AlluxioJobMasterInfo
 
setVersion(String) - Method in class alluxio.wire.AlluxioJobWorkerInfo
 
setVersion(String) - Method in class alluxio.wire.AlluxioMasterInfo
 
setVersion(String) - Method in class alluxio.wire.AlluxioProxyInfo
 
setVersion(String) - Method in class alluxio.wire.AlluxioWorkerInfo
 
setVersion(String) - Method in class alluxio.wire.MasterWebUIOverview
Sets version.
setVersion(String) - Method in class alluxio.wire.WorkerWebUIOverview
Sets version.
setVersionBytes(ByteString) - Method in class alluxio.grpc.MasterInfo.Builder
optional string version = 7;
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;
setVersionCreationTime(long) - Method in class alluxio.proto.journal.Table.AddTableEntry.Builder
optional int64 version_creation_time = 12;
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.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
 
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.
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;
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.
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;
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.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.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;
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.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
 
setWorkingDirectory(Path) - Method in class alluxio.hadoop.AbstractFileSystem
 
setWorkingDirectory(Path) - Method in class alluxio.hadoop.LocalCacheFileSystem
 
setWriteBufferSize(int) - Method in class alluxio.client.file.cache.store.RocksPageStoreOptions
 
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.CreateDirectoryPOptions.Builder
optional .alluxio.grpc.file.WritePType writeType = 4;
setWriteType(WritePType) - Method in class alluxio.grpc.CreateFilePOptions.Builder
optional .alluxio.grpc.file.WritePType writeType = 8;
setWriteType(WriteType) - Method in class alluxio.master.file.contexts.CreatePathContext
 
setWritingToLocal(boolean) - Method in class alluxio.worker.grpc.BlockWriteRequestContext
 
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[]>) - Method in class alluxio.wire.FileInfo
 
setZookeeperAddresses(int, String) - Method in class alluxio.grpc.MasterInfo.Builder
Empty means zookeeper is not enabled
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
 
SHARED_OPTION - Static variable in class alluxio.table.common.udb.UdbConfiguration
 
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_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
 
shouldCommit(TableWriter) - Method in class alluxio.job.plan.transform.format.tables.BytesCommitter
 
shouldCommit(TableWriter) - Method in interface alluxio.job.plan.transform.format.tables.Committer
 
shouldCommit(TableWriter) - Method in class alluxio.job.plan.transform.format.tables.RowsCommitter
 
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<T>.ResourceInternal<T>) - Method in class alluxio.resource.DynamicResourcePool
 
shouldGc(DynamicResourcePool<IMetaStoreClient>.ResourceInternal<IMetaStoreClient>) - Method in class alluxio.table.under.hive.util.HiveClientPool
 
shouldSkip() - Method in class alluxio.cli.validation.HdfsValidationTask
 
shouldSkip() - Method in class alluxio.cli.validation.SecureHdfsValidationTask
 
shouldSkipCache() - Method in class alluxio.master.metastore.ReadOption
 
shouldSync() - Method in class alluxio.master.file.meta.LockingScheme
 
shouldSync(UdbTable) - Method in class alluxio.master.table.Table
 
shouldSyncPath(String, long, boolean) - Method in class alluxio.master.file.meta.UfsSyncPathCache
The logic of shouldSyncPath need to consider the difference between file and directory, with the variable isGetFileInfo we just process getFileInfo specially.
shouldUseDisplayValue() - Method in class alluxio.conf.ConfigurationValueOptions
 
shouldUseRawValue() - Method in class alluxio.conf.ConfigurationValueOptions
 
ShowCommand - Class in alluxio.cli.fsadmin.pathconf
Show path level configurations.
ShowCommand(Context, AlluxioConfiguration) - Constructor for class alluxio.cli.fsadmin.pathconf.ShowCommand
 
shutdown() - Method in class alluxio.concurrent.jsr.ForkJoinPool
Possibly initiates an orderly shutdown in which previously submitted tasks are executed, but no new tasks will be accepted.
shutdown() - Method in class alluxio.grpc.GrpcChannel
Shuts down the channel.
shutdown() - Method in class alluxio.grpc.GrpcServer
Shuts down the server.
shutdown() - Method in class alluxio.util.executor.ControllableScheduler
 
shutDown() - Method in class alluxio.worker.block.AsyncBlockRemover
Shutdown async block remover.
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.util.executor.ControllableScheduler
 
signalLosePrimacy() - Method in class alluxio.master.journal.ufs.UfsJournal
Notifies this journal that it is no longer primary.
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
SimpleInodeLockList - Class in alluxio.master.file.meta
A simple inode lock list.
SimpleInodeLockList(InodeLockManager) - Constructor for class alluxio.master.file.meta.SimpleInodeLockList
Creates a new empty lock list.
SimpleUserState - Class in alluxio.security.user
UserState implementation for the simple authentication schemes.
SimpleUserState.Factory - Class in alluxio.security.user
Factory class to create the user state.
SINGLE_MASTER_AUTH - Static variable in interface alluxio.uri.Authority
 
singleElementIterator(T) - Static method in class alluxio.util.CommonUtils
Returns an iterator that iterates on a single element.
SingleMasterAuthority - Class in alluxio.uri
A single master authority implementation.
SingleMasterAuthority(String, int) - Constructor for class alluxio.uri.SingleMasterAuthority
 
SingleMasterConnectDetails(InetSocketAddress) - Constructor for class alluxio.master.SingleMasterInquireClient.SingleMasterConnectDetails
 
SingleMasterInquireClient - Class in alluxio.master
A MasterInquireClient which always returns a fixed master address.
SingleMasterInquireClient(InetSocketAddress) - Constructor for class alluxio.master.SingleMasterInquireClient
 
SingleMasterInquireClient.SingleMasterConnectDetails - Class in alluxio.master
Connect details for a single master inquire client.
SingleTagValueAggregator - Class in alluxio.metrics.aggregator
An aggregator that aggregates the metrics into multiple values based on a single tag of the metric.
SingleTagValueAggregator(String, String, String) - Constructor for class alluxio.metrics.aggregator.SingleTagValueAggregator
Constructs a new instance of SingleTagValueAggregator.
SingleValueAggregator - Interface in alluxio.metrics
Interface for the aggregator that aggregates into a single value from the metrics of different hosts.
Sink - Interface in alluxio.metrics.sink
Sink consumes the records generated by the metrics source.
SINK_REGEX - Static variable in class alluxio.metrics.MetricsSystem
 
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 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.master.file.meta.LockedInodePath
 
size() - Method in class alluxio.resource.DynamicResourcePool
 
size() - Method in interface alluxio.resource.Pool
 
size() - Method in class alluxio.resource.ResourcePool
 
size() - Method in class alluxio.StorageTierAssoc
 
size() - Method in class alluxio.StreamCache
 
SKEWED_FIELD_NUMBER - Static variable in class alluxio.grpc.table.layout.hive.Storage
 
skip(long) - Method in class alluxio.client.block.stream.BlockInStream
 
skip(long) - Method in class alluxio.client.file.AlluxioFileInStream
 
skip(long) - Method in class alluxio.client.file.cache.LocalCacheFileInStream
 
skip(long) - Method in class alluxio.hadoop.AlluxioHdfsInputStream
 
skip(long) - Method in class alluxio.hadoop.HdfsFileInputStream
 
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.hdfs.HdfsPositionedUnderFileInputStream
 
skip(long) - Method in class alluxio.underfs.MultiRangeObjectInputStream
 
skip(long) - Method in class alluxio.underfs.s3a.S3AInputStream
 
sleep(Duration) - Method in interface alluxio.time.Sleeper
Sleeps for the given duration.
sleep(Duration) - Method in class alluxio.time.ThreadSleeper
 
Sleeper - Interface in alluxio.time
An interface for a utility which provides a sleep method.
SLEEPING_TIMER_CLASS - Static variable in class alluxio.heartbeat.HeartbeatContext
 
SleepingRetry - Class in alluxio.retry
A retry policy that uses thread sleeping for the delay.
SleepingRetry(int) - Constructor for class alluxio.retry.SleepingRetry
 
SleepingTimer - Class in alluxio.heartbeat
This class can be used for executing heartbeats periodically.
SleepingTimer(String, long) - Constructor for class alluxio.heartbeat.SleepingTimer
Creates a new instance of SleepingTimer.
SleepingTimer(String, long, Logger, Clock, Sleeper) - Constructor for class alluxio.heartbeat.SleepingTimer
Creates a new instance of SleepingTimer.
sleepMs(long) - Static method in class alluxio.util.CommonUtils
Sleeps for the given number of milliseconds.
sleepMs(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.
SMALLINT - Static variable in class alluxio.job.plan.transform.HiveConstants.Types
Hive small int type.
snapshot(SnapshotWriter) - Method in class alluxio.master.journal.raft.JournalStateMachine
 
snapshot() - Method in class alluxio.master.meta.PathProperties
 
SnapshotReaderStream - Class in alluxio.master.journal.raft
An input stream for reading from a SnapshotReader.
SnapshotReaderStream(SnapshotReader) - Constructor for class alluxio.master.journal.raft.SnapshotReaderStream
 
SnapshotWriterStream - Class in alluxio.master.journal.raft
A wrapper for giving an OutputStream API on top of Copycat's SnapshotWriter.
SnapshotWriterStream(SnapshotWriter) - Constructor for class alluxio.master.journal.raft.SnapshotWriterStream
 
SORTED_BY_FIELD_NUMBER - Static variable in class alluxio.grpc.table.layout.hive.HiveBucketProperty
 
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_PORT_FIELD_NUMBER - Static variable in class alluxio.grpc.AsyncCacheRequest
 
SPACE_TO_RESERVE_FIELD_NUMBER - Static variable in class alluxio.grpc.CreateLocalBlockRequest
 
SpaceReserver - Class in alluxio.worker.block
The SpaceReserver periodically checks the available space on each storage tier.
SpaceReserver(BlockWorker) - Constructor for class alluxio.worker.block.SpaceReserver
Creates a new instance of SpaceReserver.
SparkIntegrationChecker - Class in alluxio.checker
The Spark integration checker includes a Spark job to test the integration of Spark with Alluxio.
SparkIntegrationChecker() - Constructor for class alluxio.checker.SparkIntegrationChecker
 
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
 
SpecificHostPolicy - Class in alluxio.client.block.policy
Always returns a worker with the specified hostname.
SpecificHostPolicy(AlluxioConfiguration) - Constructor for class alluxio.client.block.policy.SpecificHostPolicy
Constructs a new SpecificHostPolicy.
SpecificHostPolicy(String) - Constructor for class alluxio.client.block.policy.SpecificHostPolicy
Constructs the policy with the hostname.
SpecificPathConfiguration - Class in alluxio.conf.path
Configuration for a specific Alluxio path.
SpecificPathConfiguration(AlluxioConfiguration, PathConfiguration, AlluxioURI) - Constructor for class alluxio.conf.path.SpecificPathConfiguration
Constructs a new instance with the specified references without copying the underlying properties.
SPECIFIED_OPTION_NAME - Static variable in class alluxio.cli.fsadmin.command.ReportCommand
 
SPECIFIED_VALUE - Static variable in enum alluxio.grpc.WorkerRange
SPECIFIED = 4;
spliterator() - Method in class alluxio.collections.DelegatingSet
 
SshCommand - Class in alluxio.shell
Object representation of a remote shell command by SSH.
SshCommand(String, String[]) - Constructor for class alluxio.shell.SshCommand
Creates a SshCommand instance from the remote hostname and command.
sshExecCommandWithOutput(String, String...) - Static method in class alluxio.util.ShellUtils
Static method to execute a shell command remotely via ssh.
SshValidationTask - Class in alluxio.cli.validation
Task for validating SSH reachability.
SshValidationTask(String) - Constructor for class alluxio.cli.validation.SshValidationTask
Creates a new instance of SshValidationTask.
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.
start() - Method in class alluxio.grpc.GrpcServer
Start serving.
start() - Method in class alluxio.logserver.AlluxioLogServerProcess
Starts the Alluxio process.
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.AlluxioJobMasterProcess
Starts the Alluxio job master server.
start() - Method in class alluxio.master.AlluxioMasterProcess
 
start() - Method in class alluxio.master.AlluxioSecondaryMaster
 
start() - Method in class alluxio.master.audit.AsyncUserAccessAuditLogWriter
start(Boolean) - Method in class alluxio.master.block.DefaultBlockMaster
 
start() - Method in class alluxio.master.file.activesync.ActiveSyncManager
Start the polling threads.
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 class alluxio.master.journal.AsyncJournalWriter
 
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 secondary mode.
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(InetSocketAddress) - Method in class alluxio.master.PrimarySelectorClient
Starts the leader selection.
start(Boolean) - Method in class alluxio.master.table.DefaultTableMaster
 
start(ExecutorService, UserState) - Method in class alluxio.master.table.transform.TransformManager
Starts background heartbeats.
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.ExternalProcess
Starts the process.
start() - Method in class alluxio.multi.process.Master
Launches the master 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.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.block.DefaultBlockWorker
Runs the block worker.
start(WorkerNetAddress) - Method in class alluxio.worker.JobWorker
 
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;
startActiveSyncPolling(long) - Method in class alluxio.concurrent.ManagedBlockingUfsForwarder
 
startActiveSyncPolling(long) - Method in class alluxio.underfs.BaseUnderFileSystem
 
startActiveSyncPolling(long) - Method in class alluxio.underfs.hdfs.HdfsUnderFileSystem
 
startActiveSyncPolling(long) - Method in interface alluxio.underfs.UnderFileSystem
Start Active Sync.
startActiveSyncPolling(long) - Method in class alluxio.underfs.UnderFileSystemWithLogging
 
startAuthenticatedChannel(long) - Method in class alluxio.security.authentication.AuthenticatedChannelClientDriver
Starts authentication with the server and wait until completion.
startInternal() - Method in class alluxio.master.journal.AbstractJournalSystem
Starts the journal system.
startInternal() - Method in class alluxio.master.journal.raft.RaftJournalSystem
 
startInternal() - Method in class alluxio.master.journal.ufs.UfsJournalSystem
 
startJvmMonitorProcess() - Method in class alluxio.master.AlluxioMasterProcess
Starts jvm monitor process, to monitor jvm.
startMaster(boolean) - Method in class alluxio.master.AlluxioJobMasterProcess
 
startMaster(int) - Method in class alluxio.multi.process.MultiProcessCluster
Starts the specified master.
startMasters() - Method in class alluxio.master.AbstractLocalAlluxioCluster
Configures and starts the master(s).
startMasters(boolean) - Method in class alluxio.master.AlluxioMasterProcess
Starts all masters, including block master, FileSystem master, and additional masters.
startMasters() - Method in class alluxio.master.LocalAlluxioCluster
 
startMasters() - Method in class alluxio.master.MultiMasterLocalAlluxioCluster
 
startMasters() - Method in class alluxio.multi.process.MultiProcessCluster
Starts all masters.
startPolling(long) - Method in class alluxio.underfs.hdfs.activesync.SupportedHdfsActiveSyncProvider
 
startPolling(long) - Method in interface alluxio.underfs.hdfs.HdfsActiveSyncProvider
start polling thread.
startPolling(long) - Method in class alluxio.underfs.hdfs.NoopHdfsActiveSyncProvider
 
startRejectingServers() - Method in class alluxio.master.MasterProcess
 
startServing(String, String) - Method in class alluxio.master.AlluxioJobMasterProcess
 
startServing(String, String) - Method in class alluxio.master.AlluxioMasterProcess
Starts serving, letting MetricsSystem start sink and starting the web ui server and RPC Server.
startServing() - Method in class alluxio.master.MasterProcess
 
startServingRPCServer() - Method in class alluxio.master.AlluxioJobMasterProcess
Starts the gRPC server.
startServingRPCServer() - Method in class alluxio.master.AlluxioMasterProcess
Starts the gRPC server.
startServingWebServer() - Method in class alluxio.master.AlluxioJobMasterProcess
 
startServingWebServer() - Method in class alluxio.master.AlluxioMasterProcess
Starts serving web ui server, resetting master web port, adding the metrics servlet to the web server and starting web ui.
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.
startSync(AlluxioURI) - Method in class alluxio.client.file.BaseFileSystem
Starts the active syncing process on an Alluxio path.
startSync(AlluxioURI) - Method in class alluxio.client.file.DelegatingFileSystem
 
startSync(AlluxioURI) - Method in interface alluxio.client.file.FileSystem
Starts the active syncing process on an Alluxio path.
startSync(AlluxioURI) - Method in class alluxio.client.file.FileSystemCache.InstanceCachingFileSystem
 
startSync(AlluxioURI) - Method in interface alluxio.client.file.FileSystemMasterClient
Start the active syncing process for a specified path.
startSync(AlluxioURI) - Method in class alluxio.client.file.RetryHandlingFileSystemMasterClient
 
startSync(AlluxioURI) - Method in class alluxio.concurrent.ManagedBlockingUfsForwarder
 
startSync(StartSyncPRequest) - Method in class alluxio.grpc.FileSystemMasterClientServiceGrpc.FileSystemMasterClientServiceBlockingStub
Start the active syncing of the directory or file
startSync(StartSyncPRequest) - Method in class alluxio.grpc.FileSystemMasterClientServiceGrpc.FileSystemMasterClientServiceFutureStub
Start the active syncing of the directory or file
startSync(StartSyncPRequest, StreamObserver<StartSyncPResponse>) - Method in class alluxio.grpc.FileSystemMasterClientServiceGrpc.FileSystemMasterClientServiceImplBase
Start the active syncing of the directory or file
startSync(StartSyncPRequest, StreamObserver<StartSyncPResponse>) - Method in class alluxio.grpc.FileSystemMasterClientServiceGrpc.FileSystemMasterClientServiceStub
Start the active syncing of the directory or file
startSync(AlluxioURI) - Method in class alluxio.hadoop.AlluxioHdfsFileSystem
 
startSync(AlluxioURI) - Method in class alluxio.master.file.DefaultFileSystemMaster
 
startSync(AlluxioURI) - Method in interface alluxio.master.file.FileSystemMaster
starts active sync on a specified alluxioURI.
startSync(StartSyncPRequest, StreamObserver<StartSyncPResponse>) - Method in class alluxio.master.file.FileSystemMasterClientServiceHandler
 
startSync(AlluxioURI) - Method in class alluxio.underfs.BaseUnderFileSystem
 
startSync(AlluxioURI) - Method in class alluxio.underfs.hdfs.activesync.SupportedHdfsActiveSyncProvider
startSync on a ufs uri.
startSync(AlluxioURI) - Method in interface alluxio.underfs.hdfs.HdfsActiveSyncProvider
start syncing on a ufs uri.
startSync(AlluxioURI) - Method in class alluxio.underfs.hdfs.HdfsUnderFileSystem
 
startSync(AlluxioURI) - Method in class alluxio.underfs.hdfs.NoopHdfsActiveSyncProvider
 
startSync(AlluxioURI) - Method in interface alluxio.underfs.UnderFileSystem
Add Sync Point.
startSync(AlluxioURI) - Method in class alluxio.underfs.UnderFileSystemWithLogging
 
startSyncAndJournal(RpcContext, AlluxioURI) - Method in class alluxio.master.file.activesync.ActiveSyncManager
Start active sync on a URI and journal the add entry.
StartSyncCommand - Class in alluxio.cli.fs.command
Start a polling sync of a particular path.
StartSyncCommand(FileSystemContext) - Constructor for class alluxio.cli.fs.command.StartSyncCommand
 
StartSyncPOptions - Class in alluxio.grpc
Protobuf type alluxio.grpc.file.StartSyncPOptions
StartSyncPOptions.Builder - Class in alluxio.grpc
Protobuf type alluxio.grpc.file.StartSyncPOptions
StartSyncPOptionsOrBuilder - Interface in alluxio.grpc
 
StartSyncPRequest - Class in alluxio.grpc
Protobuf type alluxio.grpc.file.StartSyncPRequest
StartSyncPRequest.Builder - Class in alluxio.grpc
Protobuf type alluxio.grpc.file.StartSyncPRequest
StartSyncPRequestOrBuilder - Interface in alluxio.grpc
 
StartSyncPResponse - Class in alluxio.grpc
Protobuf type alluxio.grpc.file.StartSyncPResponse
StartSyncPResponse.Builder - Class in alluxio.grpc
Protobuf type alluxio.grpc.file.StartSyncPResponse
StartSyncPResponseOrBuilder - Interface in alluxio.grpc
 
STARTTIMEMS_FIELD_NUMBER - Static variable in class alluxio.grpc.MasterInfo
 
STARTTIMEMS_FIELD_NUMBER - Static variable in class alluxio.grpc.WorkerInfo
 
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.MultiMasterLocalAlluxioCluster
 
StatCommand - Class in alluxio.cli.fs.command
Displays the path's info.
StatCommand(FileSystemContext) - Constructor for class alluxio.cli.fs.command.StatCommand
 
StatCommand - Class in alluxio.cli.job.command
Displays the status of the job.
StatCommand(FileSystemContext) - Constructor for class alluxio.cli.job.command.StatCommand
Creates the job stat command.
State(MountInfo) - Constructor for class alluxio.master.file.meta.MountTable.State
 
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.WorkerInfo
 
STATE_VALUE - Static variable in enum alluxio.grpc.WorkerInfoField
STATE = 7;
stateChanged(CuratorFramework, ConnectionState) - Method in class alluxio.master.PrimarySelectorClient
 
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
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(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.
StateLockOptions.GraceMode - Enum in alluxio.master
Defines the grace mode of exclusive locking of the state-lock.
STATELOCKSLEEPDURATIONMS_FIELD_NUMBER - Static variable in class alluxio.grpc.BackupPOptions
 
STATELOCKTIMEOUTMS_FIELD_NUMBER - Static variable in class alluxio.grpc.BackupPOptions
 
STATELOCKTRYDURATIONMS_FIELD_NUMBER - Static variable in class alluxio.grpc.BackupPOptions
 
statfs(String, Statvfs) - Method in class alluxio.fuse.AlluxioFuseFileSystem
Gets the filesystem statistics.
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.ConfigCheckReport
 
STATUS_FIELD_NUMBER - Static variable in class alluxio.grpc.JobInfo
 
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.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
 
stop(Status, String) - Method in class alluxio.job.workflow.WorkflowExecution
stops future execution.
stop() - Method in class alluxio.logserver.AlluxioLogServerProcess
Stops the Alluxio process, blocking until the action is completed.
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.AlluxioJobMasterProcess
Stops the Alluxio job master server.
stop() - Method in class alluxio.master.AlluxioMasterProcess
 
stop() - Method in class alluxio.master.AlluxioSecondaryMaster
 
stop() - Method in class alluxio.master.audit.AsyncUserAccessAuditLogWriter
stop() - Method in class alluxio.master.block.DefaultBlockMaster
 
stop() - Method in class alluxio.master.file.activesync.ActiveSyncManager
Stops the sync manager and any outstanding threads, does not change the sync points.
stop() - Method in class alluxio.master.file.DefaultFileSystemMaster
 
stop() - Method in class alluxio.master.journal.AbstractJournalSystem
 
stop() - Method in class alluxio.master.journal.AsyncJournalWriter
 
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.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.PrimarySelectorClient
 
stop() - Method in class alluxio.master.table.DefaultTableMaster
 
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.block.DefaultBlockWorker
Stops the block worker.
stop() - Method in class alluxio.worker.JobWorker
 
stopActiveSyncPolling() - Method in class alluxio.concurrent.ManagedBlockingUfsForwarder
 
stopActiveSyncPolling() - Method in class alluxio.underfs.BaseUnderFileSystem
 
stopActiveSyncPolling() - Method in class alluxio.underfs.hdfs.HdfsUnderFileSystem
 
stopActiveSyncPolling() - Method in interface alluxio.underfs.UnderFileSystem
Stop Active Sync.
stopActiveSyncPolling() - Method in class alluxio.underfs.UnderFileSystemWithLogging
 
stopAndJoin() - Method in class alluxio.network.RejectingServer
Stops the server and joins the server thread.
stopFS() - Method in class alluxio.master.AbstractLocalAlluxioCluster
Stops the alluxio filesystem's service thread only.
stopFS() - Method in class alluxio.master.MultiMasterLocalAlluxioCluster
 
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
 
stopLeader() - Method in class alluxio.master.MultiMasterLocalAlluxioCluster
Iterates over the masters in the order of master creation, stops the leader master.
stopMaster() - Method in class alluxio.master.AlluxioJobMasterProcess
 
stopMaster(int) - Method in class alluxio.multi.process.MultiProcessCluster
 
stopMasters() - Method in class alluxio.master.AbstractLocalAlluxioCluster
Stops the masters.
stopMasters() - Method in class alluxio.master.AlluxioMasterProcess
Stops all masters, including block master, fileSystem master and additional masters.
stopMasters() - Method in class alluxio.master.LocalAlluxioCluster
 
stopMasters() - Method in class alluxio.master.MultiMasterLocalAlluxioCluster
 
stopMasters() - Method in class alluxio.multi.process.MultiProcessCluster
Stops all masters.
stopPolling() - Method in class alluxio.underfs.hdfs.activesync.SupportedHdfsActiveSyncProvider
 
stopPolling() - Method in interface alluxio.underfs.hdfs.HdfsActiveSyncProvider
stop polling thread.
stopPolling() - Method in class alluxio.underfs.hdfs.NoopHdfsActiveSyncProvider
 
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.
stopRejectingRpcServer() - Method in class alluxio.master.MasterProcess
 
stopRejectingServers() - Method in class alluxio.master.MasterProcess
 
stopRejectingWebServer() - Method in class alluxio.master.MasterProcess
 
stopServing() - Method in class alluxio.master.AlluxioJobMasterProcess
 
stopServing() - Method in class alluxio.master.AlluxioMasterProcess
Stops serving, trying stop RPC server and web ui server and letting MetricsSystem stop all the sinks.
stopSinks() - Static method in class alluxio.metrics.MetricsSystem
Stops all the sinks.
stopStandby() - Method in class alluxio.master.MultiMasterLocalAlluxioCluster
Iterates over the masters in the order of master creation, stops the first standby master.
stopSync(AlluxioURI) - Method in class alluxio.client.file.BaseFileSystem
Stops the active syncing process on an Alluxio path.
stopSync(AlluxioURI) - Method in class alluxio.client.file.DelegatingFileSystem
 
stopSync(AlluxioURI) - Method in interface alluxio.client.file.FileSystem
Stops the active syncing process on an Alluxio path.
stopSync(AlluxioURI) - Method in class alluxio.client.file.FileSystemCache.InstanceCachingFileSystem
 
stopSync(AlluxioURI) - Method in interface alluxio.client.file.FileSystemMasterClient
Stop the active syncing process for a specified path.
stopSync(AlluxioURI) - Method in class alluxio.client.file.RetryHandlingFileSystemMasterClient
 
stopSync(AlluxioURI) - Method in class alluxio.concurrent.ManagedBlockingUfsForwarder
 
stopSync(StopSyncPRequest) - Method in class alluxio.grpc.FileSystemMasterClientServiceGrpc.FileSystemMasterClientServiceBlockingStub
Start the active syncing of the directory or file
stopSync(StopSyncPRequest) - Method in class alluxio.grpc.FileSystemMasterClientServiceGrpc.FileSystemMasterClientServiceFutureStub
Start the active syncing of the directory or file
stopSync(StopSyncPRequest, StreamObserver<StopSyncPResponse>) - Method in class alluxio.grpc.FileSystemMasterClientServiceGrpc.FileSystemMasterClientServiceImplBase
Start the active syncing of the directory or file
stopSync(StopSyncPRequest, StreamObserver<StopSyncPResponse>) - Method in class alluxio.grpc.FileSystemMasterClientServiceGrpc.FileSystemMasterClientServiceStub
Start the active syncing of the directory or file
stopSync(AlluxioURI) - Method in class alluxio.hadoop.AlluxioHdfsFileSystem
 
stopSync(AlluxioURI) - Method in class alluxio.master.file.DefaultFileSystemMaster
 
stopSync(AlluxioURI) - Method in interface alluxio.master.file.FileSystemMaster
stops active sync on a specific syncpoint.
stopSync(StopSyncPRequest, StreamObserver<StopSyncPResponse>) - Method in class alluxio.master.file.FileSystemMasterClientServiceHandler
 
stopSync(AlluxioURI) - Method in class alluxio.underfs.BaseUnderFileSystem
 
stopSync(AlluxioURI) - Method in class alluxio.underfs.hdfs.activesync.SupportedHdfsActiveSyncProvider
stop sync on a ufs uri.
stopSync(AlluxioURI) - Method in interface alluxio.underfs.hdfs.HdfsActiveSyncProvider
stop syncing on a ufs uri.
stopSync(AlluxioURI) - Method in class alluxio.underfs.hdfs.HdfsUnderFileSystem
 
stopSync(AlluxioURI) - Method in class alluxio.underfs.hdfs.NoopHdfsActiveSyncProvider
 
stopSync(AlluxioURI) - Method in interface alluxio.underfs.UnderFileSystem
Stop Sync Point.
stopSync(AlluxioURI) - Method in class alluxio.underfs.UnderFileSystemWithLogging
 
stopSyncAndJournal(RpcContext, AlluxioURI) - Method in class alluxio.master.file.activesync.ActiveSyncManager
Stop active sync on a URI and journal the remove entry.
StopSyncCommand - Class in alluxio.cli.fs.command
This class represents a stop sync command.
StopSyncCommand(FileSystemContext) - Constructor for class alluxio.cli.fs.command.StopSyncCommand
Create a StopSync Command object.
stopSyncForMount(long) - Method in class alluxio.master.file.activesync.ActiveSyncManager
Stop active sync on a mount id.
StopSyncPOptions - Class in alluxio.grpc
Protobuf type alluxio.grpc.file.StopSyncPOptions
StopSyncPOptions.Builder - Class in alluxio.grpc
Protobuf type alluxio.grpc.file.StopSyncPOptions
StopSyncPOptionsOrBuilder - Interface in alluxio.grpc
 
StopSyncPRequest - Class in alluxio.grpc
Protobuf type alluxio.grpc.file.StopSyncPRequest
StopSyncPRequest.Builder - Class in alluxio.grpc
Protobuf type alluxio.grpc.file.StopSyncPRequest
StopSyncPRequestOrBuilder - Interface in alluxio.grpc
 
StopSyncPResponse - Class in alluxio.grpc
Protobuf type alluxio.grpc.file.StopSyncPResponse
StopSyncPResponse.Builder - Class in alluxio.grpc
Protobuf type alluxio.grpc.file.StopSyncPResponse
StopSyncPResponseOrBuilder - Interface in alluxio.grpc
 
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
 
StorageChecker() - Constructor for class alluxio.worker.block.DefaultBlockWorker.StorageChecker
 
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 - Class in alluxio.worker.block.meta
Represents a directory in a storage tier.
StorageDirAllocatorView - Class in alluxio.worker.block.meta
This class is a wrapper of StorageDir to provide more limited access for allocators.
StorageDirAllocatorView(StorageDir, StorageTierView) - Constructor for class alluxio.worker.block.meta.StorageDirAllocatorView
Creates a StorageDirAllocatorView using the actual StorageDir.
StorageDirEvictorView - Class in alluxio.worker.block.meta
This class is a wrapper of StorageDir to provide more limited access for evictors.
StorageDirEvictorView(StorageDir, StorageTierEvictorView, BlockMetadataEvictorView) - Constructor for class alluxio.worker.block.meta.StorageDirEvictorView
Creates a StorageDirEvictorView using the actual StorageDir and the associated BlockMetadataEvictorView.
StorageDirView - Class in alluxio.worker.block.meta
This class is a wrapper of StorageDir to provide more limited access.
StorageDirView(StorageDir, StorageTierView) - Constructor for class alluxio.worker.block.meta.StorageDirView
Creates a StorageDirView using the actual StorageDir.
StorageFormat - Class in alluxio.grpc.table.layout.hive
Protobuf type alluxio.grpc.table.layout.StorageFormat
StorageFormat.Builder - Class in alluxio.grpc.table.layout.hive
Protobuf type alluxio.grpc.table.layout.StorageFormat
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.validation
Task for validating whether worker tiered storage has enough space.
StorageSpaceValidationTask() - Constructor for class alluxio.cli.validation.StorageSpaceValidationTask
Creates a new instance of StorageSpaceValidationTask for validating tiered storage space.
StorageTier - Class in alluxio.worker.block.meta
Represents a tier of storage, for example memory or SSD.
StorageTierAllocatorView - Class in alluxio.worker.block.meta
This class is a wrapper of StorageTier to provide more limited access for allocators.
StorageTierAllocatorView(StorageTier) - Constructor for class alluxio.worker.block.meta.StorageTierAllocatorView
Creates a StorageTierView using the actual StorageTier.
StorageTierAssoc - Class in alluxio
Creates a two-way mapping between storage tier aliases and ordinal numbers from the given ServerConfiguration.
StorageTierAssoc(PropertyKey, PropertyKey.Template) - Constructor for class alluxio.StorageTierAssoc
Constructs a new instance using the given ServerConfiguration object.
StorageTierAssoc(List<String>) - Constructor for class alluxio.StorageTierAssoc
Constructs a new instance using the given list of storage tier aliases in order of their position in the hierarchy.
StorageTierEvictorView - Class in alluxio.worker.block.meta
This class is a wrapper of StorageTier to provide more limited access for evictors.
StorageTierEvictorView(StorageTier, BlockMetadataEvictorView) - Constructor for class alluxio.worker.block.meta.StorageTierEvictorView
Creates a StorageTierEvictorView using the actual StorageTier and the above BlockMetadataEvictorView.
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
 
StorageTierView - Class in alluxio.worker.block.meta
This class is an abstract class for allocators and evictors to extend to provide limited access to StorageTier.
StorageTierView(StorageTier) - Constructor for class alluxio.worker.block.meta.StorageTierView
Creates a StorageTierView using the actual StorageTier.
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.
STRING - Static variable in class alluxio.job.plan.transform.HiveConstants.Types
Hive string type.
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
 
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
 
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.
SUBJECT_FIELD_NUMBER - Static variable in class alluxio.grpc.PAclEntry
 
SUBJECT_FIELD_NUMBER - Static variable in class alluxio.proto.shared.Acl.AclEntry
 
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(FileInfo) - Method in class alluxio.master.file.ListStatusResultStream
 
submit(T) - Method in interface alluxio.master.file.ResultStream
Submits a new item to stream.
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.
submitRequest(AsyncCacheRequest) - Method in class alluxio.worker.block.AsyncCacheRequestManager
Handles a request to cache a block asynchronously.
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.
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;
Summary() - Constructor for class alluxio.job.util.TimeSeries.Summary
Creates a TimeSeries.Summary instance.
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.
SUMMARYPERSTATUS_FIELD_NUMBER - Static variable in class alluxio.grpc.JobServiceSummary
 
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.
supportAlluxioHA(PrintWriter, AlluxioConfiguration) - Static method in class alluxio.checker.CheckerUtils
Checks if the Zookeeper address has been set when running the Alluxio HA mode.
SupportedHdfsAclProvider - Class in alluxio.underfs.hdfs.acl
Provides the HDFS ACLs.
SupportedHdfsAclProvider() - Constructor for class alluxio.underfs.hdfs.acl.SupportedHdfsAclProvider
 
SupportedHdfsActiveSyncProvider - Class in alluxio.underfs.hdfs.activesync
Supported Hdfs Active Sync Provider.
SupportedHdfsActiveSyncProvider(URI, Configuration, UnderFileSystemConfiguration) - Constructor for class alluxio.underfs.hdfs.activesync.SupportedHdfsActiveSyncProvider
Constructor for supported Hdfs Active Sync Provider.
supportsActiveSync() - Method in class alluxio.concurrent.ManagedBlockingUfsForwarder
 
supportsActiveSync() - Method in class alluxio.underfs.BaseUnderFileSystem
 
supportsActiveSync() - Method in class alluxio.underfs.hdfs.HdfsUnderFileSystem
 
supportsActiveSync() - Method in interface alluxio.underfs.UnderFileSystem
Whether this type of UFS supports active sync.
supportsActiveSync() - Method in class alluxio.underfs.UnderFileSystemWithLogging
 
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.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
 
supportsFlush() - Method in class alluxio.underfs.web.WebUnderFileSystem
 
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.cos.COSUnderFileSystemFactory
 
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.kodo.KodoUnderFileSystemFactory
 
supportsPath(String) - Method in class alluxio.underfs.local.LocalUnderFileSystemFactory
 
supportsPath(String) - Method in class alluxio.underfs.oss.OSSUnderFileSystemFactory
 
supportsPath(String) - Method in class alluxio.underfs.s3a.S3AUnderFileSystemFactory
 
supportsPath(String) - Method in class alluxio.underfs.swift.SwiftUnderFileSystemFactory
 
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
 
supportsPath(String) - Method in class alluxio.underfs.web.WebUnderFileSystemFactory
 
supportsVersion(Version) - Method in class alluxio.master.backcompat.ops.SetAcl
 
supportsVersion(Version) - Method in interface alluxio.master.backcompat.TestOp
 
suspend() - Method in interface alluxio.master.journal.JournalSystem
Suspends applying for all journals.
suspend() - Method in class alluxio.master.journal.noop.NoopJournalSystem
 
suspend() - Method in class alluxio.master.journal.raft.BufferedJournalApplier
Suspend the applier.
suspend() - Method in class alluxio.master.journal.raft.JournalStateMachine
Suspends applying to masters.
suspend() - Method in class alluxio.master.journal.raft.RaftJournalSystem
 
suspend() - Method in class alluxio.master.journal.ufs.UfsJournal
Suspends applying this journal until resumed.
suspend() - 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_METHOD_KEY - Static variable in class alluxio.conf.PropertyKey.Name
 
SWIFT_AUTH_METHOD_KEY - Static variable in class alluxio.conf.PropertyKey
 
SWIFT_AUTH_SWIFTAUTH - Static variable in class alluxio.Constants
 
SWIFT_AUTH_URL_KEY - Static variable in class alluxio.conf.PropertyKey.Name
 
SWIFT_AUTH_URL_KEY - Static variable in class alluxio.conf.PropertyKey
 
SWIFT_PASSWORD_KEY - Static variable in class alluxio.conf.PropertyKey.Name
 
SWIFT_PASSWORD_KEY - Static variable in class alluxio.conf.PropertyKey
 
SWIFT_REGION_KEY - Static variable in class alluxio.conf.PropertyKey.Name
 
SWIFT_REGION_KEY - Static variable in class alluxio.conf.PropertyKey
 
SWIFT_SIMULATION - Static variable in class alluxio.conf.PropertyKey.Name
 
SWIFT_SIMULATION - Static variable in class alluxio.conf.PropertyKey
 
SWIFT_TENANT_KEY - Static variable in class alluxio.conf.PropertyKey.Name
 
SWIFT_TENANT_KEY - Static variable in class alluxio.conf.PropertyKey
 
SWIFT_USER_KEY - Static variable in class alluxio.conf.PropertyKey.Name
 
SWIFT_USER_KEY - Static variable in class alluxio.conf.PropertyKey
 
SwiftDirectClient - Class in alluxio.underfs.swift.http
Makes direct calls to a Swift API backend.
SwiftDirectClient() - Constructor for class alluxio.underfs.swift.http.SwiftDirectClient
Constructs a new SwiftDirectClient.
SwiftInputStream - Class in alluxio.underfs.swift
A stream for reading data from a Swift API based object store.
SwiftInputStream(Account, String, String, RetryPolicy, long) - Constructor for class alluxio.underfs.swift.SwiftInputStream
Constructor for an input stream to an object in a Swift API based store.
SwiftInputStream(Account, String, String, long, RetryPolicy, long) - Constructor for class alluxio.underfs.swift.SwiftInputStream
Constructor for an input stream to an object in a Swift API based store.
SwiftMockOutputStream - Class in alluxio.underfs.swift
A stream for writing data to an in-memory simulated Swift client.
SwiftMockOutputStream(Account, String, String, List<String>) - Constructor for class alluxio.underfs.swift.SwiftMockOutputStream
Creates a new instance of SwiftMockOutputStream.
SwiftOutputStream - Class in alluxio.underfs.swift
A stream for writing data to Swift API based object store.
SwiftOutputStream(HttpURLConnection) - Constructor for class alluxio.underfs.swift.SwiftOutputStream
Creates a new instance of SwiftOutputStream.
SwiftUnderFileSystem - Class in alluxio.underfs.swift
OpenStack Swift UnderFileSystem implementation based on the JOSS library.
SwiftUnderFileSystem(AlluxioURI, UnderFileSystemConfiguration) - Constructor for class alluxio.underfs.swift.SwiftUnderFileSystem
Constructs a new Swift UnderFileSystem.
SwiftUnderFileSystemFactory - Class in alluxio.underfs.swift
Factory for creating SwiftUnderFileSystem.
SwiftUnderFileSystemFactory() - Constructor for class alluxio.underfs.swift.SwiftUnderFileSystemFactory
Constructs a new SwiftUnderFileSystemFactory.
sync(JournalContext) - Method in class alluxio.master.table.Database
Syncs the metadata from the under db.
SYNC_STATUS_FIELD_NUMBER - Static variable in class alluxio.grpc.table.AttachDatabasePResponse
 
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) - 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.TableMasterClientServiceImplBase
Sync existing database into the catalog
syncDatabase(SyncDatabasePRequest, StreamObserver<SyncDatabasePResponse>) - Method in class alluxio.grpc.table.TableMasterClientServiceGrpc.TableMasterClientServiceStub
Sync existing database into the catalog
syncDatabase(JournalContext, String) - Method in class alluxio.master.table.AlluxioCatalog
Syncs a database.
syncDatabase(String) - Method in class alluxio.master.table.DefaultTableMaster
 
syncDatabase(String) - Method in interface alluxio.master.table.TableMaster
Syncs a database.
syncDatabase(SyncDatabasePRequest, StreamObserver<SyncDatabasePResponse>) - Method in class alluxio.master.table.TableMasterClientServiceHandler
 
SyncDatabaseCommand - Class in alluxio.cli.table.command
A command which can be used to sync a database with the underlying udb.
SyncDatabaseCommand(AlluxioConfiguration, TableMasterClient) - Constructor for class alluxio.cli.table.command.SyncDatabaseCommand
Creates a new instance of SyncDatabaseCommand.
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
 
SyncInfo - Class in alluxio
This class is used to represent what the active syncing process should sync.
SyncInfo(Map<AlluxioURI, Set<AlluxioURI>>, boolean, long) - Constructor for class alluxio.SyncInfo
Constructs a SyncInfo.
Syncing_VALUE - Static variable in enum alluxio.grpc.SyncPointStatus
Syncing = 1;
SYNCINTERVALMS_FIELD_NUMBER - Static variable in class alluxio.grpc.FileSystemMasterCommonPOptions
 
SYNCPATHS_FIELD_NUMBER - Static variable in class alluxio.grpc.GetSyncPathListPResponse
 
syncPersistExistingDirectory(Supplier<JournalContext>, InodeDirectoryView) - Method in class alluxio.master.file.meta.InodeTree
Synchronously persists an inode directory to the UFS.
syncPersistNewDirectory(MutableInodeDirectory) - 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
 
SyncPointInfo - Class in alluxio.grpc
Protobuf type alluxio.grpc.file.SyncPointInfo
SyncPointInfo - Class in alluxio.wire
This class represents the state of a sync point, whether the intial syncing is done, in progress or not going to be done.
SyncPointInfo(AlluxioURI, SyncPointInfo.SyncStatus) - Constructor for class alluxio.wire.SyncPointInfo
Constructs a SyncPointInfo object.
SyncPointInfo.Builder - Class in alluxio.grpc
Protobuf type alluxio.grpc.file.SyncPointInfo
SyncPointInfo.SyncStatus - Enum in alluxio.wire
Indicates the status of the initial sync of the active sync point.
SyncPointInfoOrBuilder - Interface in alluxio.grpc
 
SyncPointStatus - Enum in alluxio.grpc
Protobuf enum alluxio.grpc.file.SyncPointStatus
SYNCPOINTURI_FIELD_NUMBER - Static variable in class alluxio.grpc.SyncPointInfo
 
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
SYNCSTATUS_FIELD_NUMBER - Static variable in class alluxio.grpc.SyncPointInfo
 
SyncStatusOrBuilder - Interface in alluxio.grpc.table
 
SYSTEM - Static variable in class alluxio.time.TimeContext
 
SYSTEM_PROPERTY - Static variable in class alluxio.conf.Source
 
SystemClock - Class in alluxio.clock
A clock representing the current time as reported by the operating system.
SystemClock() - Constructor for class alluxio.clock.SystemClock
Constructs a new Clock which reports the actual time.

T

Table - Class in alluxio.master.table
The table implementation which manages all the versions of the table.
Table - Class in alluxio.proto.journal
 
Table.AddTableEntry - Class in alluxio.proto.journal
next available id: 13
Table.AddTableEntry.Builder - Class in alluxio.proto.journal
next available id: 13
Table.AddTableEntryOrBuilder - Interface in alluxio.proto.journal
 
Table.AddTransformJobInfoEntry - Class in alluxio.proto.journal
next available id: 6
Table.AddTransformJobInfoEntry.Builder - Class in alluxio.proto.journal
next available id: 6
Table.AddTransformJobInfoEntryOrBuilder - Interface in alluxio.proto.journal
 
Table.AttachDbEntry - Class in alluxio.proto.journal
next available id: 6
Table.AttachDbEntry.Builder - Class in alluxio.proto.journal
next available id: 6
Table.AttachDbEntryOrBuilder - Interface in alluxio.proto.journal
 
Table.CompleteTransformTableEntry - Class in alluxio.proto.journal
next available id: 5
Table.CompleteTransformTableEntry.Builder - Class in alluxio.proto.journal
next available id: 5
Table.CompleteTransformTableEntryOrBuilder - Interface in alluxio.proto.journal
 
Table.DetachDbEntry - Class in alluxio.proto.journal
next available id: 2
Table.DetachDbEntry.Builder - Class in alluxio.proto.journal
next available id: 2
Table.DetachDbEntryOrBuilder - Interface in alluxio.proto.journal
 
Table.RemoveTableEntry - Class in alluxio.proto.journal
next available id: 5
Table.RemoveTableEntry.Builder - Class in alluxio.proto.journal
next available id: 5
Table.RemoveTableEntryOrBuilder - Interface in alluxio.proto.journal
 
Table.RemoveTransformJobInfoEntry - Class in alluxio.proto.journal
next available id: 3
Table.RemoveTransformJobInfoEntry.Builder - Class in alluxio.proto.journal
next available id: 3
Table.RemoveTransformJobInfoEntryOrBuilder - Interface in alluxio.proto.journal
 
Table.UpdateDatabaseInfoEntry - Class in alluxio.proto.journal
next available id: 6
Table.UpdateDatabaseInfoEntry.Builder - Class in alluxio.proto.journal
next available id: 6
Table.UpdateDatabaseInfoEntryOrBuilder - Interface in alluxio.proto.journal
 
TABLE_CATALOG_PATH - Static variable in class alluxio.conf.PropertyKey.Name
 
TABLE_CATALOG_PATH - Static variable in class alluxio.conf.PropertyKey
 
TABLE_CATALOG_UDB_SYNC_TIMEOUT - Static variable in class alluxio.conf.PropertyKey.Name
 
TABLE_CATALOG_UDB_SYNC_TIMEOUT - Static variable in class alluxio.conf.PropertyKey
 
TABLE_ENABLED - Static variable in class alluxio.conf.PropertyKey.Name
 
TABLE_ENABLED - Static variable in class alluxio.conf.PropertyKey
 
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_NAME - Static variable in class alluxio.Constants
 
TABLE_MASTER_CLIENT_SERVICE_VALUE - Static variable in enum alluxio.grpc.ServiceType
TABLE_MASTER_CLIENT_SERVICE = 14;
TABLE_MASTER_CLIENT_SERVICE_VERSION - Static variable in class alluxio.Constants
 
TABLE_MASTER_NAME - Static variable in class alluxio.Constants
 
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
 
TABLE_NAME_FIELD_NUMBER - Static variable in class alluxio.proto.journal.Table.AddTableEntry
 
TABLE_NAME_FIELD_NUMBER - Static variable in class alluxio.proto.journal.Table.AddTransformJobInfoEntry
 
TABLE_NAME_FIELD_NUMBER - Static variable in class alluxio.proto.journal.Table.CompleteTransformTableEntry
 
TABLE_NAME_FIELD_NUMBER - Static variable in class alluxio.proto.journal.Table.RemoveTableEntry
 
TABLE_NAME_FIELD_NUMBER - Static variable in class alluxio.proto.journal.Table.RemoveTransformJobInfoEntry
 
TABLE_STATS_FIELD_NUMBER - Static variable in class alluxio.proto.journal.Table.AddTableEntry
 
TABLE_TRANSFORM_MANAGER_JOB_HISTORY_RETENTION_TIME - Static variable in class alluxio.conf.PropertyKey.Name
 
TABLE_TRANSFORM_MANAGER_JOB_HISTORY_RETENTION_TIME - Static variable in class alluxio.conf.PropertyKey
 
TABLE_TRANSFORM_MANAGER_JOB_MONITOR_INTERVAL - Static variable in class alluxio.conf.PropertyKey.Name
 
TABLE_TRANSFORM_MANAGER_JOB_MONITOR_INTERVAL - Static variable in class alluxio.conf.PropertyKey
 
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
 
TableMaster - Interface in alluxio.master.table
Interface of the table master that manages the table service.
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.TableMasterClientServiceBlockingStub - Class in alluxio.grpc.table
This interface contains table master service endpoints for Alluxio clients.
TableMasterClientServiceGrpc.TableMasterClientServiceFutureStub - Class in alluxio.grpc.table
This interface contains table master service endpoints for Alluxio clients.
TableMasterClientServiceGrpc.TableMasterClientServiceImplBase - Class in alluxio.grpc.table
This interface contains table master service endpoints for Alluxio clients.
TableMasterClientServiceGrpc.TableMasterClientServiceStub - Class in alluxio.grpc.table
This interface contains table master service endpoints for Alluxio clients.
TableMasterClientServiceHandler - Class in alluxio.master.table
This class is a gRPC handler for table master RPCs.
TableMasterClientServiceHandler(TableMaster) - Constructor for class alluxio.master.table.TableMasterClientServiceHandler
Creates a new instance of TableMasterClientServiceHandler.
TableMasterClientServiceImplBase() - Constructor for class alluxio.grpc.table.TableMasterClientServiceGrpc.TableMasterClientServiceImplBase
 
TableMasterFactory - Class in alluxio.master.table
Factory to create a TableMaster instance.
TableMasterFactory() - Constructor for class alluxio.master.table.TableMasterFactory
Constructs a new TableMasterFactory.
TableMasterProto - Class in alluxio.grpc.table
 
TableReader - Interface in alluxio.job.plan.transform.format
A reader for reading rows in a table.
TableRow - Interface in alluxio.job.plan.transform.format
A row in a table.
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_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
 
TableSchema - Interface in alluxio.job.plan.transform.format
The table schema.
TableShell - Class in alluxio.cli.table
A shell implementation which is used to load the commands for interacting with the Alluxio table service.
TableShell(InstancedConfiguration) - Constructor for class alluxio.cli.table.TableShell
Construct a new instance of TableShell.
TableShellUtils - Class in alluxio.cli.table
A utility class for the table shell.
TablesWriter - Class in alluxio.job.plan.transform.format.tables
Writes a stream of rows to a list of tables, when Committer determines that the current table should be committed/completed, the table file is completed and a new table file is created.
TableWriter - Interface in alluxio.job.plan.transform.format
A writer for writing rows to a table.
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
 
TAGS_FIELD_NUMBER - Static variable in class alluxio.grpc.Metric
 
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
 
takeBackup(BackupPRequest, AtomicLong) - Method in class alluxio.master.backup.AbstractBackupRole
Takes a backup on local master.
takeLeadership(CuratorFramework) - Method in class alluxio.master.PrimarySelectorClient
 
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
 
TARGETDIRECTORY_FIELD_NUMBER - Static variable in class alluxio.grpc.BackupPRequest
 
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
Utility methods for working with tar archives.
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) - Constructor for class alluxio.job.wire.TaskInfo
Constructs a new TaskInfo from jobId, taskId, Status, and workerAddress.
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
 
TB - Static variable in class alluxio.Constants
 
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 - Class in alluxio.worker.block.meta
Represents the metadata of an uncommitted block in Alluxio managed storage.
TempBlockMeta(long, long, long, StorageDir) - Constructor for class alluxio.worker.block.meta.TempBlockMeta
Creates a new instance of TempBlockMeta.
temporaryFileName(long, String) - Static method in class alluxio.util.io.PathUtils
Generates a deterministic temporary file name for the a path and a file id and a nonce.
tempPath(StorageDir, long, long) - Static method in class alluxio.worker.block.meta.AbstractBlockMeta
All blocks are created as temp blocks before committed.
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
 
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
 
TestOp - Interface in alluxio.master.backcompat
A test operation for use by the backwards compatibility test.
TestRunner - Class in alluxio.cli
Driver to run Alluxio tests.
TESTS_LOG - Static variable in class alluxio.Constants
 
TestUtils - Class in alluxio.master
Test utilities.
TestUtils() - Constructor for class alluxio.master.TestUtils
 
TEXT_INPUT_FORMAT_CLASS - Static variable in class alluxio.job.plan.transform.HiveConstants
Text input format.
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
 
ThreadFactoryUtils - Class in alluxio.util
Utility methods for the ThreadFactory class.
ThreadSleeper - Class in alluxio.time
A sleeping utility which delegates to Thread.sleep().
ThreadUtils - Class in alluxio.util
Utility method for working with threads.
throttle() - Method in class alluxio.worker.job.task.TaskExecutorManager
Throttle the TaskExecutorManager.
THROUGH_VALUE - Static variable in enum alluxio.grpc.WritePType
THROUGH = 4;
tick() - Method in interface alluxio.heartbeat.HeartbeatTimer
Waits until next heartbeat should be executed.
tick() - Method in class alluxio.heartbeat.ScheduledTimer
Waits until the heartbeat is scheduled for execution.
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.CreateLocalBlockRequest
 
TIER_FIELD_NUMBER - Static variable in class alluxio.grpc.WriteRequestCommand
 
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
 
TieredBlockStore - Class in alluxio.worker.block
This class represents an object store that manages all the blocks in the local tiered storage.
TieredBlockStore() - Constructor for class alluxio.worker.block.TieredBlockStore
Creates a new instance of TieredBlockStore.
TieredIdentity - Class in alluxio.grpc
Protobuf type alluxio.grpc.TieredIdentity
TieredIdentity - Class in alluxio.wire
Class representing a node's tier identity.
TieredIdentity(List<TieredIdentity.LocalityTier>) - Constructor for class alluxio.wire.TieredIdentity
 
TieredIdentity.Builder - Class in alluxio.grpc
Protobuf type alluxio.grpc.TieredIdentity
TieredIdentity.LocalityTier - Class in alluxio.wire
Class representing a locality tier, e.g.
TIEREDIDENTITY_FIELD_NUMBER - Static variable in class alluxio.grpc.WorkerNetAddress
 
TieredIdentityFactory - Class in alluxio.network
Class for getting tiered identity.
TieredIdentityFactory() - Constructor for class alluxio.network.TieredIdentityFactory
 
TieredIdentityOrBuilder - Interface in alluxio.grpc
 
TieredIdentityUtils - Class in alluxio.util
Utility functions for working with tiered identity.
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
 
TIERNAME_FIELD_NUMBER - Static variable in class alluxio.grpc.LocalityTier
 
TIERS_FIELD_NUMBER - Static variable in class alluxio.grpc.TieredIdentity
 
TIERS_FIELD_NUMBER - Static variable in class alluxio.grpc.TierList
 
TimeBoundedRetry - Class in alluxio.retry
Retry mechanism which performs retries until a certain period of time has elapsed.
TimeBoundedRetry(TimeContext, Duration) - Constructor for class alluxio.retry.TimeBoundedRetry
 
TimeContext - Class in alluxio.time
Context for managing time.
TimeContext(Clock, Sleeper) - Constructor for class alluxio.time.TimeContext
 
timeout() - Method in class alluxio.SessionInfo
Checks whether the session has timed out.
TimeoutRefresh - Class in alluxio.refresh
A refresh policy which allows refreshing after a specified timeout is reached.
TimeoutRefresh(long) - Constructor for class alluxio.refresh.TimeoutRefresh
Constructs a refresh facility which allows refreshing after a specified timeout is reached.
TimeoutRetry - Class in alluxio.retry
A retry policy which allows retrying until a specified timeout is reached.
TimeoutRetry(long, int) - Constructor for class alluxio.retry.TimeoutRetry
Constructs a retry facility which allows retrying until a specified timeout is reached.
timer(String) - Static method in class alluxio.metrics.MetricsSystem
Get or add timer with the given name.
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.
TIMESTAMP - Static variable in class alluxio.job.plan.transform.HiveConstants.Types
Hive timestamp type.
TINYINT - Static variable in class alluxio.job.plan.transform.HiveConstants.Types
Hive tiny int type.
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
 
toAlluxioException() - Method in exception alluxio.exception.status.AlluxioStatusException
 
toAlluxioPath(String) - Method in class alluxio.table.under.hive.util.PathTranslator
Returns the corresponding alluxio path, for the specified ufs path.
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
 
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
 
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
 
toBigDecimal(String) - Method in class alluxio.job.plan.transform.format.csv.Decimal
 
toBlockStoreLocation() - Method in class alluxio.worker.block.meta.StorageDir
 
toBlockStoreLocation() - Method in class alluxio.worker.block.meta.StorageDirView
Creates a BlockStoreLocation for this directory view.
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.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.BlockStoreLocationProto
 
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.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.Command
 
toBuilder() - Method in class alluxio.grpc.CommitBlockInUfsPOptions
 
toBuilder() - Method in class alluxio.grpc.CommitBlockInUfsPRequest
 
toBuilder() - Method in class alluxio.grpc.CommitBlockInUfsPResponse
 
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.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.CreateLocalBlockRequest
 
toBuilder() - Method in class alluxio.grpc.CreateLocalBlockResponse
 
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.ExistsPOptions
 
toBuilder() - Method in class alluxio.grpc.FileBlockInfo
 
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.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.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.GetJobServiceSummaryPOptions
 
toBuilder() - Method in class alluxio.grpc.GetJobServiceSummaryPRequest
 
toBuilder() - Method in class alluxio.grpc.GetJobServiceSummaryPResponse
 
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.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.GetPinnedFileIdsPOptions
 
toBuilder() - Method in class alluxio.grpc.GetPinnedFileIdsPRequest
 
toBuilder() - Method in class alluxio.grpc.GetPinnedFileIdsPResponse
 
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.GetServiceVersionPRequest
 
toBuilder() - Method in class alluxio.grpc.GetServiceVersionPResponse
 
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.GetSyncPathListPRequest
 
toBuilder() - Method in class alluxio.grpc.GetSyncPathListPResponse
 
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.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.JobServiceSummary
 
toBuilder() - Method in class alluxio.grpc.JobUnused
 
toBuilder() - Method in class alluxio.grpc.JobWorkerHealth
 
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.ListStatusPOptions
 
toBuilder() - Method in class alluxio.grpc.ListStatusPRequest
 
toBuilder() - Method in class alluxio.grpc.ListStatusPResponse
 
toBuilder() - Method in class alluxio.grpc.LoadMetadataPOptions
 
toBuilder() - Method in class alluxio.grpc.LocalityTier
 
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.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.NetAddress
 
toBuilder() - Method in class alluxio.grpc.OpenFilePOptions
 
toBuilder() - Method in class alluxio.grpc.OpenLocalBlockRequest
 
toBuilder() - Method in class alluxio.grpc.OpenLocalBlockResponse
 
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.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.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.RemovePathConfigurationPOptions
 
toBuilder() - Method in class alluxio.grpc.RemovePathConfigurationPRequest
 
toBuilder() - Method in class alluxio.grpc.RemovePathConfigurationPResponse
 
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.ReverseResolvePRequest
 
toBuilder() - Method in class alluxio.grpc.ReverseResolvePResponse
 
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.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.StartSyncPOptions
 
toBuilder() - Method in class alluxio.grpc.StartSyncPRequest
 
toBuilder() - Method in class alluxio.grpc.StartSyncPResponse
 
toBuilder() - Method in class alluxio.grpc.StatusSummary
 
toBuilder() - Method in class alluxio.grpc.StopSyncPOptions
 
toBuilder() - Method in class alluxio.grpc.StopSyncPRequest
 
toBuilder() - Method in class alluxio.grpc.StopSyncPResponse
 
toBuilder() - Method in class alluxio.grpc.StorageList
 
toBuilder() - Method in class alluxio.grpc.SyncPointInfo
 
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.TieredIdentity
 
toBuilder() - Method in class alluxio.grpc.TierList
 
toBuilder() - Method in class alluxio.grpc.TransportMessage
 
toBuilder() - Method in class alluxio.grpc.UfsInfo
 
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.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.WorkerInfo
 
toBuilder() - Method in class alluxio.grpc.WorkerLostStorageInfo
 
toBuilder() - Method in class alluxio.grpc.WorkerNetAddress
 
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.CreateUfsBlockOptions
 
toBuilder() - Method in class alluxio.proto.dataserver.Protocol.CreateUfsFileOptions
 
toBuilder() - Method in class alluxio.proto.dataserver.Protocol.OpenUfsBlockOptions
 
toBuilder() - Method in class alluxio.proto.dataserver.Protocol.Response
 
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.Journal.JournalEntry
 
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.Table.AddTableEntry
 
toBuilder() - Method in class alluxio.proto.journal.Table.AddTransformJobInfoEntry
 
toBuilder() - Method in class alluxio.proto.journal.Table.AttachDbEntry
 
toBuilder() - Method in class alluxio.proto.journal.Table.CompleteTransformTableEntry
 
toBuilder() - Method in class alluxio.proto.journal.Table.DetachDbEntry
 
toBuilder() - Method in class alluxio.proto.journal.Table.RemoveTableEntry
 
toBuilder() - Method in class alluxio.proto.journal.Table.RemoveTransformJobInfoEntry
 
toBuilder() - Method in class alluxio.proto.journal.Table.UpdateDatabaseInfoEntry
 
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.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
 
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
 
toEvict() - Method in class alluxio.worker.block.evictor.EvictionPlan
 
toGetStatusOptions(ExistsPOptions) - Static method in class alluxio.grpc.GrpcUtils
Converts from proto type to options.
toGrpcStatusException() - Method in exception alluxio.exception.status.AlluxioStatusException
 
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 interface alluxio.master.journal.JournalEntryRepresentable
 
toJournalEntry() - Method in interface alluxio.master.journalv0.JournalEntryRepresentable
 
toJournalProto(DatabaseInfo, String) - Static method in class alluxio.master.table.Database
 
toJournalProto() - Method in class alluxio.master.table.Table
 
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
 
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(ConfigurationValueOptions) - Method in class alluxio.conf.InstancedConfiguration
 
toMap(ConfigurationValueOptions) - Method in class alluxio.conf.path.SpecificPathConfiguration
 
toMap() - Static method in class alluxio.conf.ServerConfiguration
 
toMap(ConfigurationValueOptions) - Static method in class alluxio.conf.ServerConfiguration
 
toModeBits() - Method in class alluxio.security.authorization.AclActions
 
toMountPointInfo() - Method in class alluxio.master.file.meta.options.MountInfo
 
toMove() - Method in class alluxio.worker.block.evictor.EvictionPlan
 
toOptions() - Method in class alluxio.client.file.cache.store.PageStoreOptions
 
toParquet() - Method in class alluxio.job.plan.transform.format.csv.CsvRow
 
toParquet() - Method in class alluxio.job.plan.transform.format.csv.CsvSchema
 
toParquet() - Method in class alluxio.job.plan.transform.format.parquet.ParquetRow
 
toParquet() - Method in class alluxio.job.plan.transform.format.parquet.ParquetSchema
 
toParquet() - Method in interface alluxio.job.plan.transform.format.TableRow
 
toParquet() - Method in interface alluxio.job.plan.transform.format.TableSchema
 
toParquetBytes(String) - Method in class alluxio.job.plan.transform.format.csv.Decimal
 
toPath(AlluxioURI) - Static method in class alluxio.hadoop.HadoopUtils
 
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 class alluxio.client.file.cache.store.RocksPageStoreOptions
 
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(TieredIdentity.LocalityTier) - Static method in class alluxio.grpc.GrpcUtils
Converts wire type to proto type.
toProto(MountPointInfo) - Static method in class alluxio.grpc.GrpcUtils
Converts wire type to proto type.
toProto(TieredIdentity) - 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() - Method in interface alluxio.job.wire.JobInfo
 
toProto() - Method in class alluxio.job.wire.JobServiceSummary
 
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.master.table.Partition
 
toProto() - Method in class alluxio.master.table.Table
 
toProto() - Method in class alluxio.master.table.transform.TransformJobInfo
 
toProto() - Method in class alluxio.metrics.Metric
 
toProto() - Method in enum alluxio.security.authorization.Mode.Bits
 
toProto() - Method in class alluxio.security.authorization.Mode
 
toProto() - Method in interface alluxio.table.common.Layout
 
toProto(List<FieldSchema>) - Static method in class alluxio.table.under.hive.HiveUtils
 
toProto(StorageDescriptor, PathTranslator) - Static method in class alluxio.table.under.hive.HiveUtils
Convert from a StorageDescriptor to a Storage object.
toProto(ColumnStatisticsObj) - Static method in class alluxio.table.under.hive.HiveUtils
Convert ColumnStatisticsObj to proto definition.
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() - Method in class alluxio.wire.SyncPointInfo
 
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
 
toProtoSchema(List<FieldSchema>) - Static method in class alluxio.table.under.hive.HiveUtils
 
topTiersMatch(TieredIdentity) - Method in class alluxio.wire.TieredIdentity
 
toS3Date(long) - Static method in class alluxio.proxy.s3.S3RestUtils
 
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.client.block.BlockWorkerInfo
 
toString() - Method in class alluxio.client.block.options.GetWorkerReportOptions
 
toString() - Method in class alluxio.client.block.policy.DeterministicHashPolicy
 
toString() - Method in class alluxio.client.block.policy.LocalFirstAvoidEvictionPolicy
 
toString() - Method in class alluxio.client.block.policy.LocalFirstPolicy
 
toString() - Method in class alluxio.client.block.policy.MostAvailableFirstPolicy
 
toString() - Method in class alluxio.client.block.policy.options.GetWorkerOptions
 
toString() - Method in class alluxio.client.block.policy.RoundRobinPolicy
 
toString() - Method in class alluxio.client.block.policy.SpecificHostPolicy
 
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.cache.store.LocalPageStoreOptions
 
toString() - Method in class alluxio.client.file.cache.store.RocksPageStoreOptions
 
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.URIStatus
 
toString() - Method in class alluxio.collections.ConcurrentHashSet
 
toString() - Method in class alluxio.collections.Pair
 
toString() - Method in class alluxio.collections.PrefixList
Print out all prefixes separated by ";".
toString() - Method in class alluxio.concurrent.jsr.CompletableFuture
Returns a string identifying this CompletableFuture, as well as its completion state.
toString() - Method in class alluxio.concurrent.jsr.ForkJoinPool
Returns a string identifying this pool, as well as its state, including indications of run state, parallelism level, and worker and task counts.
toString() - Method in class alluxio.conf.PropertyKey.Builder
 
toString() - Method in enum alluxio.conf.PropertyKey.Template
 
toString() - Method in class alluxio.conf.PropertyKey
 
toString() - Method in class alluxio.conf.Source
 
toString() - Method in exception alluxio.exception.AggregateException
 
toString() - Method in enum alluxio.exception.PreconditionMessage
 
toString() - Method in class alluxio.grpc.GrpcChannel
 
toString() - Method in class alluxio.grpc.GrpcChannelKey
 
toString() - Method in class alluxio.grpc.GrpcConnectionKey
 
toString() - Method in class alluxio.grpc.GrpcServer
 
toString() - Method in class alluxio.grpc.GrpcServerAddress
 
toString() - Method in class alluxio.job.MasterWorkerInfo
 
toString() - Method in class alluxio.job.plan.load.LoadConfig
 
toString() - Method in class alluxio.job.plan.load.LoadDefinition.LoadTask
 
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.persist.PersistConfig
 
toString() - Method in class alluxio.job.plan.replicate.EvictConfig
 
toString() - Method in class alluxio.job.plan.replicate.MoveConfig
 
toString() - Method in class alluxio.job.plan.replicate.ReplicateConfig
 
toString() - Method in class alluxio.job.plan.transform.CompactConfig
 
toString() - Method in class alluxio.job.plan.transform.CompactTask
 
toString() - Method in class alluxio.job.plan.transform.FieldSchema
 
toString() - Method in class alluxio.job.plan.transform.PartitionInfo
 
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.AlluxioJobMasterProcess
 
toString() - Method in class alluxio.master.AlluxioMasterProcess
 
toString() - Method in class alluxio.master.AlluxioSecondaryMaster
 
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.MasterBlockInfo
 
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.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.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.meta.Edge
 
toString() - Method in class alluxio.master.file.meta.LockedInodePath
 
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.SimpleInodeLockList
 
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.journal.options.JournalReaderOptions
 
toString() - Method in class alluxio.master.journal.options.JournalWriterOptions
 
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.MasterInfo
 
toString() - Method in class alluxio.master.metrics.MetricsStore.ClusterCounterKey
 
toString() - Method in class alluxio.master.PollingMasterInquireClient.MultiMasterConnectDetails
 
toString() - Method in class alluxio.master.SingleMasterInquireClient.SingleMasterConnectDetails
 
toString() - Method in class alluxio.master.table.DatabaseInfo
 
toString() - Method in class alluxio.master.transport.GrpcMessagingConnection
 
toString() - Method in class alluxio.master.ZkMasterInquireClient.ZkMasterConnectDetails
 
toString() - Method in class alluxio.metrics.Metric
 
toString() - Method in enum alluxio.metrics.MetricInfo.UfsOps
 
toString() - Method in class alluxio.metrics.MetricKey
 
toString() - Method in class alluxio.metrics.MetricsConfig
 
toString() - Method in class alluxio.metrics.MetricsFilter
 
toString() - Method in enum alluxio.metrics.MetricsSystem.InstanceType
 
toString() - Method in class alluxio.multi.process.MasterNetAddress
 
toString() - Method in class alluxio.proxy.AlluxioProxyProcess
 
toString() - Method in class alluxio.proxy.s3.ListBucketOptions
 
toString() - Method in class alluxio.security.authentication.AuthenticatedUserInfo
 
toString() - Method in class alluxio.security.authorization.AccessControlList
 
toString() - Method in class alluxio.security.authorization.AclActions
 
toString() - Method in class alluxio.security.authorization.AclEntry
 
toString() - Method in enum alluxio.security.authorization.Mode.Bits
 
toString() - Method in class alluxio.security.authorization.Mode
 
toString() - Method in class alluxio.security.CurrentUser
 
toString() - Method in class alluxio.security.User
 
toString() - Method in class alluxio.SessionInfo
 
toString() - Method in class alluxio.shell.ShellCommand
Converts the command to string repr.
toString() - Method in class alluxio.underfs.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.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.util.executor.ControllableQueue
 
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.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.LogInfo
 
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.MasterWebUIMetrics
 
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.TieredIdentity.LocalityTier
 
toString() - Method in class alluxio.wire.TieredIdentity
 
toString() - Method in class alluxio.wire.WorkerInfo
 
toString() - Method in class alluxio.wire.WorkerNetAddress
 
toString() - Method in class alluxio.wire.WorkerWebUIBlockInfo
 
toString() - Method in class alluxio.wire.WorkerWebUIInit
 
toString() - Method in class alluxio.wire.WorkerWebUILogs
 
toString() - Method in class alluxio.wire.WorkerWebUIMetrics
 
toString() - Method in class alluxio.wire.WorkerWebUIOverview
 
toString() - Method in class alluxio.worker.AlluxioJobWorkerProcess
 
toString() - Method in class alluxio.worker.AlluxioWorkerProcess
 
toString() - Method in class alluxio.worker.block.BlockStoreLocation
Converts the location to a human readable form.
toString() - Method in class alluxio.worker.block.evictor.BlockTransferInfo
 
toString() - Method in class alluxio.worker.block.evictor.EvictionPlan
 
toString() - Method in class alluxio.worker.grpc.BlockReadRequest
 
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.
toStringHadoopInputSplit(InputSplit) - Static method in class alluxio.hadoop.HadoopUtils
Returns a string representation of a InputSplit.
toStringHelper() - Method in class alluxio.master.file.meta.MutableInode
 
toStringHelper() - Method in class alluxio.underfs.UfsStatus
 
toStringHelper() - Method in class alluxio.worker.grpc.BlockWriteRequest
 
toStringHelper() - Method in class alluxio.worker.grpc.UfsFileWriteRequest
 
toStringHelper() - Method in class alluxio.worker.grpc.WriteRequest
 
toStringShort() - Method in class alluxio.grpc.GrpcChannel
 
toStringShort() - Method in class alluxio.grpc.GrpcChannelKey
 
toSyncChildren() - Method in class alluxio.master.file.meta.UfsSyncUtils.SyncPlan
 
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
 
toUpdateMetaData() - Method in class alluxio.master.file.meta.UfsSyncUtils.SyncPlan
 
toUserPropertyMap(ConfigurationValueOptions) - Method in class alluxio.underfs.UnderFileSystemConfiguration
 
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
 
transferTo(ByteBuf) - Method in interface alluxio.worker.block.io.BlockReader
Transfers data (up to buf.writableBytes()) from this reader to the buffer.
transferTo(ByteBuf) - Method in class alluxio.worker.block.io.LocalFileBlockReader
 
transferTo(ByteBuf) - Method in class alluxio.worker.block.RemoteBlockReader
 
transferTo(ByteBuf) - Method in class alluxio.worker.block.UnderFileSystemBlockReader
This interface is supposed to be used for sequence block reads.
transform(String, Layout) - Method in class alluxio.master.table.Partition
Transform the partition.
TransformAction - Interface in alluxio.table.common.transform.action
The definition of an individual transformation action.
TransformAction.Parser - Class in alluxio.table.common.transform.action
A class to parse transform actions.
TransformActionFactory - Interface in alluxio.table.common.transform.action
The action factory interface.
TransformActionRegistry - Class in alluxio.table.common.transform.action
The registry of transform actions.
TransformActionUtils - Class in alluxio.table.common.transform.action
Utilities for implementing TransformAction.
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
 
TransformContext - Class in alluxio.table.common.transform
The context for generating transformation plans.
TransformContext(String, String, String) - Constructor for class alluxio.table.common.transform.TransformContext
Creates an instance.
TransformDefinition - Class in alluxio.table.common.transform
The definition of a transformation.
TRANSFORMED_LAYOUTS_FIELD_NUMBER - Static variable in class alluxio.proto.journal.Table.AddTransformJobInfoEntry
 
TRANSFORMED_LAYOUTS_FIELD_NUMBER - Static variable in class alluxio.proto.journal.Table.CompleteTransformTableEntry
 
TransformJobInfo - Class in alluxio.grpc.table
Protobuf type alluxio.grpc.table.TransformJobInfo
TransformJobInfo - Class in alluxio.master.table.transform
Information kept for a transformation job.
TransformJobInfo(String, String, String, long, Map<String, Layout>) - Constructor for class alluxio.master.table.transform.TransformJobInfo
The default job status on construction is Status.RUNNING.
TransformJobInfo.Builder - Class in alluxio.grpc.table
Protobuf type alluxio.grpc.table.TransformJobInfo
TransformJobInfoOrBuilder - Interface in alluxio.grpc.table
 
TransformManager - Class in alluxio.master.table.transform
Manages transformations.
TransformManager(TransformManager.ThrowingSupplier<JournalContext, UnavailableException>, AlluxioCatalog, JobMasterClient) - Constructor for class alluxio.master.table.transform.TransformManager
An internal job master client will be created.
TransformManager.ThrowingSupplier<R,E extends Throwable> - Interface in alluxio.master.table.transform
A supplier with return type R that might throw exception E.
TransformPlan - Class in alluxio.table.common.transform
The plan for a transformation.
TransformPlan(Layout, Layout, TransformDefinition) - Constructor for class alluxio.table.common.transform.TransformPlan
A list of jobs will be computed based on the provided transform definition.
TransformStatusCommand - Class in alluxio.cli.table.command
Check transformation status.
TransformStatusCommand(AlluxioConfiguration, TableMasterClient) - Constructor for class alluxio.cli.table.command.TransformStatusCommand
creates the command.
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) - 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.TableMasterClientServiceImplBase
 
transformTable(TransformTablePRequest, StreamObserver<TransformTablePResponse>) - Method in class alluxio.grpc.table.TableMasterClientServiceGrpc.TableMasterClientServiceStub
 
transformTable(String, String, String) - Method in class alluxio.master.table.DefaultTableMaster
 
transformTable(String, String, String) - Method in interface alluxio.master.table.TableMaster
Transforms a table to a new table.
transformTable(TransformTablePRequest, StreamObserver<TransformTablePResponse>) - Method in class alluxio.master.table.TableMasterClientServiceHandler
 
TransformTableCommand - Class in alluxio.cli.table.command
Transforms a structured table in Alluxio.
TransformTableCommand(AlluxioConfiguration, TableMasterClient) - Constructor for class alluxio.cli.table.command.TransformTableCommand
creates the command.
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
 
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.
translatePosixPermissionToMode(Set<PosixFilePermission>) - Static method in class alluxio.util.io.FileUtils
Translate posix file permissions to short mode.
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.
TrieNode - Class in alluxio.conf.path
A node in a trie.
TrieNode() - Constructor for class alluxio.conf.path.TrieNode
 
TRIGGERED_EMBEDDED_CHECKPOINT - Static variable in class alluxio.multi.process.PortCoordination
 
TRIGGERED_UFS_CHECKPOINT - Static variable in class alluxio.multi.process.PortCoordination
 
truncate(String, long) - Method in class alluxio.fuse.AlluxioFuseFileSystem
Changes the size of a file.
TRY_CACHE_VALUE - Static variable in enum alluxio.grpc.WritePType
TRY_CACHE = 2;
tryAcquirePersistingLock(long) - Method in class alluxio.master.file.meta.InodeLockManager
Tries to acquire a lock for persisting the specified inode id.
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.
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.
tryUnfork() - Method in class alluxio.concurrent.jsr.ForkJoinTask
Tries to unschedule this task for execution.
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
 
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.
TX_ID_FIELD_NUMBER - Static variable in class alluxio.proto.journal.File.ActiveSyncTxIdEntry
 
TYPE - Static variable in class alluxio.table.common.layout.HiveLayout
 
TYPE - Static variable in class alluxio.table.under.hive.HiveDatabaseFactory
 
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.shared.Acl.AclEntry
 

U

UDB_CONNECTION_URI_FIELD_NUMBER - Static variable in class alluxio.grpc.table.AttachDatabasePRequest
 
UDB_CONNECTION_URI_FIELD_NUMBER - Static variable in class alluxio.proto.journal.Table.AttachDbEntry
 
UDB_DB_NAME_FIELD_NUMBER - Static variable in class alluxio.grpc.table.AttachDatabasePRequest
 
UDB_DB_NAME_FIELD_NUMBER - Static variable in class alluxio.proto.journal.Table.AttachDbEntry
 
UDB_TYPE_FIELD_NUMBER - Static variable in class alluxio.grpc.table.AttachDatabasePRequest
 
UDB_TYPE_FIELD_NUMBER - Static variable in class alluxio.proto.journal.Table.AttachDbEntry
 
UdbConfiguration - Class in alluxio.table.common.udb
This represents a configuration of the UDB.
UdbConfiguration(Map<String, String>) - Constructor for class alluxio.table.common.udb.UdbConfiguration
Creates an instance.
UdbContext - Class in alluxio.table.common.udb
The context for the udb.
UdbContext(UnderDatabaseRegistry, FileSystem, String, String, String, String) - Constructor for class alluxio.table.common.udb.UdbContext
Creates an instance.
UdbPartition - Interface in alluxio.table.common
A representation of a table partition in the udb.
UdbProperty - Class in alluxio.table.common.udb
This represents a property name and default value for the UDB.
UdbProperty(String, String, String) - Constructor for class alluxio.table.common.udb.UdbProperty
Creates an instance.
UdbTable - Interface in alluxio.table.common.udb
The interface for the underdb table.
UFS_FALLBACK_BLOCK_VALUE - Static variable in enum alluxio.grpc.RequestType
UFS_FALLBACK_BLOCK = 2;
UFS_FILE_VALUE - Static variable in enum alluxio.grpc.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_HADOOP_VERSION - Static variable in class alluxio.UfsConstants
 
UFS_INPUT_STREAM_CACHE_EXPIRATION - Static variable in class alluxio.Constants
 
UFS_OP_PREFIX - Static variable in class alluxio.metrics.MetricInfo
 
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
 
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.
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.command
Update attributes for an existing mount point.
UfsCommand(Context, AlluxioConfiguration) - Constructor for class alluxio.cli.fsadmin.command.UfsCommand
 
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.validation
Task for validating whether UFS directory is accessible.
UfsDirectoryValidationTask() - Constructor for class alluxio.cli.validation.UfsDirectoryValidationTask
Creates a new instance of UfsDirectoryValidationTask for validating root under file system.
UfsFallbackBlockWriteHandler - Class in alluxio.worker.grpc
This handler handles UFS block write request.
UfsFallbackLocalFileDataWriter - Class in alluxio.client.block.stream
A data writer that writes to local first and fallback to UFS block writes when the block storage on this local worker is full.
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
UfsFileStatus(String, String, long, long, String, String, short) - Constructor for class alluxio.underfs.UfsFileStatus
UfsFileStatus(UfsFileStatus) - Constructor for class alluxio.underfs.UfsFileStatus
Creates a new instance of UfsFileStatus as a copy.
UfsFileWriteHandler - Class in alluxio.worker.grpc
This handler handles writes to a file in the under file system.
UfsFileWriteRequest - Class in alluxio.worker.grpc
The UFS File write request internal representation.
UfsFileWriteRequestContext - Class in alluxio.worker.grpc
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
 
UfsInputStreamManager - Class in alluxio.worker.block
An under filesystem input stream manager that can cache seekable input streams for future reuse.
UfsInputStreamManager() - Constructor for class alluxio.worker.block.UfsInputStreamManager
Creates a new UfsInputStreamManager.
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.
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.
UfsJournalReader - Class in alluxio.master.journal.ufs
Implementation of JournalReader that reads journal entries from a UFS.
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.
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
 
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
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.
UFSSTRINGLOCATIONS_FIELD_NUMBER - Static variable in class alluxio.grpc.FileBlockInfo
 
UfsSuperUserValidationTask - Class in alluxio.cli.validation
Task for validating whether Alluxio can access UFS as super user.
UfsSuperUserValidationTask() - Constructor for class alluxio.cli.validation.UfsSuperUserValidationTask
Creates a new instance of UfsSuperUserValidationTask for validating root 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
This cache maintains the Alluxio paths which have been synced with UFS.
UfsSyncPathCache() - 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.MountPointInfo
 
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
 
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.
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.
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
 
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
 
UNCHECKED_FIELD_NUMBER - Static variable in class alluxio.grpc.DeletePOptions
 
UnderDatabase - Interface in alluxio.table.common.udb
The database interface.
UnderDatabaseFactory - Interface in alluxio.table.common.udb
The under database factory interface.
UnderDatabaseRegistry - Class in alluxio.table.common.udb
The registry of under database implementations.
UnderDatabaseRegistry() - Constructor for class alluxio.table.common.udb.UnderDatabaseRegistry
Creates an instance.
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.
UnderFileSystemBlockMeta - Class in alluxio.worker.block.meta
This class represents the metadata of a block that is in UFS.
UnderFileSystemBlockMeta(long, long, Protocol.OpenUfsBlockOptions) - Constructor for class alluxio.worker.block.meta.UnderFileSystemBlockMeta
Creates an instance of UnderFileSystemBlockMeta.
UnderFileSystemBlockReader - Class in alluxio.worker.block
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.
UnderFileSystemBlockStore - Class in alluxio.worker.block
This class manages the virtual blocks in the UFS for delegated UFS reads/writes.
UnderFileSystemBlockStore(BlockStore, UfsManager) - Constructor for class alluxio.worker.block.UnderFileSystemBlockStore
Creates an instance of UnderFileSystemBlockStore.
UnderFileSystemCommonOperations - Class in alluxio.examples
Examples for under filesystem common operations.
UnderFileSystemCommonOperations(String, String, UnderFileSystem, InstancedConfiguration) - Constructor for class alluxio.examples.UnderFileSystemCommonOperations
 
UnderFileSystemConfiguration - Class in alluxio.underfs
Ufs configuration properties, including ufs specific configuration and global configuration.
UnderFileSystemContractTest - Class in alluxio.cli
Integration tests for Alluxio under filesystems.
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.
UnderFileSystemFileOutStream - Class in alluxio.client.block.stream
Provides a streaming API to write to a file in the under file system through an Alluxio worker's data server.
UnderFileSystemFileOutStream(DataWriter, WorkerNetAddress) - Constructor for class alluxio.client.block.stream.UnderFileSystemFileOutStream
Constructs a new UnderFileSystemFileOutStream with only one DataWriter.
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
UFS related properties.
UNDERFS_CLEANUP_ENABLED - Static variable in class alluxio.conf.PropertyKey.Name
 
UNDERFS_CLEANUP_ENABLED - Static variable in class alluxio.conf.PropertyKey
 
UNDERFS_CLEANUP_INTERVAL - Static variable in class alluxio.conf.PropertyKey.Name
 
UNDERFS_CLEANUP_INTERVAL - Static variable in class alluxio.conf.PropertyKey
 
UNDERFS_EVENTUAL_CONSISTENCY_RETRY_BASE_SLEEP_MS - Static variable in class alluxio.conf.PropertyKey.Name
 
UNDERFS_EVENTUAL_CONSISTENCY_RETRY_BASE_SLEEP_MS - Static variable in class alluxio.conf.PropertyKey
 
UNDERFS_EVENTUAL_CONSISTENCY_RETRY_MAX_NUM - Static variable in class alluxio.conf.PropertyKey.Name
 
UNDERFS_EVENTUAL_CONSISTENCY_RETRY_MAX_NUM - Static variable in class alluxio.conf.PropertyKey
 
UNDERFS_EVENTUAL_CONSISTENCY_RETRY_MAX_SLEEP_MS - Static variable in class alluxio.conf.PropertyKey.Name
 
UNDERFS_EVENTUAL_CONSISTENCY_RETRY_MAX_SLEEP_MS - Static variable in class alluxio.conf.PropertyKey
 
UNDERFS_GCS_DEFAULT_MODE - Static variable in class alluxio.conf.PropertyKey.Name
 
UNDERFS_GCS_DEFAULT_MODE - Static variable in class alluxio.conf.PropertyKey
 
UNDERFS_GCS_DIRECTORY_SUFFIX - Static variable in class alluxio.conf.PropertyKey.Name
 
UNDERFS_GCS_DIRECTORY_SUFFIX - Static variable in class alluxio.conf.PropertyKey
 
UNDERFS_GCS_OWNER_ID_TO_USERNAME_MAPPING - Static variable in class alluxio.conf.PropertyKey.Name
 
UNDERFS_GCS_OWNER_ID_TO_USERNAME_MAPPING - Static variable in class alluxio.conf.PropertyKey
 
UNDERFS_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_KODO_CONNECT_TIMEOUT - Static variable in class alluxio.conf.PropertyKey.Name
 
UNDERFS_KODO_CONNECT_TIMEOUT - Static variable in class alluxio.conf.PropertyKey
 
UNDERFS_KODO_REQUESTS_MAX - Static variable in class alluxio.conf.PropertyKey.Name
 
UNDERFS_KODO_REQUESTS_MAX - Static variable in class alluxio.conf.PropertyKey
 
UNDERFS_LISTING_LENGTH - Static variable in class alluxio.conf.PropertyKey.Name
 
UNDERFS_LISTING_LENGTH - Static variable in class alluxio.conf.PropertyKey
 
UNDERFS_OBJECT_STORE_BREADCRUMBS_ENABLED - Static variable in class alluxio.conf.PropertyKey.Name
 
UNDERFS_OBJECT_STORE_BREADCRUMBS_ENABLED - Static variable in class alluxio.conf.PropertyKey
 
UNDERFS_OBJECT_STORE_MOUNT_SHARED_PUBLICLY - Static variable in class alluxio.conf.PropertyKey.Name
 
UNDERFS_OBJECT_STORE_MOUNT_SHARED_PUBLICLY - Static variable in class alluxio.conf.PropertyKey
 
UNDERFS_OBJECT_STORE_MULTI_RANGE_CHUNK_SIZE - Static variable in class alluxio.conf.PropertyKey.Name
 
UNDERFS_OBJECT_STORE_MULTI_RANGE_CHUNK_SIZE - Static variable in class alluxio.conf.PropertyKey
 
UNDERFS_OBJECT_STORE_SERVICE_THREADS - Static variable in class alluxio.conf.PropertyKey.Name
 
UNDERFS_OBJECT_STORE_SERVICE_THREADS - Static variable in class alluxio.conf.PropertyKey
 
UNDERFS_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_SOCKET_TIMEOUT - Static variable in class alluxio.conf.PropertyKey.Name
 
UNDERFS_OSS_SOCKET_TIMEOUT - 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_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_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_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_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_VERSION - Static variable in class alluxio.conf.PropertyKey.Name
 
UNDERFS_VERSION - Static variable in class alluxio.conf.PropertyKey
 
UNDERFS_WEB_CONNECTION_TIMEOUT - Static variable in class alluxio.conf.PropertyKey.Name
 
UNDERFS_WEB_CONNECTION_TIMEOUT - Static variable in class alluxio.conf.PropertyKey
 
UNDERFS_WEB_HEADER_LAST_MODIFIED - Static variable in class alluxio.conf.PropertyKey.Name
 
UNDERFS_WEB_HEADER_LAST_MODIFIED - Static variable in class alluxio.conf.PropertyKey
 
UNDERFS_WEB_PARENT_NAMES - Static variable in class alluxio.conf.PropertyKey.Name
 
UNDERFS_WEB_PARENT_NAMES - Static variable in class alluxio.conf.PropertyKey
 
UNDERFS_WEB_TITLES - Static variable in class alluxio.conf.PropertyKey.Name
 
UNDERFS_WEB_TITLES - Static variable in class alluxio.conf.PropertyKey
 
UNDERSCORE - Static variable in class alluxio.underfs.Fingerprint
 
UnderStorageType - Enum in alluxio.client
Specifies the type of data interaction with Alluxio's Under Storage.
unescape(String) - Static method in class alluxio.metrics.MetricsSystem
Unescapes a URI, reverts it to before the escape, to display it correctly.
UnexpectedAlluxioException - Exception in alluxio.exception
The exception thrown when an unexpected error occurs within the Alluxio system.
UnexpectedAlluxioException(String) - Constructor for exception alluxio.exception.UnexpectedAlluxioException
Constructs a new exception with the specified detail message.
UnexpectedAlluxioException(Exception) - Constructor for exception alluxio.exception.UnexpectedAlluxioException
 
unfinishedTasks() - Method in class alluxio.worker.job.task.TaskExecutorManager
 
UNFINISHEDTASKS_FIELD_NUMBER - Static variable in class alluxio.grpc.JobWorkerHealth
 
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
 
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.
uniqPath() - Static method in class alluxio.util.io.PathUtils
Creates a unique path based off the caller.
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_HOSTNAME - Static variable in class alluxio.util.network.NetworkAddressUtils
 
UNKNOWN_INODES - Static variable in class alluxio.fuse.AlluxioFuseFileSystem
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.
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
 
unlink(String) - Method in class alluxio.fuse.AlluxioFuseFileSystem
Deletes a file from the FS.
unlockBlock(long) - Method in class alluxio.worker.block.BlockLockManager
Releases the lock with the specified lock id.
unlockBlock(long, long) - Method in class alluxio.worker.block.BlockLockManager
Releases the lock with the specified session and block id.
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.
unlockBlock(long) - Method in class alluxio.worker.block.DefaultBlockWorker
 
unlockBlock(long, long) - Method in class alluxio.worker.block.DefaultBlockWorker
 
unlockBlock(long) - Method in class alluxio.worker.block.TieredBlockStore
 
unlockBlock(long, long) - Method in class alluxio.worker.block.TieredBlockStore
 
unlockBlockNoException(long) - Method in class alluxio.worker.block.BlockLockManager
Releases the lock with the specified lock 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
 
unmount(AlluxioURI, UnmountPOptions) - Method in class alluxio.client.file.BaseFileSystem
 
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(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.FileSystemMasterClientServiceImplBase
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, UnmountPOptions) - Method in class alluxio.hadoop.AlluxioHdfsFileSystem
 
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
 
UnmountCommand - Class in alluxio.cli.fs.command
Unmounts an Alluxio path.
UnmountCommand(FileSystemContext) - Constructor for class alluxio.cli.fs.command.UnmountCommand
 
unmountDefaults(AlluxioConfiguration) - Static method in class alluxio.util.FileSystemOptions
 
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
 
unpackToDirectory(Path) - Method in class alluxio.master.journal.checkpoint.TarballCheckpointFormat.TarballCheckpointReader
Unpacks the tarball data to the given path.
UnpartitionedTableScheme - Class in alluxio.master.table
Unpartitoned table scheme.
UnpartitionedTableScheme(List<Partition>) - Constructor for class alluxio.master.table.UnpartitionedTableScheme
Constructor for UnpartitionedTableScheme.
UnpinCommand - Class in alluxio.cli.fs.command
Unpins the given file or folder (recursively unpinning all children if a folder).
UnpinCommand(FileSystemContext) - Constructor for class alluxio.cli.fs.command.UnpinCommand
 
unregister(PropertyKey) - Static method in class alluxio.conf.PropertyKey
Unregisters the given key from the global key map.
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.
unregisterChannel(UUID) - Method in interface alluxio.security.authentication.AuthenticationServer
Unregisters given channel.
unregisterChannel(UUID) - Method in class alluxio.security.authentication.DefaultAuthenticationServer
 
UNSCALED_FIELD_NUMBER - Static variable in class alluxio.grpc.table.Decimal
 
unset(PropertyKey) - Method in class alluxio.conf.InstancedConfiguration
Unsets the value for the appropriate key in the Properties.
unset(PropertyKey) - Static method in class alluxio.conf.ServerConfiguration
Unsets the value for the appropriate key in the Properties.
UnsetTtlCommand - Class in alluxio.cli.fs.command
Unsets the TTL value for the given path.
UnsetTtlCommand(FileSystemContext) - Constructor for class alluxio.cli.fs.command.UnsetTtlCommand
 
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(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_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_DATABASE_INFO_FIELD_NUMBER - Static variable in class alluxio.proto.journal.Journal.JournalEntry
 
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.
updateBlockStoreLocation(long, BlockStoreLocation) - Method in class alluxio.worker.block.evictor.AbstractEvictor
Updates the block store location if the evictor wants to free space in a specific location.
updateBlockStoreLocation(long, BlockStoreLocation) - Method in class alluxio.worker.block.evictor.PartialLRUEvictor
 
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.master.meta
Check for updates.
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, String) - Method in class alluxio.multi.process.Master
Updates the master's configuration.
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.
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
 
UPDATELASTACCESSTIME_FIELD_NUMBER - Static variable in class alluxio.grpc.OpenFilePOptions
 
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.MasterInfo
Updates the last updated time of the master in ms.
updateLength(long) - Method in class alluxio.master.block.meta.MasterBlockInfo
Updates the length, if and only if the length was previously unknown.
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.BaseFileSystem
 
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(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.FileSystemMasterClientServiceImplBase
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, MountPOptions) - Method in class alluxio.hadoop.AlluxioHdfsFileSystem
 
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
 
UpdateMountCommand - Class in alluxio.cli.fs.command
Update options for an Alluxio mount point.
UpdateMountCommand(FileSystemContext) - Constructor for class alluxio.cli.fs.command.UpdateMountCommand
 
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.CacheEvictor
Updates evictor after a delete operation.
updateOnDelete(PageId) - Method in class alluxio.client.file.cache.evictor.LFUCacheEvictor
 
updateOnDelete(PageId) - Method in class alluxio.client.file.cache.evictor.LRUCacheEvictor
 
updateOnGet(PageId) - Method in interface alluxio.client.file.cache.CacheEvictor
Updates evictor after a get operation.
updateOnGet(PageId) - Method in class alluxio.client.file.cache.evictor.LFUCacheEvictor
 
updateOnGet(PageId) - Method in class alluxio.client.file.cache.evictor.LRUCacheEvictor
 
updateOnPut(PageId) - Method in interface alluxio.client.file.cache.CacheEvictor
Updates evictor after a put operation.
updateOnPut(PageId) - Method in class alluxio.client.file.cache.evictor.LFUCacheEvictor
 
updateOnPut(PageId) - Method in class alluxio.client.file.cache.evictor.LRUCacheEvictor
 
updatePinList(Set<Long>) - Method in interface alluxio.worker.block.BlockWorker
Sets the pinlist for the underlying block store.
updatePinList(Set<Long>) - Method in class alluxio.worker.block.DefaultBlockWorker
 
updatePinnedInodes(Set<Long>) - Method in interface alluxio.worker.block.BlockStore
Update the pinned inodes.
updatePinnedInodes(Set<Long>) - Method in class alluxio.worker.block.TieredBlockStore
Updates the pinned blocks.
updateState(BackupState) - Method in class alluxio.master.backup.BackupTracker
Updates the state of backup status.
updateStorageInfo() - Method in class alluxio.worker.block.SpaceReserver
Re-calculates storage spaces and watermarks.
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) - 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.FileSystemMasterClientServiceImplBase
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
 
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.
upgrade() - Method in class alluxio.master.journal.raft.JournalStateMachine
Upgrades the journal state machine to primary mode.
uploadFile(String, File) - Method in class alluxio.underfs.kodo.KodoClient
Puts Object to Qiniu kodo.
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
 
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.
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
 
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
 
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_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_RETRY_MAX_DURATION - Static variable in class alluxio.conf.PropertyKey.Name
 
USER_BLOCK_READ_RETRY_MAX_DURATION - Static variable in class alluxio.conf.PropertyKey
 
USER_BLOCK_READ_RETRY_SLEEP_MAX - Static variable in class alluxio.conf.PropertyKey.Name
 
USER_BLOCK_READ_RETRY_SLEEP_MAX - Static variable in class alluxio.conf.PropertyKey
 
USER_BLOCK_READ_RETRY_SLEEP_MIN - Static variable in class alluxio.conf.PropertyKey.Name
 
USER_BLOCK_READ_RETRY_SLEEP_MIN - Static variable in class alluxio.conf.PropertyKey
 
USER_BLOCK_REMOTE_READ_BUFFER_SIZE_BYTES - Static variable in class alluxio.conf.PropertyKey.Name
 
USER_BLOCK_REMOTE_READ_BUFFER_SIZE_BYTES - Static variable in class alluxio.conf.PropertyKey
 
USER_BLOCK_SIZE_BYTES_DEFAULT - Static variable in class alluxio.conf.PropertyKey.Name
 
USER_BLOCK_SIZE_BYTES_DEFAULT - Static variable in class alluxio.conf.PropertyKey
 
USER_BLOCK_WORKER_CLIENT_POOL_GC_THRESHOLD_MS - Static variable in class alluxio.conf.PropertyKey.Name
 
USER_BLOCK_WORKER_CLIENT_POOL_GC_THRESHOLD_MS - Static variable in class alluxio.conf.PropertyKey
 
USER_BLOCK_WORKER_CLIENT_POOL_MAX - Static variable in class alluxio.conf.PropertyKey.Name
 
USER_BLOCK_WORKER_CLIENT_POOL_MAX - Static variable in class alluxio.conf.PropertyKey
 
USER_BLOCK_WORKER_CLIENT_POOL_MIN - Static variable in class alluxio.conf.PropertyKey.Name
 
USER_BLOCK_WORKER_CLIENT_POOL_MIN - Static variable in class alluxio.conf.PropertyKey
 
USER_BLOCK_WORKER_CLIENT_POOL_SIZE - Static variable in class alluxio.conf.PropertyKey.Name
 
USER_BLOCK_WORKER_CLIENT_READ_RETRY - Static variable in class alluxio.conf.PropertyKey.Name
 
USER_BLOCK_WRITE_LOCATION_POLICY - Static variable in class alluxio.conf.PropertyKey.Name
 
USER_BLOCK_WRITE_LOCATION_POLICY - Static variable in class alluxio.conf.PropertyKey
 
USER_CLIENT_CACHE_ASYNC_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_DIR - Static variable in class alluxio.conf.PropertyKey.Name
 
USER_CLIENT_CACHE_DIR - 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_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_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_SIZE - Static variable in class alluxio.conf.PropertyKey.Name
 
USER_CLIENT_CACHE_SIZE - 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_COMPONENT - Static variable in enum alluxio.security.authorization.AclEntryType
 
USER_CONF_CLUSTER_DEFAULT_ENABLED - Static variable in class alluxio.conf.PropertyKey.Name
 
USER_CONF_CLUSTER_DEFAULT_ENABLED - Static variable in class alluxio.conf.PropertyKey
 
USER_CONF_SYNC_INTERVAL - Static variable in class alluxio.conf.PropertyKey.Name
 
USER_CONF_SYNC_INTERVAL - Static variable in class alluxio.conf.PropertyKey
 
USER_DATE_FORMAT_PATTERN - Static variable in class alluxio.conf.PropertyKey.Name
 
USER_DATE_FORMAT_PATTERN - Static variable in class alluxio.conf.PropertyKey
 
USER_FIELD_NUMBER - Static variable in class alluxio.proto.dataserver.Protocol.OpenUfsBlockOptions
 
USER_FILE_BUFFER_BYTES - Static variable in class alluxio.conf.PropertyKey.Name
 
USER_FILE_BUFFER_BYTES - Static variable in class alluxio.conf.PropertyKey
 
USER_FILE_COPYFROMLOCAL_BLOCK_LOCATION_POLICY - Static variable in class alluxio.conf.PropertyKey.Name
 
USER_FILE_COPYFROMLOCAL_BLOCK_LOCATION_POLICY - Static variable in class alluxio.conf.PropertyKey
 
USER_FILE_CREATE_TTL - Static variable in class alluxio.conf.PropertyKey.Name
 
USER_FILE_CREATE_TTL - Static variable in class alluxio.conf.PropertyKey
 
USER_FILE_CREATE_TTL_ACTION - Static variable in class alluxio.conf.PropertyKey.Name
 
USER_FILE_CREATE_TTL_ACTION - Static variable in class alluxio.conf.PropertyKey
 
USER_FILE_DELETE_UNCHECKED - Static variable in class alluxio.conf.PropertyKey.Name
 
USER_FILE_DELETE_UNCHECKED - Static variable in class alluxio.conf.PropertyKey
 
USER_FILE_MASTER_CLIENT_POOL_GC_INTERVAL_MS - Static variable in class alluxio.conf.PropertyKey.Name
 
USER_FILE_MASTER_CLIENT_POOL_GC_INTERVAL_MS - Static variable in class alluxio.conf.PropertyKey
 
USER_FILE_MASTER_CLIENT_POOL_GC_THRESHOLD_MS - Static variable in class alluxio.conf.PropertyKey.Name
 
USER_FILE_MASTER_CLIENT_POOL_GC_THRESHOLD_MS - Static variable in class alluxio.conf.PropertyKey
 
USER_FILE_MASTER_CLIENT_POOL_SIZE_MAX - Static variable in class alluxio.conf.PropertyKey.Name
 
USER_FILE_MASTER_CLIENT_POOL_SIZE_MAX - Static variable in class alluxio.conf.PropertyKey
 
USER_FILE_MASTER_CLIENT_POOL_SIZE_MIN - Static variable in class alluxio.conf.PropertyKey.Name
 
USER_FILE_MASTER_CLIENT_POOL_SIZE_MIN - Static variable in class alluxio.conf.PropertyKey
 
USER_FILE_METADATA_LOAD_TYPE - Static variable in class alluxio.conf.PropertyKey.Name
 
USER_FILE_METADATA_LOAD_TYPE - Static variable in class alluxio.conf.PropertyKey
 
USER_FILE_METADATA_SYNC_INTERVAL - Static variable in class alluxio.conf.PropertyKey.Name
 
USER_FILE_METADATA_SYNC_INTERVAL - Static variable in class alluxio.conf.PropertyKey
 
USER_FILE_PASSIVE_CACHE_ENABLED - Static variable in class alluxio.conf.PropertyKey.Name
 
USER_FILE_PASSIVE_CACHE_ENABLED - Static variable in class alluxio.conf.PropertyKey
 
USER_FILE_PERSIST_ON_RENAME - Static variable in class alluxio.conf.PropertyKey.Name
 
USER_FILE_PERSIST_ON_RENAME - Static variable in class alluxio.conf.PropertyKey
 
USER_FILE_PERSISTENCE_INITIAL_WAIT_TIME - Static variable in class alluxio.conf.PropertyKey.Name
 
USER_FILE_PERSISTENCE_INITIAL_WAIT_TIME - Static variable in class alluxio.conf.PropertyKey
 
USER_FILE_READ_TYPE_DEFAULT - Static variable in class alluxio.conf.PropertyKey.Name
 
USER_FILE_READ_TYPE_DEFAULT - Static variable in class alluxio.conf.PropertyKey
 
USER_FILE_REPLICATION_DURABLE - Static variable in class alluxio.conf.PropertyKey.Name
 
USER_FILE_REPLICATION_DURABLE - Static variable in class alluxio.conf.PropertyKey
 
USER_FILE_REPLICATION_MAX - Static variable in class alluxio.conf.PropertyKey.Name
 
USER_FILE_REPLICATION_MAX - Static variable in class alluxio.conf.PropertyKey
 
USER_FILE_REPLICATION_MIN - Static variable in class alluxio.conf.PropertyKey.Name
 
USER_FILE_REPLICATION_MIN - Static variable in class alluxio.conf.PropertyKey
 
USER_FILE_SEQUENTIAL_PREAD_THRESHOLD - Static variable in class alluxio.conf.PropertyKey.Name
 
USER_FILE_SEQUENTIAL_PREAD_THRESHOLD - Static variable in class alluxio.conf.PropertyKey
 
USER_FILE_UFS_TIER_ENABLED - Static variable in class alluxio.conf.PropertyKey.Name
 
USER_FILE_UFS_TIER_ENABLED - Static variable in class alluxio.conf.PropertyKey
 
USER_FILE_WAITCOMPLETED_POLL_MS - Static variable in class alluxio.conf.PropertyKey.Name
 
USER_FILE_WAITCOMPLETED_POLL_MS - Static variable in class alluxio.conf.PropertyKey
 
USER_FILE_WRITE_TIER_DEFAULT - Static variable in class alluxio.conf.PropertyKey.Name
 
USER_FILE_WRITE_TIER_DEFAULT - Static variable in class alluxio.conf.PropertyKey
 
USER_FILE_WRITE_TYPE_DEFAULT - Static variable in class alluxio.conf.PropertyKey.Name
 
USER_FILE_WRITE_TYPE_DEFAULT - Static variable in class alluxio.conf.PropertyKey
 
USER_HOSTNAME - Static variable in class alluxio.conf.PropertyKey.Name
 
USER_HOSTNAME - Static variable in class alluxio.conf.PropertyKey
 
USER_LOCAL_READER_CHUNK_SIZE_BYTES - Static variable in class alluxio.conf.PropertyKey.Name
 
USER_LOCAL_READER_CHUNK_SIZE_BYTES - Static variable in class alluxio.conf.PropertyKey
 
USER_LOCAL_WRITER_CHUNK_SIZE_BYTES - Static variable in class alluxio.conf.PropertyKey.Name
 
USER_LOCAL_WRITER_CHUNK_SIZE_BYTES - Static variable in class alluxio.conf.PropertyKey
 
USER_LOGS_DIR - Static variable in class alluxio.conf.PropertyKey.Name
 
USER_LOGS_DIR - Static variable in class alluxio.conf.PropertyKey
 
USER_METADATA_CACHE_ENABLED - Static variable in class alluxio.conf.PropertyKey.Name
 
USER_METADATA_CACHE_ENABLED - 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_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_WORKER_THREADS - Static variable in class alluxio.conf.PropertyKey.Name
 
USER_NETWORK_NETTY_WORKER_THREADS - 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_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_SHORT_CIRCUIT_ENABLED - Static variable in class alluxio.conf.PropertyKey.Name
 
USER_SHORT_CIRCUIT_ENABLED - Static variable in class alluxio.conf.PropertyKey
 
USER_SHORT_CIRCUIT_PREFERRED - Static variable in class alluxio.conf.PropertyKey.Name
 
USER_SHORT_CIRCUIT_PREFERRED - Static variable in class alluxio.conf.PropertyKey
 
USER_STREAMING_DATA_TIMEOUT - Static variable in class alluxio.conf.PropertyKey.Name
 
USER_STREAMING_DATA_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_WRITER_BUFFER_SIZE_MESSAGES - Static variable in class alluxio.conf.PropertyKey.Name
 
USER_STREAMING_WRITER_BUFFER_SIZE_MESSAGES - Static variable in class alluxio.conf.PropertyKey
 
USER_STREAMING_WRITER_CHUNK_SIZE_BYTES - Static variable in class alluxio.conf.PropertyKey.Name
 
USER_STREAMING_WRITER_CHUNK_SIZE_BYTES - Static variable in class alluxio.conf.PropertyKey
 
USER_STREAMING_WRITER_CLOSE_TIMEOUT - Static variable in class alluxio.conf.PropertyKey.Name
 
USER_STREAMING_WRITER_CLOSE_TIMEOUT - Static variable in class alluxio.conf.PropertyKey
 
USER_STREAMING_WRITER_FLUSH_TIMEOUT - Static variable in class alluxio.conf.PropertyKey.Name
 
USER_STREAMING_WRITER_FLUSH_TIMEOUT - Static variable in class alluxio.conf.PropertyKey
 
USER_STREAMING_ZEROCOPY_ENABLED - Static variable in class alluxio.conf.PropertyKey.Name
 
USER_STREAMING_ZEROCOPY_ENABLED - Static variable in class alluxio.conf.PropertyKey
 
USER_UFS_BLOCK_LOCATION_ALL_FALLBACK_ENABLED - Static variable in class alluxio.conf.PropertyKey.Name
 
USER_UFS_BLOCK_LOCATION_ALL_FALLBACK_ENABLED - Static variable in class alluxio.conf.PropertyKey
 
USER_UFS_BLOCK_READ_CONCURRENCY_MAX - Static variable in class alluxio.conf.PropertyKey.Name
 
USER_UFS_BLOCK_READ_CONCURRENCY_MAX - Static variable in class alluxio.conf.PropertyKey
 
USER_UFS_BLOCK_READ_LOCATION_POLICY - Static variable in class alluxio.conf.PropertyKey.Name
 
USER_UFS_BLOCK_READ_LOCATION_POLICY - Static variable in class alluxio.conf.PropertyKey
 
USER_UFS_BLOCK_READ_LOCATION_POLICY_DETERMINISTIC_HASH_SHARDS - Static variable in class alluxio.conf.PropertyKey.Name
 
USER_UFS_BLOCK_READ_LOCATION_POLICY_DETERMINISTIC_HASH_SHARDS - Static variable in class alluxio.conf.PropertyKey
 
USER_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
 
USERACTIONS_FIELD_NUMBER - Static variable in class alluxio.proto.shared.Acl.AccessControlList
 
useRawValue(boolean) - Method in class alluxio.conf.ConfigurationValueOptions
 
userKeySet() - Method in interface alluxio.conf.AlluxioConfiguration
 
userKeySet() - Method in class alluxio.conf.AlluxioProperties
 
userKeySet() - Method in class alluxio.conf.InstancedConfiguration
 
userKeySet() - Method in class alluxio.conf.path.SpecificPathConfiguration
 
UserLimitValidationTask - Class in alluxio.cli.validation
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.cli.validation
Utilities for validating Alluxio environment.
Utils - Class in alluxio.master.backcompat
Util methods.
Utils - Class in alluxio.multi.process
Utility methods for external test cluster classes.
utimens(String, Timespec[]) - Method in class alluxio.fuse.AlluxioFuseFileSystem
Alluxio does not have access time, and the file is created only once.

V

validate(String...) - Static method in class alluxio.cli.ValidateEnv
Validates environment.
validate(Map<String, String>) - Method in class alluxio.cli.validation.ClusterConfConsistencyValidationTask
 
validate(Map<String, String>) - Method in class alluxio.cli.validation.HdfsValidationTask
 
validate(Map<String, String>) - Method in class alluxio.cli.validation.PortAvailabilityValidationTask
 
validate(Map<String, String>) - Method in class alluxio.cli.validation.RamDiskMountPrivilegeValidationTask
 
validate(Map<String, String>) - Method in class alluxio.cli.validation.SecureHdfsValidationTask
 
validate(Map<String, String>) - Method in class alluxio.cli.validation.SshValidationTask
 
validate(Map<String, String>) - Method in class alluxio.cli.validation.StorageSpaceValidationTask
 
validate(Map<String, String>) - Method in class alluxio.cli.validation.UfsDirectoryValidationTask
 
validate(Map<String, String>) - Method in class alluxio.cli.validation.UfsSuperUserValidationTask
 
validate(Map<String, String>) - Method in class alluxio.cli.validation.UserLimitValidationTask
 
validate(Map<String, String>) - Method in interface alluxio.cli.validation.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.conf.path.SpecificPathConfiguration
 
validate() - Method in class alluxio.master.journal.raft.RaftJournalConfiguration
Validates the configuration.
validate() - Method in class alluxio.worker.block.BlockLockManager
Checks the internal state of the manager to make sure invariants hold.
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.CheckConsistencyCommand
 
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.CopyFromLocalCommand
 
validateArgs(CommandLine) - Method in class alluxio.cli.fs.command.CopyToLocalCommand
 
validateArgs(CommandLine) - Method in class alluxio.cli.fs.command.CountCommand
 
validateArgs(CommandLine) - Method in class alluxio.cli.fs.command.CpCommand
 
validateArgs(CommandLine) - Method in class alluxio.cli.fs.command.DistributedCpCommand
 
validateArgs(CommandLine) - Method in class alluxio.cli.fs.command.DistributedLoadCommand
 
validateArgs(CommandLine) - Method in class alluxio.cli.fs.command.DistributedMvCommand
 
validateArgs(CommandLine) - Method in class alluxio.cli.fs.command.DuCommand
 
validateArgs(CommandLine) - Method in class alluxio.cli.fs.command.FreeCommand
 
validateArgs(CommandLine) - Method in class alluxio.cli.fs.command.GetCapacityBytesCommand
 
validateArgs(CommandLine) - Method in class alluxio.cli.fs.command.GetFaclCommand
 
validateArgs(CommandLine) - Method in class alluxio.cli.fs.command.GetSyncPathListCommand
 
validateArgs(CommandLine) - Method in class alluxio.cli.fs.command.GetUsedBytesCommand
 
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.LeaderCommand
 
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.MasterInfoCommand
 
validateArgs(CommandLine) - Method in class alluxio.cli.fs.command.MkdirCommand
 
validateArgs(CommandLine) - Method in class alluxio.cli.fs.command.MountCommand
 
validateArgs(CommandLine) - Method in class alluxio.cli.fs.command.MvCommand
 
validateArgs(CommandLine) - Method in class alluxio.cli.fs.command.PersistCommand
 
validateArgs(CommandLine) - Method in class alluxio.cli.fs.command.PinCommand
 
validateArgs(CommandLine) - Method in class alluxio.cli.fs.command.RmCommand
 
validateArgs(CommandLine) - Method in class alluxio.cli.fs.command.SetFaclCommand
 
validateArgs(CommandLine) - Method in class alluxio.cli.fs.command.SetReplicationCommand
 
validateArgs(CommandLine) - Method in class alluxio.cli.fs.command.SetTtlCommand
 
validateArgs(CommandLine) - Method in class alluxio.cli.fs.command.StartSyncCommand
 
validateArgs(CommandLine) - Method in class alluxio.cli.fs.command.StatCommand
 
validateArgs(CommandLine) - Method in class alluxio.cli.fs.command.StopSyncCommand
 
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.fs.command.UnmountCommand
 
validateArgs(CommandLine) - Method in class alluxio.cli.fs.command.UnpinCommand
 
validateArgs(CommandLine) - Method in class alluxio.cli.fs.command.UnsetTtlCommand
 
validateArgs(CommandLine) - Method in class alluxio.cli.fs.command.UpdateMountCommand
 
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.GetBlockInfoCommand
 
validateArgs(CommandLine) - Method in class alluxio.cli.fsadmin.command.ReportCommand
 
validateArgs(CommandLine) - Method in class alluxio.cli.fsadmin.command.UfsCommand
 
validateArgs(CommandLine) - Method in class alluxio.cli.fsadmin.journal.CheckpointCommand
 
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(CommandLine) - Method in class alluxio.cli.fsadmin.pathconf.AddCommand
 
validateArgs(CommandLine) - Method in class alluxio.cli.fsadmin.pathconf.ListCommand
 
validateArgs(CommandLine) - Method in class alluxio.cli.fsadmin.pathconf.RemoveCommand
 
validateArgs(CommandLine) - Method in class alluxio.cli.fsadmin.pathconf.ShowCommand
 
validateArgs(CommandLine) - Method in class alluxio.cli.job.command.CancelCommand
 
validateArgs(CommandLine) - Method in class alluxio.cli.job.command.LeaderCommand
 
validateArgs(CommandLine) - Method in class alluxio.cli.job.command.ListCommand
 
validateArgs(CommandLine) - Method in class alluxio.cli.job.command.StatCommand
 
validateArgs(CommandLine) - Method in class alluxio.cli.table.command.AbstractTableCommand
 
validateArgs(CommandLine) - Method in class alluxio.cli.table.command.AttachDatabaseCommand
 
validateArgs(CommandLine) - Method in class alluxio.cli.table.command.DetachDatabaseCommand
 
validateArgs(CommandLine) - Method in class alluxio.cli.table.command.ListDatabasesCommand
 
validateArgs(CommandLine) - Method in class alluxio.cli.table.command.SyncDatabaseCommand
 
validateArgs(CommandLine) - Method in class alluxio.cli.table.command.TransformStatusCommand
 
validateArgs(CommandLine) - Method in class alluxio.cli.table.command.TransformTableCommand
 
validateBlocks(Function<Long, Boolean>, boolean) - Method in interface alluxio.master.block.BlockMaster
Validates the integrity of blocks with respect to the validator.
validateBlocks(Function<Long, Boolean>, boolean) - Method in class alluxio.master.block.DefaultBlockMaster
 
ValidateConf - Class in alluxio.cli
Validate the Alluxio configuration.
ValidateEnv - Class in alluxio.cli
Utility for checking Alluxio environment.
validateFsUri(URI) - Method in class alluxio.hadoop.AbstractFileSystem
Validates given FS base URI for scheme and authority.
validateFsUri(URI) - Method in class alluxio.hadoop.FileSystem
 
validateInodeBlocks(boolean) - Method in class alluxio.master.file.DefaultFileSystemMaster
 
validateInodeBlocks(boolean) - Method in interface alluxio.master.file.FileSystemMaster
Checks the integrity of the inodes with respect to the blocks of the system.
validateLock(long, long, long) - Method in class alluxio.worker.block.BlockLockManager
Validates the lock is hold by the given session for the given block.
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.
ValidationTask - Interface in alluxio.cli.validation
Interface for a validation task run by validateEnv command.
ValidationTask.TaskResult - Enum in alluxio.cli.validation
Result of a validation task.
Value(FileSystem, int) - Constructor for class alluxio.client.file.FileSystemCache.Value
 
Value - Class in alluxio.grpc.table
Protobuf type alluxio.grpc.table.Value
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.LocalityTier
 
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
 
valueAsString(String) - Static method in class alluxio.util.ConfigurationUtils
 
valueOf(String) - Static method in enum alluxio.checker.CheckerUtils.Status
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum alluxio.checker.HiveIntegrationChecker.Mode
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.validation.ValidationTask.TaskResult
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.block.stream.BlockInStream.BlockInStreamSource
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.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.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.file.options.DescendantType
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.GrpcNetworkGroup
Returns the enum constant of this type with the specified name.
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.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.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.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.job.plan.PlanDefinitionRegistry
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum alluxio.job.plan.transform.Format
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.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.PersistJob.CancelState
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.raft.RaftJournalConfiguration.StorageLevel
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.PrimarySelector.State
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum alluxio.master.PrimarySelectorClient.ZookeeperConnectionErrorPolicy
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum alluxio.master.StateLockOptions.GraceMode
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.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.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.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.security.authentication.AuthType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum alluxio.security.authorization.AclAction
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum alluxio.security.authorization.AclEntryType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum alluxio.security.authorization.Mode.Bits
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum alluxio.time.ExponentialTimer.Result
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum alluxio.underfs.Fingerprint.Tag
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum alluxio.underfs.Fingerprint.Type
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum alluxio.underfs.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.network.NetworkAddressUtils.ServiceType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum alluxio.wire.BlockMasterInfo.BlockMasterInfoField
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum alluxio.wire.CommandType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum alluxio.wire.LoadMetadataType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum alluxio.wire.SyncPointInfo.SyncStatus
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum alluxio.worker.block.BlockLockType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum alluxio.worker.block.evictor.Evictor.Mode
Returns the enum constant of this type with the specified name.
ValueOrBuilder - Interface in alluxio.grpc.table
 
values() - Static method in enum alluxio.checker.CheckerUtils.Status
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum alluxio.checker.HiveIntegrationChecker.Mode
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.validation.ValidationTask.TaskResult
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.block.stream.BlockInStream.BlockInStreamSource
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.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.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.file.options.DescendantType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum alluxio.grpc.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.GrpcNetworkGroup
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.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.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.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.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.transform.Format
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.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.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.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.raft.RaftJournalConfiguration.StorageLevel
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.PrimarySelector.State
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum alluxio.master.PrimarySelectorClient.ZookeeperConnectionErrorPolicy
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum alluxio.master.StateLockOptions.GraceMode
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.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.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.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.security.authentication.AuthType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum alluxio.security.authorization.AclAction
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum alluxio.security.authorization.AclEntryType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum alluxio.security.authorization.Mode.Bits
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum alluxio.time.ExponentialTimer.Result
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum alluxio.underfs.Fingerprint.Tag
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum alluxio.underfs.Fingerprint.Type
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum alluxio.underfs.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.network.NetworkAddressUtils.ServiceType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum alluxio.wire.BlockMasterInfo.BlockMasterInfoField
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum alluxio.wire.CommandType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum alluxio.wire.LoadMetadataType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum alluxio.wire.SyncPointInfo.SyncStatus
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum alluxio.worker.block.BlockLockType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum alluxio.worker.block.evictor.Evictor.Mode
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
 
VARCHAR - Static variable in class alluxio.job.plan.transform.HiveConstants.Types
Hive varchar type.
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_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_CREATION_TIME_FIELD_NUMBER - Static variable in class alluxio.proto.journal.Table.AddTableEntry
 
VERSION_FIELD_NUMBER - Static variable in class alluxio.grpc.GetServiceVersionPResponse
 
VERSION_FIELD_NUMBER - Static variable in class alluxio.grpc.MasterInfo
 
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.proto.journal.Table.AddTableEntry
 
VERSION_FIELD_NUMBER - Static variable in class alluxio.proto.journal.Table.RemoveTableEntry
 
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(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.
waitForAndKillPrimaryMaster(int) - Method in class alluxio.multi.process.MultiProcessCluster
Kills the primary master.
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
 
waitForNewMaster(int) - Method in class alluxio.master.MultiMasterLocalAlluxioCluster
Waits for a new master to start until a timeout occurs.
WaitForOptions - Class in alluxio.util
waitForReady(int) - Method in class alluxio.logserver.AlluxioLogServerProcess
 
waitForReady(int) - Method in class alluxio.master.AlluxioSecondaryMaster
 
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>, WaitForOptions) - Static method in class alluxio.util.CommonUtils
Waits for an operation to return a non-null value with a specified timeout.
waitForState(PrimarySelector.State) - Method in class alluxio.master.AbstractPrimarySelector
 
waitForState(PrimarySelector.State) - Method in interface alluxio.master.PrimarySelector
Blocks until the primary selector enters the specified state.
waitForWorkersRegistered(int) - Method in class alluxio.master.AbstractLocalAlluxioCluster
Waits for all workers registered with master.
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_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 message 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.
WeakSafeReentrantReadWriteLock - Class in alluxio.concurrent
ReadWriteLock implementation whose read and write locks retain a reference back to this lock.
WeakSafeReentrantReadWriteLock() - Constructor for class alluxio.concurrent.WeakSafeReentrantReadWriteLock
Creates a new lock.
WEB_CORS_ENABLED - Static variable in class alluxio.conf.PropertyKey.Name
 
WEB_CORS_ENABLED - Static variable in class alluxio.conf.PropertyKey
 
WEB_FILE_INFO_ENABLED - Static variable in class alluxio.conf.PropertyKey.Name
 
WEB_FILE_INFO_ENABLED - Static variable in class alluxio.conf.PropertyKey
 
WEB_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_THREADS - Static variable in class alluxio.conf.PropertyKey.Name
 
WEB_THREADS - 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.
WEBUI_BLOCKINFO - Static variable in class alluxio.worker.AlluxioWorkerRestServiceHandler
 
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_INIT - Static variable in class alluxio.worker.AlluxioWorkerRestServiceHandler
 
WEBUI_LOGS - Static variable in class alluxio.master.meta.AlluxioMasterRestServiceHandler
 
WEBUI_LOGS - Static variable in class alluxio.worker.AlluxioWorkerRestServiceHandler
 
WEBUI_METRICS - Static variable in class alluxio.master.meta.AlluxioMasterRestServiceHandler
 
WEBUI_METRICS - Static variable in class alluxio.worker.AlluxioWorkerRestServiceHandler
 
WEBUI_OVERVIEW - Static variable in class alluxio.master.meta.AlluxioMasterRestServiceHandler
 
WEBUI_OVERVIEW - Static variable in class alluxio.worker.AlluxioWorkerRestServiceHandler
 
WEBUI_WORKERS - Static variable in class alluxio.master.meta.AlluxioMasterRestServiceHandler
 
WebUnderFileSystem - Class in alluxio.underfs.web
Web UnderFileSystem implementation.
WebUnderFileSystem(AlluxioURI, UnderFileSystemConfiguration) - Constructor for class alluxio.underfs.web.WebUnderFileSystem
Constructs a new WebUnderFileSystem.
WebUnderFileSystemFactory - Class in alluxio.underfs.web
Factory for creating WebUnderFileSystem.
WebUnderFileSystemFactory() - Constructor for class alluxio.underfs.web.WebUnderFileSystemFactory
Constructs a new WebUnderFileSystemFactory.
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_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
 
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
 
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, String>) - Constructor for class alluxio.multi.process.Worker
 
Worker - Interface in alluxio.worker
Interface of an Alluxio worker.
WORKER_ADDRESSES_VALUE - Static variable in enum alluxio.grpc.MasterInfoField
WORKER_ADDRESSES = 8;
WORKER_ALLOCATOR_CLASS - Static variable in class alluxio.conf.PropertyKey.Name
 
WORKER_ALLOCATOR_CLASS - Static variable in class alluxio.conf.PropertyKey
 
WORKER_ASYNC_CACHE_DUPLICATE_REQUESTS - Static variable in class alluxio.metrics.MetricKey.Name
 
WORKER_ASYNC_CACHE_DUPLICATE_REQUESTS - Static variable in class alluxio.metrics.MetricKey
 
WORKER_ASYNC_CACHE_FAILED_BLOCKS - Static variable in class alluxio.metrics.MetricKey.Name
 
WORKER_ASYNC_CACHE_FAILED_BLOCKS - Static variable in class alluxio.metrics.MetricKey
 
WORKER_ASYNC_CACHE_REMOTE_BLOCKS - Static variable in class alluxio.metrics.MetricKey.Name
 
WORKER_ASYNC_CACHE_REMOTE_BLOCKS - Static variable in class alluxio.metrics.MetricKey
 
WORKER_ASYNC_CACHE_REQUESTS - Static variable in class alluxio.metrics.MetricKey.Name
 
WORKER_ASYNC_CACHE_REQUESTS - Static variable in class alluxio.metrics.MetricKey
 
WORKER_ASYNC_CACHE_SUCCEEDED_BLOCKS - Static variable in class alluxio.metrics.MetricKey.Name
 
WORKER_ASYNC_CACHE_SUCCEEDED_BLOCKS - Static variable in class alluxio.metrics.MetricKey
 
WORKER_ASYNC_CACHE_UFS_BLOCKS - Static variable in class alluxio.metrics.MetricKey.Name
 
WORKER_ASYNC_CACHE_UFS_BLOCKS - Static variable in class alluxio.metrics.MetricKey
 
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_HEARTBEAT_TIMEOUT_MS - Static variable in class alluxio.conf.PropertyKey.Name
 
WORKER_BLOCK_HEARTBEAT_TIMEOUT_MS - Static variable in class alluxio.conf.PropertyKey
 
WORKER_BLOCK_MASTER_CLIENT_POOL_SIZE - Static variable in class alluxio.conf.PropertyKey.Name
 
WORKER_BLOCK_MASTER_CLIENT_POOL_SIZE - Static variable in class alluxio.conf.PropertyKey
 
WORKER_BLOCK_SYNC - Static variable in class alluxio.heartbeat.HeartbeatContext
 
WORKER_BLOCKS_ACCESSED - Static variable in class alluxio.metrics.MetricKey.Name
 
WORKER_BLOCKS_ACCESSED - Static variable in class alluxio.metrics.MetricKey
 
WORKER_BLOCKS_CACHED - Static variable in class alluxio.metrics.MetricKey.Name
 
WORKER_BLOCKS_CACHED - Static variable in class alluxio.metrics.MetricKey
 
WORKER_BLOCKS_CANCELLED - Static variable in class alluxio.metrics.MetricKey.Name
 
WORKER_BLOCKS_CANCELLED - Static variable in class alluxio.metrics.MetricKey
 
WORKER_BLOCKS_DELETED - Static variable in class alluxio.metrics.MetricKey.Name
 
WORKER_BLOCKS_DELETED - Static variable in class alluxio.metrics.MetricKey
 
WORKER_BLOCKS_EVICTED - Static variable in class alluxio.metrics.MetricKey.Name
 
WORKER_BLOCKS_EVICTED - Static variable in class alluxio.metrics.MetricKey
 
WORKER_BLOCKS_LOST - Static variable in class alluxio.metrics.MetricKey.Name
 
WORKER_BLOCKS_LOST - Static variable in class alluxio.metrics.MetricKey
 
WORKER_BLOCKS_PROMOTED - Static variable in class alluxio.metrics.MetricKey.Name
 
WORKER_BLOCKS_PROMOTED - Static variable in class alluxio.metrics.MetricKey
 
WORKER_BYTES_READ_ALLUXIO - Static variable in class alluxio.metrics.MetricKey.Name
 
WORKER_BYTES_READ_ALLUXIO - Static variable in class alluxio.metrics.MetricKey
 
WORKER_BYTES_READ_ALLUXIO_THROUGHPUT - Static variable in class alluxio.metrics.MetricKey.Name
 
WORKER_BYTES_READ_ALLUXIO_THROUGHPUT - Static variable in class alluxio.metrics.MetricKey
 
WORKER_BYTES_READ_DOMAIN - Static variable in class alluxio.metrics.MetricKey.Name
 
WORKER_BYTES_READ_DOMAIN - Static variable in class alluxio.metrics.MetricKey
 
WORKER_BYTES_READ_DOMAIN_THROUGHPUT - Static variable in class alluxio.metrics.MetricKey.Name
 
WORKER_BYTES_READ_DOMAIN_THROUGHPUT - Static variable in class alluxio.metrics.MetricKey
 
WORKER_BYTES_READ_UFS - Static variable in class alluxio.metrics.MetricKey.Name
 
WORKER_BYTES_READ_UFS - Static variable in class alluxio.metrics.MetricKey
 
WORKER_BYTES_READ_UFS_THROUGHPUT - Static variable in class alluxio.metrics.MetricKey.Name
 
WORKER_BYTES_READ_UFS_THROUGHPUT - Static variable in class alluxio.metrics.MetricKey
 
WORKER_BYTES_WRITTEN_ALLUXIO - Static variable in class alluxio.metrics.MetricKey.Name
 
WORKER_BYTES_WRITTEN_ALLUXIO - Static variable in class alluxio.metrics.MetricKey
 
WORKER_BYTES_WRITTEN_ALLUXIO_THROUGHPUT - Static variable in class alluxio.metrics.MetricKey.Name
 
WORKER_BYTES_WRITTEN_ALLUXIO_THROUGHPUT - Static variable in class alluxio.metrics.MetricKey
 
WORKER_BYTES_WRITTEN_DOMAIN - Static variable in class alluxio.metrics.MetricKey.Name
 
WORKER_BYTES_WRITTEN_DOMAIN - Static variable in class alluxio.metrics.MetricKey
 
WORKER_BYTES_WRITTEN_DOMAIN_THROUGHPUT - Static variable in class alluxio.metrics.MetricKey.Name
 
WORKER_BYTES_WRITTEN_DOMAIN_THROUGHPUT - Static variable in class alluxio.metrics.MetricKey
 
WORKER_BYTES_WRITTEN_UFS - Static variable in class alluxio.metrics.MetricKey.Name
 
WORKER_BYTES_WRITTEN_UFS - Static variable in class alluxio.metrics.MetricKey
 
WORKER_BYTES_WRITTEN_UFS_THROUGHPUT - Static variable in class alluxio.metrics.MetricKey.Name
 
WORKER_BYTES_WRITTEN_UFS_THROUGHPUT - 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.Name
 
WORKER_CAPACITY_FREE - Static variable in class alluxio.metrics.MetricKey
 
WORKER_CAPACITY_TOTAL - Static variable in class alluxio.metrics.MetricKey.Name
 
WORKER_CAPACITY_TOTAL - Static variable in class alluxio.metrics.MetricKey
 
WORKER_CAPACITY_USED - Static variable in class alluxio.metrics.MetricKey.Name
 
WORKER_CAPACITY_USED - Static variable in class alluxio.metrics.MetricKey
 
WORKER_CLIENT - Static variable in class alluxio.heartbeat.HeartbeatContext
 
WORKER_DATA_FOLDER - Static variable in class alluxio.conf.PropertyKey.Name
 
WORKER_DATA_FOLDER - Static variable in class alluxio.conf.PropertyKey
 
WORKER_DATA_FOLDER_PERMISSIONS - Static variable in class alluxio.conf.PropertyKey.Name
 
WORKER_DATA_FOLDER_PERMISSIONS - Static variable in class alluxio.conf.PropertyKey
 
WORKER_DATA_SERVER_CLASS - Static variable in class alluxio.conf.PropertyKey.Name
 
WORKER_DATA_SERVER_CLASS - Static variable in class alluxio.conf.PropertyKey
 
WORKER_DATA_SERVER_DOMAIN_SOCKET_ADDRESS - Static variable in class alluxio.conf.PropertyKey.Name
 
WORKER_DATA_SERVER_DOMAIN_SOCKET_ADDRESS - Static variable in class alluxio.conf.PropertyKey
 
WORKER_DATA_SERVER_DOMAIN_SOCKET_AS_UUID - Static variable in class alluxio.conf.PropertyKey.Name
 
WORKER_DATA_SERVER_DOMAIN_SOCKET_AS_UUID - Static variable in class alluxio.conf.PropertyKey
 
WORKER_DATA_TMP_FOLDER - Static variable in class alluxio.conf.PropertyKey.Name
 
WORKER_DATA_TMP_FOLDER - Static variable in class alluxio.conf.PropertyKey
 
WORKER_DATA_TMP_SUBDIR_MAX - Static variable in class alluxio.conf.PropertyKey.Name
 
WORKER_DATA_TMP_SUBDIR_MAX - Static variable in class alluxio.conf.PropertyKey
 
WORKER_EVICTOR_CLASS - Static variable in class alluxio.conf.PropertyKey.Name
 
WORKER_EVICTOR_CLASS - Static variable in class alluxio.conf.PropertyKey
 
WORKER_EVICTOR_LRFU_ATTENUATION_FACTOR - Static variable in class alluxio.conf.PropertyKey.Name
 
WORKER_EVICTOR_LRFU_ATTENUATION_FACTOR - Static variable in class alluxio.conf.PropertyKey
 
WORKER_EVICTOR_LRFU_STEP_FACTOR - Static variable in class alluxio.conf.PropertyKey.Name
 
WORKER_EVICTOR_LRFU_STEP_FACTOR - Static variable in class alluxio.conf.PropertyKey
 
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_HOSTNAME - Static variable in class alluxio.conf.PropertyKey.Name
 
WORKER_HOSTNAME - Static variable in class alluxio.conf.PropertyKey
 
WORKER_ID_FIELD_NUMBER - Static variable in class alluxio.proto.meta.Block.BlockLocation
 
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_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_MEMORY_SIZE - Static variable in class alluxio.conf.PropertyKey.Name
 
WORKER_MEMORY_SIZE - Static variable in class alluxio.conf.PropertyKey
 
WORKER_NETWORK_ASYNC_CACHE_MANAGER_THREADS_MAX - Static variable in class alluxio.conf.PropertyKey.Name
 
WORKER_NETWORK_ASYNC_CACHE_MANAGER_THREADS_MAX - Static variable in class alluxio.conf.PropertyKey
 
WORKER_NETWORK_BLOCK_READER_THREADS_MAX - Static variable in class alluxio.conf.PropertyKey.Name
 
WORKER_NETWORK_BLOCK_READER_THREADS_MAX - Static variable in class alluxio.conf.PropertyKey
 
WORKER_NETWORK_BLOCK_WRITER_THREADS_MAX - Static variable in class alluxio.conf.PropertyKey.Name
 
WORKER_NETWORK_BLOCK_WRITER_THREADS_MAX - Static variable in class alluxio.conf.PropertyKey
 
WORKER_NETWORK_FLOWCONTROL_WINDOW - Static variable in class alluxio.conf.PropertyKey.Name
 
WORKER_NETWORK_FLOWCONTROL_WINDOW - Static variable in class alluxio.conf.PropertyKey
 
WORKER_NETWORK_KEEPALIVE_TIME_MS - Static variable in class alluxio.conf.PropertyKey.Name
 
WORKER_NETWORK_KEEPALIVE_TIME_MS - Static variable in class alluxio.conf.PropertyKey
 
WORKER_NETWORK_KEEPALIVE_TIMEOUT_MS - Static variable in class alluxio.conf.PropertyKey.Name
 
WORKER_NETWORK_KEEPALIVE_TIMEOUT_MS - Static variable in class alluxio.conf.PropertyKey
 
WORKER_NETWORK_MAX_INBOUND_MESSAGE_SIZE - Static variable in class alluxio.conf.PropertyKey.Name
 
WORKER_NETWORK_MAX_INBOUND_MESSAGE_SIZE - Static variable in class alluxio.conf.PropertyKey
 
WORKER_NETWORK_NETTY_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_CHANNEL - Static variable in class alluxio.conf.PropertyKey.Name
 
WORKER_NETWORK_NETTY_CHANNEL - 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_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_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_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_RPC_PORT - Static variable in class alluxio.conf.PropertyKey.Name
 
WORKER_RPC_PORT - Static variable in class alluxio.conf.PropertyKey
 
WORKER_SESSION_TIMEOUT_MS - Static variable in class alluxio.conf.PropertyKey.Name
 
WORKER_SESSION_TIMEOUT_MS - Static variable in class alluxio.conf.PropertyKey
 
WORKER_SPACE_RESERVER - Static variable in class alluxio.heartbeat.HeartbeatContext
 
WORKER_STORAGE_CHECKER_ENABLED - Static variable in class alluxio.conf.PropertyKey.Name
 
WORKER_STORAGE_CHECKER_ENABLED - Static variable in class alluxio.conf.PropertyKey
 
WORKER_STORAGE_HEALTH - Static variable in class alluxio.heartbeat.HeartbeatContext
 
WORKER_TIERED_STORE_BLOCK_LOCK_READERS - Static variable in class alluxio.conf.PropertyKey.Name
 
WORKER_TIERED_STORE_BLOCK_LOCK_READERS - Static variable in class alluxio.conf.PropertyKey
 
WORKER_TIERED_STORE_BLOCK_LOCKS - Static variable in class alluxio.conf.PropertyKey.Name
 
WORKER_TIERED_STORE_BLOCK_LOCKS - Static variable in class alluxio.conf.PropertyKey
 
WORKER_TIERED_STORE_LEVEL0_ALIAS - Static variable in class alluxio.conf.PropertyKey
 
WORKER_TIERED_STORE_LEVEL0_DIRS_MEDIUMTYPE - Static variable in class alluxio.conf.PropertyKey
 
WORKER_TIERED_STORE_LEVEL0_DIRS_PATH - Static variable in class alluxio.conf.PropertyKey
 
WORKER_TIERED_STORE_LEVEL0_DIRS_QUOTA - Static variable in class alluxio.conf.PropertyKey
 
WORKER_TIERED_STORE_LEVEL0_HIGH_WATERMARK_RATIO - Static variable in class alluxio.conf.PropertyKey
 
WORKER_TIERED_STORE_LEVEL0_LOW_WATERMARK_RATIO - Static variable in class alluxio.conf.PropertyKey
 
WORKER_TIERED_STORE_LEVEL1_ALIAS - Static variable in class alluxio.conf.PropertyKey
 
WORKER_TIERED_STORE_LEVEL1_DIRS_MEDIUMTYPE - Static variable in class alluxio.conf.PropertyKey
 
WORKER_TIERED_STORE_LEVEL1_DIRS_PATH - Static variable in class alluxio.conf.PropertyKey
 
WORKER_TIERED_STORE_LEVEL1_DIRS_QUOTA - Static variable in class alluxio.conf.PropertyKey
 
WORKER_TIERED_STORE_LEVEL1_HIGH_WATERMARK_RATIO - Static variable in class alluxio.conf.PropertyKey
 
WORKER_TIERED_STORE_LEVEL1_LOW_WATERMARK_RATIO - Static variable in class alluxio.conf.PropertyKey
 
WORKER_TIERED_STORE_LEVEL2_ALIAS - Static variable in class alluxio.conf.PropertyKey
 
WORKER_TIERED_STORE_LEVEL2_DIRS_MEDIUMTYPE - Static variable in class alluxio.conf.PropertyKey
 
WORKER_TIERED_STORE_LEVEL2_DIRS_PATH - Static variable in class alluxio.conf.PropertyKey
 
WORKER_TIERED_STORE_LEVEL2_DIRS_QUOTA - Static variable in class alluxio.conf.PropertyKey
 
WORKER_TIERED_STORE_LEVEL2_HIGH_WATERMARK_RATIO - Static variable in class alluxio.conf.PropertyKey
 
WORKER_TIERED_STORE_LEVEL2_LOW_WATERMARK_RATIO - Static variable in class alluxio.conf.PropertyKey
 
WORKER_TIERED_STORE_LEVELS - Static variable in class alluxio.conf.PropertyKey.Name
 
WORKER_TIERED_STORE_LEVELS - Static variable in class alluxio.conf.PropertyKey
 
WORKER_TIERED_STORE_RESERVER_INTERVAL_MS - Static variable in class alluxio.conf.PropertyKey.Name
 
WORKER_TIERED_STORE_RESERVER_INTERVAL_MS - 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
 
WORKERADDRESSES_FIELD_NUMBER - Static variable in class alluxio.grpc.MasterInfo
 
workerEventLoopGroup(EventLoopGroup) - Method in class alluxio.grpc.GrpcServerBuilder
Sets the worker EventLoopGroup.
WorkerFactory - Interface in alluxio.worker
Interface for factory of Worker.
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
 
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.GetWorkerIdPResponse
 
WORKERID_FIELD_NUMBER - Static variable in class alluxio.grpc.JobWorkerHealth
 
WORKERID_FIELD_NUMBER - Static variable in class alluxio.grpc.RegisterWorkerPRequest
 
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
Creates a new instance of 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
WorkerInfoOrBuilder - Interface in alluxio.grpc
 
WORKERINFOS_FIELD_NUMBER - Static variable in class alluxio.grpc.GetWorkerInfoListPResponse
 
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
 
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.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.
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
 
WorkerRegistry - Class in alluxio.worker
A worker registry.
WorkerRegistry() - Constructor for class alluxio.worker.WorkerRegistry
Creates a new instance of WorkerRegistry.
WorkerStorageTierAssoc - Class in alluxio
StorageTierAssoc for workers.
WorkerStorageTierAssoc() - Constructor for class alluxio.WorkerStorageTierAssoc
Creates a new instance of WorkerStorageTierAssoc using a ServerConfiguration.
WorkerStorageTierAssoc(List<String>) - Constructor for class alluxio.WorkerStorageTierAssoc
Creates a new instance of WorkerStorageTierAssoc using a list of storage tier aliases.
WorkerUfsManager - Class in alluxio.underfs
The default implementation of UfsManager to manage the ufs used by different worker services.
WorkerUfsManager() - Constructor for class alluxio.underfs.WorkerUfsManager
Constructs an instance of WorkerUfsManager.
WorkerWebServer - Class in alluxio.web
The Alluxio worker web server.
WorkerWebServer(InetSocketAddress, WorkerProcess, BlockWorker, String, long) - 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.
WorkerWebUIInit - Class in alluxio.wire
Alluxio WebUI overview information.
WorkerWebUIInit() - Constructor for class alluxio.wire.WorkerWebUIInit
Creates a new instance of WorkerWebUIInit.
WorkerWebUILogs - Class in alluxio.wire
Alluxio WebUI logs information.
WorkerWebUILogs() - Constructor for class alluxio.wire.WorkerWebUILogs
Creates a new instance of MasterWebUIWorkers.
WorkerWebUIMetrics - Class in alluxio.wire
Alluxio WebUI overview information.
WorkerWebUIMetrics() - Constructor for class alluxio.wire.WorkerWebUIMetrics
Creates a new instance of WorkerWebUIMetrics.
WorkerWebUIOverview - Class in alluxio.wire
Alluxio WebUI overview information.
WorkerWebUIOverview() - Constructor for class alluxio.wire.WorkerWebUIOverview
Creates a new instance of WorkerWebUIOverview.
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, 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.block.stream.BlockOutStream
 
write(byte[]) - Method in class alluxio.client.block.stream.BlockOutStream
 
write(byte[], int, int) - Method in class alluxio.client.block.stream.BlockOutStream
 
write(ByteBuf) - Method in class alluxio.client.block.stream.BlockOutStream
Writes the data in the specified byte buf to this output stream.
write(ByteBuf, int, int) - Method in class alluxio.client.block.stream.BlockOutStream
Writes len bytes from the specified byte buf starting at offset off to this output stream.
write(int) - Method in class alluxio.client.file.AlluxioFileOutStream
 
write(byte[]) - Method in class alluxio.client.file.AlluxioFileOutStream
 
write(byte[], int, int) - Method in class alluxio.client.file.AlluxioFileOutStream
 
write(String, Pointer, long, long, FuseFileInfo) - Method in class alluxio.fuse.AlluxioFuseFileSystem
Writes a buffer to an open Alluxio file.
write(TableRow) - Method in class alluxio.job.plan.transform.format.csv.CsvWriter
 
write(TableRow) - Method in class alluxio.job.plan.transform.format.parquet.ParquetWriter
 
write(TableRow) - Method in class alluxio.job.plan.transform.format.tables.TablesWriter
 
write(TableRow) - Method in interface alluxio.job.plan.transform.format.TableWriter
Writes a row.
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(int) - Method in class alluxio.master.journal.raft.SnapshotWriterStream
 
write(byte[], int, int) - Method in class alluxio.master.journal.raft.SnapshotWriterStream
 
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.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.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.kodo.KodoOutputStream
 
write(byte[]) - Method in class alluxio.underfs.kodo.KodoOutputStream
 
write(byte[], int, int) - Method in class alluxio.underfs.kodo.KodoOutputStream
 
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.S3ALowLevelOutputStream
 
write(byte[]) - Method in class alluxio.underfs.s3a.S3ALowLevelOutputStream
 
write(byte[], int, int) - Method in class alluxio.underfs.s3a.S3ALowLevelOutputStream
 
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(int) - Method in class alluxio.underfs.swift.SwiftMockOutputStream
 
write(byte[], int, int) - Method in class alluxio.underfs.swift.SwiftMockOutputStream
 
write(byte[]) - Method in class alluxio.underfs.swift.SwiftMockOutputStream
 
write(int) - Method in class alluxio.underfs.swift.SwiftOutputStream
 
write(byte[], int, int) - Method in class alluxio.underfs.swift.SwiftOutputStream
 
write(byte[]) - Method in class alluxio.underfs.swift.SwiftOutputStream
 
WRITE_EXECUTE_VALUE - Static variable in enum alluxio.grpc.Bits
WRITE_EXECUTE = 4;
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;
WriteAction - Class in alluxio.table.common.transform.action
The definition of the write action.
WriteAction.WriteActionFactory - Class in alluxio.table.common.transform.action
Factory to create an instance.
WriteActionFactory() - Constructor for class alluxio.table.common.transform.action.WriteAction.WriteActionFactory
 
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 class alluxio.grpc.BlockWorkerGrpc.BlockWorkerImplBase
 
writeBlock(StreamObserver<WriteResponse>) - Method in class alluxio.grpc.BlockWorkerGrpc.BlockWorkerStub
 
writeBlock(StreamObserver<WriteResponse>) - Method in class alluxio.worker.grpc.BlockWorkerImpl
 
writeBuf(BlockWriteRequestContext, StreamObserver<WriteResponse>, DataBuffer, long) - Method in class alluxio.worker.grpc.BlockWriteHandler
 
writeBuf(BlockWriteRequestContext, StreamObserver<WriteResponse>, DataBuffer, long) - Method in class alluxio.worker.grpc.UfsFallbackBlockWriteHandler
 
writeBuf(UfsFileWriteRequestContext, StreamObserver<WriteResponse>, DataBuffer, long) - Method in class alluxio.worker.grpc.UfsFileWriteHandler
 
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.
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.LocalFileDataWriter
 
writeChunk(ByteBuf) - Method in class alluxio.client.block.stream.UfsFallbackLocalFileDataWriter
 
writeCSVFile(Collection<? extends PropertyKey>, String) - Static method in class alluxio.cli.docgen.ConfigurationDocGenerator
Writes property key to csv files.
writeFallbackInitRequest(long) - Method in class alluxio.client.block.stream.GrpcDataWriter
Notifies the server UFS fallback endpoint to start writing a new block by resuming the given number of bytes from block store.
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.
writeJournalEntryCheckpoint(OutputStream, JournalEntryIterable) - Static method in class alluxio.master.journal.JournalUtils
Writes a checkpoint of the entries in the given iterable.
writeLock() - Method in class alluxio.concurrent.WeakSafeReentrantReadWriteLock
 
writeLock() - Method in class alluxio.worker.block.ClientRWLock
 
writeLong(byte[], int, long) - Static method in class alluxio.util.io.ByteIOUtils
Writes a specific long value (8 bytes) to the output byte array at the given offset.
writeLong(OutputStream, long) - Static method in class alluxio.util.io.ByteIOUtils
Writes a specific long value (8 bytes) to the output stream.
writeNewInode(MutableInode<?>) - Method in class alluxio.master.metastore.caching.CachingInodeStore
 
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
 
writeObject(BufferOutput<?>, Serializer) - Method in class alluxio.master.journal.raft.JournalEntryCommand
 
writePartition() - Method in class alluxio.examples.Performance.AlluxioWriterWorker
Writes a partition.
WritePType - Enum in alluxio.grpc
Protobuf enum alluxio.grpc.file.WritePType
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
 
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.
writeTarGz(Path, OutputStream) - Static method in class alluxio.util.TarUtils
Creates a gzipped tar archive from the given path, streaming the data to the give output stream.
writeThroughConf() - Static method in class alluxio.job.plan.transform.format.ReadWriterUtils
 
WRITETIER_FIELD_NUMBER - Static variable in class alluxio.grpc.CreateFilePOptions
 
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.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.BlockStoreLocationProto
 
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.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.Command
 
writeTo(CodedOutputStream) - Method in class alluxio.grpc.CommitBlockInUfsPOptions
 
writeTo(CodedOutputStream) - Method in class alluxio.grpc.CommitBlockInUfsPRequest
 
writeTo(CodedOutputStream) - Method in class alluxio.grpc.CommitBlockInUfsPResponse
 
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.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.CreateLocalBlockRequest
 
writeTo(CodedOutputStream) - Method in class alluxio.grpc.CreateLocalBlockResponse
 
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.ExistsPOptions
 
writeTo(CodedOutputStream) - Method in class alluxio.grpc.FileBlockInfo
 
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.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.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.GetJobServiceSummaryPOptions
 
writeTo(CodedOutputStream) - Method in class alluxio.grpc.GetJobServiceSummaryPRequest
 
writeTo(CodedOutputStream) - Method in class alluxio.grpc.GetJobServiceSummaryPResponse
 
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.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.GetPinnedFileIdsPOptions
 
writeTo(CodedOutputStream) - Method in class alluxio.grpc.GetPinnedFileIdsPRequest
 
writeTo(CodedOutputStream) - Method in class alluxio.grpc.GetPinnedFileIdsPResponse
 
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.GetServiceVersionPRequest
 
writeTo(CodedOutputStream) - Method in class alluxio.grpc.GetServiceVersionPResponse
 
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.GetSyncPathListPRequest
 
writeTo(CodedOutputStream) - Method in class alluxio.grpc.GetSyncPathListPResponse
 
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.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.JobServiceSummary
 
writeTo(CodedOutputStream) - Method in class alluxio.grpc.JobUnused
 
writeTo(CodedOutputStream) - Method in class alluxio.grpc.JobWorkerHealth
 
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.ListStatusPOptions
 
writeTo(CodedOutputStream) - Method in class alluxio.grpc.ListStatusPRequest
 
writeTo(CodedOutputStream) - Method in class alluxio.grpc.ListStatusPResponse
 
writeTo(CodedOutputStream) - Method in class alluxio.grpc.LoadMetadataPOptions
 
writeTo(CodedOutputStream) - Method in class alluxio.grpc.LocalityTier
 
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.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.NetAddress
 
writeTo(CodedOutputStream) - Method in class alluxio.grpc.OpenFilePOptions
 
writeTo(CodedOutputStream) - Method in class alluxio.grpc.OpenLocalBlockRequest
 
writeTo(CodedOutputStream) - Method in class alluxio.grpc.OpenLocalBlockResponse
 
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.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.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.RemovePathConfigurationPOptions
 
writeTo(CodedOutputStream) - Method in class alluxio.grpc.RemovePathConfigurationPRequest
 
writeTo(CodedOutputStream) - Method in class alluxio.grpc.RemovePathConfigurationPResponse
 
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.ReverseResolvePRequest
 
writeTo(CodedOutputStream) - Method in class alluxio.grpc.ReverseResolvePResponse
 
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.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.StartSyncPOptions
 
writeTo(CodedOutputStream) - Method in class alluxio.grpc.StartSyncPRequest
 
writeTo(CodedOutputStream) - Method in class alluxio.grpc.StartSyncPResponse
 
writeTo(CodedOutputStream) - Method in class alluxio.grpc.StatusSummary
 
writeTo(CodedOutputStream) - Method in class alluxio.grpc.StopSyncPOptions
 
writeTo(CodedOutputStream) - Method in class alluxio.grpc.StopSyncPRequest
 
writeTo(CodedOutputStream) - Method in class alluxio.grpc.StopSyncPResponse
 
writeTo(CodedOutputStream) - Method in class alluxio.grpc.StorageList
 
writeTo(CodedOutputStream) - Method in class alluxio.grpc.SyncPointInfo
 
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.TieredIdentity
 
writeTo(CodedOutputStream) - Method in class alluxio.grpc.TierList
 
writeTo(CodedOutputStream) - Method in class alluxio.grpc.TransportMessage
 
writeTo(CodedOutputStream) - Method in class alluxio.grpc.UfsInfo
 
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.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.WorkerInfo
 
writeTo(CodedOutputStream) - Method in class alluxio.grpc.WorkerLostStorageInfo
 
writeTo(CodedOutputStream) - Method in class alluxio.grpc.WorkerNetAddress
 
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.CreateUfsBlockOptions
 
writeTo(CodedOutputStream) - Method in class alluxio.proto.dataserver.Protocol.CreateUfsFileOptions
 
writeTo(CodedOutputStream) - Method in class alluxio.proto.dataserver.Protocol.OpenUfsBlockOptions
 
writeTo(CodedOutputStream) - Method in class alluxio.proto.dataserver.Protocol.Response
 
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.Journal.JournalEntry
 
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.Table.AddTableEntry
 
writeTo(CodedOutputStream) - Method in class alluxio.proto.journal.Table.AddTransformJobInfoEntry
 
writeTo(CodedOutputStream) - Method in class alluxio.proto.journal.Table.AttachDbEntry
 
writeTo(CodedOutputStream) - Method in class alluxio.proto.journal.Table.CompleteTransformTableEntry
 
writeTo(CodedOutputStream) - Method in class alluxio.proto.journal.Table.DetachDbEntry
 
writeTo(CodedOutputStream) - Method in class alluxio.proto.journal.Table.RemoveTableEntry
 
writeTo(CodedOutputStream) - Method in class alluxio.proto.journal.Table.RemoveTransformJobInfoEntry
 
writeTo(CodedOutputStream) - Method in class alluxio.proto.journal.Table.UpdateDatabaseInfoEntry
 
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.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(OutputStream) - Method in class alluxio.master.file.meta.CheckpointedIdHashSet
 
writeToCheckpoint(OutputStream) - Method in class alluxio.master.file.meta.InodeCounter
 
writeToCheckpoint(OutputStream) - Method in class alluxio.master.file.meta.InodeTreePersistentState
 
writeToCheckpoint(OutputStream) - Method in class alluxio.master.file.meta.TtlBucketList
 
writeToCheckpoint(OutputStream) - Method in interface alluxio.master.journal.checkpoint.Checkpointed
Writes a checkpoint of all state to the given output stream.
writeToCheckpoint(OutputStream) - Method in interface alluxio.master.journal.DelegatingJournaled
 
writeToCheckpoint(OutputStream) - Method in interface alluxio.master.journal.Journaled
 
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(OutputStream) - Method in interface alluxio.master.journal.NoopJournaled
 
writeToCheckpoint(OutputStream) - Method in class alluxio.master.metastore.caching.CachingInodeStore
 
writeToCheckpoint(OutputStream) - Method in class alluxio.master.metastore.heap.HeapInodeStore
 
writeToCheckpoint(OutputStream) - Method in class alluxio.master.metastore.rocks.RocksInodeStore
 
writeToCheckpoint(OutputStream) - Method in class alluxio.master.metastore.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.CreateDirectoryPOptions
 
WRITETYPE_FIELD_NUMBER - Static variable in class alluxio.grpc.CreateFilePOptions
 
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.FileInfo
 
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
 

Z

ZkMasterConnectDetails(String, String) - Constructor for class alluxio.master.ZkMasterInquireClient.ZkMasterConnectDetails
 
ZkMasterInquireClient - Class in alluxio.master
Utility to get leader from zookeeper.
ZkMasterInquireClient.ZkMasterConnectDetails - Class in alluxio.master
Details used to connect to the leader Alluxio master via Zookeeper.
ZOOKEEPER_ADDRESS - Static variable in class alluxio.conf.PropertyKey.Name
 
ZOOKEEPER_ADDRESS - Static variable in class alluxio.conf.PropertyKey
 
ZOOKEEPER_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
 
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.