- ABFS_CLIENT_ENDPOINT - Static variable in class alluxio.conf.PropertyKey
-
- ABFS_CLIENT_ENDPOINT - Static variable in class alluxio.conf.PropertyKey.Name
-
- ABFS_CLIENT_ID - Static variable in class alluxio.conf.PropertyKey
-
- ABFS_CLIENT_ID - Static variable in class alluxio.conf.PropertyKey.Name
-
- ABFS_CLIENT_SECRET - Static variable in class alluxio.conf.PropertyKey
-
- ABFS_CLIENT_SECRET - Static variable in class alluxio.conf.PropertyKey.Name
-
- ABFS_COSTMAP - Static variable in class alluxio.master.metrics.CloudCostUtils
-
- AbfsUnderFileSystem - Class in alluxio.underfs.abfs
-
A Microsoft Azure Data Lake Storage Gen2 Implementation.
- AbfsUnderFileSystem(AlluxioURI, UnderFileSystemConfiguration, Configuration) - Constructor for class alluxio.underfs.abfs.AbfsUnderFileSystem
-
- AbfsUnderFileSystemFactory - Class in alluxio.underfs.abfs
-
- AbfsUnderFileSystemFactory() - Constructor for class alluxio.underfs.abfs.AbfsUnderFileSystemFactory
-
- 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.
- AbstractBlockManagementTask - Class in alluxio.worker.block.management
-
Abstract block management task implementation.
- AbstractBlockManagementTask(BlockStore, BlockMetadataManager, BlockMetadataEvictorView, StoreLoadTracker, ExecutorService) - Constructor for class alluxio.worker.block.management.AbstractBlockManagementTask
-
Creates abstract task implementation.
- 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
-
- AbstractCollectInfoCommand - Class in alluxio.cli.bundler.command
-
Abstraction of a command under CollectInfo.
- AbstractCollectInfoCommand(FileSystemContext) - Constructor for class alluxio.cli.bundler.command.AbstractCollectInfoCommand
-
- AbstractDistributedJobCommand - Class in alluxio.cli.fs.command
-
The base class for all the distributed job based
Command
classes.
- AbstractDistributedJobCommand(FileSystemContext) - Constructor for class alluxio.cli.fs.command.AbstractDistributedJobCommand
-
- AbstractEvictor - Class in alluxio.worker.block.evictor
-
- AbstractEvictor(BlockMetadataEvictorView, Allocator) - Constructor for class alluxio.worker.block.evictor.AbstractEvictor
-
Deprecated.
- 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
-
- AbstractFileSystem() - Constructor for class alluxio.hadoop.AbstractFileSystem
-
- AbstractFileSystemCommand - Class in alluxio.cli.fs.command
-
The base class for all the FileSystem
Command
classes.
- AbstractFileSystemCommand(FileSystemContext) - Constructor for class alluxio.cli.fs.command.AbstractFileSystemCommand
-
- AbstractFsAdminCommand - Class in alluxio.cli.fsadmin.command
-
Base class for fsadmin commands.
- AbstractFsAdminCommand(Context) - Constructor for class alluxio.cli.fsadmin.command.AbstractFsAdminCommand
-
- AbstractFuseFileSystem - Class in alluxio.jnifuse
-
Abstract class for other File System to extend and integrate with Fuse.
- AbstractFuseFileSystem(Path) - Constructor for class alluxio.jnifuse.AbstractFuseFileSystem
-
- AbstractHiveClientPool - Class in alluxio.table.under.hive.util
-
A pool for hive clients.
- AbstractHiveClientPool(DynamicResourcePool.Options) - Constructor for class alluxio.table.under.hive.util.AbstractHiveClientPool
-
- AbstractJobMasterClient - Class in alluxio
-
The base class for job master clients.
- AbstractJobMasterClient(MasterClientContext) - Constructor for class alluxio.AbstractJobMasterClient
-
Creates a new master client base.
- AbstractJobMasterClient(MasterClientContext, InetSocketAddress, Supplier<RetryPolicy>) - Constructor for class alluxio.AbstractJobMasterClient
-
Creates a new master client base.
- AbstractJournalDumper - Class in alluxio.master.journal.tool
-
An abstract class for journal dumpers.
- AbstractJournalDumper(String, long, long, String, String) - Constructor for class alluxio.master.journal.tool.AbstractJournalDumper
-
- AbstractJournalProgressLogger - Class in alluxio.master.journal
-
Class to abstract out progress logging for journal replay.
- AbstractJournalProgressLogger(OptionalLong) - Constructor for class alluxio.master.journal.AbstractJournalProgressLogger
-
- 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
-
- AbstractSaslClientHandler(ChannelAuthenticationScheme) - Constructor for class alluxio.security.authentication.AbstractSaslClientHandler
-
Creates an abstract sasl handler for given scheme.
- AbstractSaslServerHandler - Class in alluxio.security.authentication
-
- 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
-
- AbstractStorageTierAssoc - Class in alluxio
-
Creates a two-way mapping between storage tier aliases and ordinal numbers from the given
ServerConfiguration
.
- AbstractStorageTierAssoc(PropertyKey, PropertyKey.Template) - Constructor for class alluxio.AbstractStorageTierAssoc
-
- AbstractStorageTierAssoc(List<String>) - Constructor for class alluxio.AbstractStorageTierAssoc
-
Constructs a new instance using the given list of storage tier aliases in order of their
position in the hierarchy.
- AbstractTableCommand - Class in alluxio.cli.table.command
-
A class which should be extended when implementing commands for the
TableShell
.
- AbstractTableCommand(AlluxioConfiguration, TableMasterClient, FileSystemContext) - Constructor for class alluxio.cli.table.command.AbstractTableCommand
-
- AbstractUfsManager - Class in alluxio.underfs
-
- AbstractUfsManager() - Constructor for class alluxio.underfs.AbstractUfsManager
-
- AbstractUfsManager.Key - Class in alluxio.underfs
-
The key of the UFS cache.
- AbstractValidationTask - Class in alluxio.cli
-
Abstract class for validation environment.
- AbstractValidationTask() - Constructor for class alluxio.cli.AbstractValidationTask
-
- AbstractVoidPlanDefinition<T extends JobConfig,P extends Serializable> - Class in alluxio.job.plan
-
An abstract job definition where the run task method does not return a value.
- AbstractVoidPlanDefinition() - Constructor for class alluxio.job.plan.AbstractVoidPlanDefinition
-
- AbstractWorker - Class in alluxio.worker
-
This is the base class for all workers, and contains common functionality.
- AbstractWorker(ExecutorServiceFactory) - Constructor for class alluxio.worker.AbstractWorker
-
- accept(T) - Method in class alluxio.master.transport.Listeners
-
Accepts an event.
- accept(T) - Method in class alluxio.master.transport.Listeners.ListenerHolder
-
- acceptAllocation(StorageDirView) - Method in class alluxio.worker.block.reviewer.AcceptingReviewer
-
- acceptAllocation(StorageDirView) - Method in class alluxio.worker.block.reviewer.ProbabilisticBufferReviewer
-
- acceptAllocation(StorageDirView) - Method in interface alluxio.worker.block.reviewer.Reviewer
-
Reviews an allocation proposed by the
Allocator
.
- 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.
- AcceptingReviewer - Class in alluxio.worker.block.reviewer
-
An implementation of
Reviewer
that never rejects.
- AcceptingReviewer() - Constructor for class alluxio.worker.block.reviewer.AcceptingReviewer
-
- access(Path, FsAction) - Method in class alluxio.hadoop.AbstractFileSystem
-
- 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
-
- AclActions - Class in alluxio.security.authorization
-
- 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
-
- AclEntry.Builder - Class in alluxio.security.authorization
-
- AclEntryType - Enum in alluxio.security.authorization
-
- 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.UfsInputStreamCache
-
Acquires an input stream.
- acquireAccess(long, long, Protocol.OpenUfsBlockOptions) - Method in class alluxio.worker.block.UnderFileSystemBlockStore
-
- 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.AbstractHiveClientPool
-
- acquireClientResource() - Method in class alluxio.table.under.hive.util.DefaultHiveClientPool
-
- 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
-
- 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(Consumer<T>) - Method in class alluxio.master.transport.Listeners
-
Adds a new listener.
- 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_TABLE_PARTITIONS_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
- addAdditionalResult(long, long) - Method in class alluxio.stress.cli.client.StressClientIOBench
-
Read the log file from java agent log file.
- addAdditionalResult(long, long) - Method in class alluxio.stress.cli.fuse.FuseIOBench
-
Reads the log file from java agent log file.
- addAddresses(String) - Method in class alluxio.grpc.GetWorkerReportPOptions.Builder
-
addresses are only valid when workerRange is SPECIFIED
- addAddressesBytes(ByteString) - Method in class alluxio.grpc.GetWorkerReportPOptions.Builder
-
addresses are only valid when workerRange is SPECIFIED
- addAffectedPaths(String) - Method in class alluxio.grpc.JobInfo.Builder
-
repeated string affectedPaths = 14;
- addAffectedPathsBytes(ByteString) - Method in class alluxio.grpc.JobInfo.Builder
-
repeated string affectedPaths = 14;
- addAggregator(MultiValueMetricsAggregator) - Method in class alluxio.master.metrics.DefaultMetricsMaster
-
- 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
- addAllAffectedPaths(Iterable<String>) - Method in class alluxio.grpc.JobInfo.Builder
-
repeated string affectedPaths = 14;
- addAllBlockId(Iterable<? extends Long>) - Method in class alluxio.grpc.BlockIdList.Builder
-
repeated int64 blockId = 1;
- addAllBlockIds(Iterable<? extends Long>) - Method in class alluxio.grpc.FileInfo.Builder
-
repeated int64 blockIds = 13;
- addAllBlockIds(Iterable<? extends Long>) - Method in class alluxio.grpc.PersistFile.Builder
-
repeated int64 blockIds = 2;
- addAllBlockIds(Iterable<? extends Long>) - Method in class alluxio.proto.journal.File.CompleteFileEntry.Builder
-
repeated int64 block_ids = 1;
- addAllBlocks(Iterable<? extends 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.grpc.FileInfo.Builder
-
repeated string mediumType = 33;
- addAllMediumType(Iterable<String>) - Method in class alluxio.proto.journal.File.InodeDirectoryEntry.Builder
-
repeated string medium_type = 18;
- addAllMediumType(Iterable<String>) - Method in class alluxio.proto.journal.File.InodeFileEntry.Builder
-
repeated string medium_type = 26;
- addAllMediumType(Iterable<String>) - Method in class alluxio.proto.journal.File.UpdateInodeEntry.Builder
-
repeated string medium_type = 16;
- addAllMediumType(Iterable<String>) - Method in class alluxio.proto.meta.InodeMeta.Inode.Builder
-
repeated string medium_type = 27;
- addAllMetrics(Iterable<? extends Metric>) - Method in class alluxio.grpc.BlockHeartbeatPOptions.Builder
-
repeated .alluxio.grpc.Metric metrics = 1;
- addAllMetrics(Iterable<? extends Metric>) - Method in class alluxio.grpc.ClientMetrics.Builder
-
repeated .alluxio.grpc.Metric metrics = 2;
- addAllPartitionCols(Iterable<? extends FieldSchema>) - Method in class alluxio.grpc.table.TableInfo.Builder
-
partitioning scheme
- 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;
- addAllPartitions(Iterable<? extends Partition>) - Method in class alluxio.proto.journal.Table.AddTablePartitionsEntry.Builder
-
repeated .alluxio.grpc.table.Partition partitions = 4;
- 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;
- addAllStatus(Iterable<? extends Status>) - Method in class alluxio.grpc.ListAllPOptions.Builder
-
repeated .alluxio.grpc.job.Status status = 1;
- addAllStorage(Iterable<String>) - Method in class alluxio.grpc.StorageList.Builder
-
a lost storage path
- addAllStorageTiers(Iterable<String>) - Method in class alluxio.grpc.RegisterWorkerPRequest.Builder
-
the list of storage tiers
- addAllSummaryPerStatus(Iterable<? extends StatusSummary>) - Method in class alluxio.grpc.JobServiceSummary.Builder
-
repeated .alluxio.grpc.job.StatusSummary summaryPerStatus = 1;
- 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;
- addAllThreads(Iterable<String>) - Method in class alluxio.grpc.GetStateLockHoldersPResponse.Builder
-
repeated string threads = 1;
- 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.DefaultStorageDir
-
- addBlockMeta(BlockMeta) - Method in interface 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;
- addChildren(AlluxioURI, Collection<UfsStatus>) - Method in class alluxio.underfs.UfsStatusCache
-
Add a parent-child mapping to the status cache.
- addChildrenBuilder() - Method in class alluxio.grpc.JobInfo.Builder
-
repeated .alluxio.grpc.job.JobInfo children = 11;
- addChildrenBuilder(int) - Method in class alluxio.grpc.JobInfo.Builder
-
repeated .alluxio.grpc.job.JobInfo children = 11;
- 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;
- addData(Object) - Method in class alluxio.stress.graph.BarGraph.Data
-
- addData(Object, Object) - Method in class alluxio.stress.graph.LineGraph.Data
-
- addDatabase(String) - Method in class alluxio.grpc.table.GetAllDatabasesPResponse.Builder
-
repeated string database = 1;
- addDatabaseBytes(ByteString) - Method in class alluxio.grpc.table.GetAllDatabasesPResponse.Builder
-
repeated string database = 1;
- addDataCols(FieldSchema) - Method in class alluxio.grpc.table.layout.hive.PartitionInfo.Builder
-
repeated .alluxio.grpc.table.FieldSchema data_cols = 6;
- addDataCols(int, FieldSchema) - Method in class alluxio.grpc.table.layout.hive.PartitionInfo.Builder
-
repeated .alluxio.grpc.table.FieldSchema data_cols = 6;
- addDataCols(FieldSchema.Builder) - Method in class alluxio.grpc.table.layout.hive.PartitionInfo.Builder
-
repeated .alluxio.grpc.table.FieldSchema data_cols = 6;
- addDataCols(int, FieldSchema.Builder) - Method in class alluxio.grpc.table.layout.hive.PartitionInfo.Builder
-
repeated .alluxio.grpc.table.FieldSchema data_cols = 6;
- addDataColsBuilder() - Method in class alluxio.grpc.table.layout.hive.PartitionInfo.Builder
-
repeated .alluxio.grpc.table.FieldSchema data_cols = 6;
- addDataColsBuilder(int) - Method in class alluxio.grpc.table.layout.hive.PartitionInfo.Builder
-
repeated .alluxio.grpc.table.FieldSchema data_cols = 6;
- addDataSeries(String, BarGraph.Data) - Method in class alluxio.stress.graph.BarGraph
-
- addDataSeries(String, LineGraph.Data) - Method in class alluxio.stress.graph.LineGraph
-
- ADDEDBLOCKS_FIELD_NUMBER - Static variable in class alluxio.grpc.BlockHeartbeatPRequest
-
- ADDEDBLOCKSONTIERS_FIELD_NUMBER - Static variable in class alluxio.grpc.BlockHeartbeatPRequest
-
- addEntries(PAclEntry) - Method in class alluxio.grpc.PAcl.Builder
-
repeated .alluxio.grpc.file.PAclEntry entries = 3;
- addEntries(int, PAclEntry) - Method in class alluxio.grpc.PAcl.Builder
-
repeated .alluxio.grpc.file.PAclEntry entries = 3;
- addEntries(PAclEntry.Builder) - Method in class alluxio.grpc.PAcl.Builder
-
repeated .alluxio.grpc.file.PAclEntry entries = 3;
- addEntries(int, PAclEntry.Builder) - Method in class alluxio.grpc.PAcl.Builder
-
repeated .alluxio.grpc.file.PAclEntry entries = 3;
- addEntries(PAclEntry) - Method in class alluxio.grpc.SetAclPRequest.Builder
-
the list of ACL entries
- addEntries(int, PAclEntry) - Method in class alluxio.grpc.SetAclPRequest.Builder
-
the list of ACL entries
- addEntries(PAclEntry.Builder) - Method in class alluxio.grpc.SetAclPRequest.Builder
-
the list of ACL entries
- addEntries(int, PAclEntry.Builder) - Method in class alluxio.grpc.SetAclPRequest.Builder
-
the list of ACL entries
- addEntries(Acl.AclEntry) - Method in class alluxio.proto.journal.File.SetAclEntry.Builder
-
repeated .alluxio.proto.shared.AclEntry entries = 4;
- addEntries(int, Acl.AclEntry) - Method in class alluxio.proto.journal.File.SetAclEntry.Builder
-
repeated .alluxio.proto.shared.AclEntry entries = 4;
- addEntries(Acl.AclEntry.Builder) - Method in class alluxio.proto.journal.File.SetAclEntry.Builder
-
repeated .alluxio.proto.shared.AclEntry entries = 4;
- addEntries(int, Acl.AclEntry.Builder) - Method in class alluxio.proto.journal.File.SetAclEntry.Builder
-
repeated .alluxio.proto.shared.AclEntry entries = 4;
- addEntriesBuilder() - Method in class alluxio.grpc.PAcl.Builder
-
repeated .alluxio.grpc.file.PAclEntry entries = 3;
- addEntriesBuilder(int) - Method in class alluxio.grpc.PAcl.Builder
-
repeated .alluxio.grpc.file.PAclEntry entries = 3;
- addEntriesBuilder() - Method in class alluxio.grpc.SetAclPRequest.Builder
-
the list of ACL entries
- addEntriesBuilder(int) - Method in class alluxio.grpc.SetAclPRequest.Builder
-
the list of ACL entries
- addEntriesBuilder() - Method in class alluxio.proto.journal.File.SetAclEntry.Builder
-
repeated .alluxio.proto.shared.AclEntry entries = 4;
- addEntriesBuilder(int) - Method in class alluxio.proto.journal.File.SetAclEntry.Builder
-
repeated .alluxio.proto.shared.AclEntry entries = 4;
- addError(String) - Method in class alluxio.stress.rpc.RpcTaskResult
-
- addError(String) - Method in class alluxio.stress.worker.IOTaskResult
-
- addErrorMessage(String) - Method in class alluxio.stress.client.ClientIOTaskResult.ThreadCountResult
-
- addErrorMessage(String) - Method in class alluxio.stress.fuse.FuseIOTaskResult.ThreadCountResult
-
- addErrorMessage(String) - Method in class alluxio.stress.jobservice.JobServiceBenchTaskResult
-
- addErrorMessage(String) - Method in class alluxio.stress.master.MasterBenchTaskResult
-
- addErrorMessage(String) - Method in class alluxio.stress.worker.WorkerBenchTaskResult
-
- addExternalMasterAddress(MasterNetAddress) - Method in class alluxio.multi.process.MultiProcessCluster
-
Updates internal master list with an external address.
- addFailedRun(long, MasterBenchSummary) - Method in class alluxio.stress.master.MaxThroughputSummary
-
Adds a failing run to the summary, for a target throughput.
- 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.
- ADDITIONAL_OPTION_NAME - Static variable in class alluxio.cli.bundler.command.CollectLogCommand
-
- addJobIds(long) - Method in class alluxio.grpc.ListAllPResponse.Builder
-
repeated int64 jobIds = 1;
- addJobInfos(JobInfo) - Method in class alluxio.grpc.ListAllPResponse.Builder
-
repeated .alluxio.grpc.job.JobInfo jobInfos = 2;
- addJobInfos(int, JobInfo) - Method in class alluxio.grpc.ListAllPResponse.Builder
-
repeated .alluxio.grpc.job.JobInfo jobInfos = 2;
- addJobInfos(JobInfo.Builder) - Method in class alluxio.grpc.ListAllPResponse.Builder
-
repeated .alluxio.grpc.job.JobInfo jobInfos = 2;
- addJobInfos(int, JobInfo.Builder) - Method in class alluxio.grpc.ListAllPResponse.Builder
-
repeated .alluxio.grpc.job.JobInfo jobInfos = 2;
- addJobInfosBuilder() - Method in class alluxio.grpc.ListAllPResponse.Builder
-
repeated .alluxio.grpc.job.JobInfo jobInfos = 2;
- addJobInfosBuilder(int) - Method in class alluxio.grpc.ListAllPResponse.Builder
-
repeated .alluxio.grpc.job.JobInfo jobInfos = 2;
- 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.common.udb.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.grpc.FileInfo.Builder
-
repeated string mediumType = 33;
- addMediumType(String) - Method in class alluxio.proto.journal.File.InodeDirectoryEntry.Builder
-
repeated string medium_type = 18;
- addMediumType(String) - Method in class alluxio.proto.journal.File.InodeFileEntry.Builder
-
repeated string medium_type = 26;
- addMediumType(String) - Method in class alluxio.proto.journal.File.UpdateInodeEntry.Builder
-
repeated string medium_type = 16;
- addMediumType(String) - Method in class alluxio.proto.meta.InodeMeta.Inode.Builder
-
repeated string medium_type = 27;
- addMediumTypeBytes(ByteString) - Method in class alluxio.grpc.FileInfo.Builder
-
repeated string mediumType = 33;
- addMediumTypeBytes(ByteString) - Method in class alluxio.proto.journal.File.InodeDirectoryEntry.Builder
-
repeated string medium_type = 18;
- addMediumTypeBytes(ByteString) - Method in class alluxio.proto.journal.File.InodeFileEntry.Builder
-
repeated string medium_type = 26;
- addMediumTypeBytes(ByteString) - Method in class alluxio.proto.journal.File.UpdateInodeEntry.Builder
-
repeated string medium_type = 16;
- addMediumTypeBytes(ByteString) - Method in class alluxio.proto.meta.InodeMeta.Inode.Builder
-
repeated string medium_type = 27;
- addMetrics(Metric) - Method in class alluxio.grpc.BlockHeartbeatPOptions.Builder
-
repeated .alluxio.grpc.Metric metrics = 1;
- addMetrics(int, Metric) - Method in class alluxio.grpc.BlockHeartbeatPOptions.Builder
-
repeated .alluxio.grpc.Metric metrics = 1;
- addMetrics(Metric.Builder) - Method in class alluxio.grpc.BlockHeartbeatPOptions.Builder
-
repeated .alluxio.grpc.Metric metrics = 1;
- addMetrics(int, Metric.Builder) - Method in class alluxio.grpc.BlockHeartbeatPOptions.Builder
-
repeated .alluxio.grpc.Metric metrics = 1;
- addMetrics(Metric) - Method in class alluxio.grpc.ClientMetrics.Builder
-
repeated .alluxio.grpc.Metric metrics = 2;
- addMetrics(int, Metric) - Method in class alluxio.grpc.ClientMetrics.Builder
-
repeated .alluxio.grpc.Metric metrics = 2;
- addMetrics(Metric.Builder) - Method in class alluxio.grpc.ClientMetrics.Builder
-
repeated .alluxio.grpc.Metric metrics = 2;
- addMetrics(int, Metric.Builder) - Method in class alluxio.grpc.ClientMetrics.Builder
-
repeated .alluxio.grpc.Metric metrics = 2;
- addMetricsBuilder() - Method in class alluxio.grpc.BlockHeartbeatPOptions.Builder
-
repeated .alluxio.grpc.Metric metrics = 1;
- addMetricsBuilder(int) - Method in class alluxio.grpc.BlockHeartbeatPOptions.Builder
-
repeated .alluxio.grpc.Metric metrics = 1;
- addMetricsBuilder() - Method in class alluxio.grpc.ClientMetrics.Builder
-
repeated .alluxio.grpc.Metric metrics = 2;
- addMetricsBuilder(int) - Method in class alluxio.grpc.ClientMetrics.Builder
-
repeated .alluxio.grpc.Metric metrics = 2;
- addMount(long, AlluxioURI, UnderFileSystemConfiguration) - Method in class alluxio.underfs.AbstractUfsManager
-
- addMount(long, AlluxioURI, UnderFileSystemConfiguration) - Method in class alluxio.underfs.MasterUfsManager
-
- addMount(long, AlluxioURI, UnderFileSystemConfiguration) - Method in interface alluxio.underfs.UfsManager
-
Keeps track of a mount id and maps it to its URI in Alluxio and configuration.
- addNextInode(Inode) - Method in class alluxio.master.file.meta.LockedInodePath
-
Adds the next inode to the path.
- addOpResults(BlockOperationType, BlockOperationResult) - Method in class alluxio.worker.block.management.BlockManagementTaskResult
-
- 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.
- addPage(PageId, PageInfo) - Method in class alluxio.client.file.cache.QuotaMetaStore
-
- 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(List<Partition>) - Method in class alluxio.master.table.BasePartitionScheme
-
- addPartitions(List<Partition>) - Method in interface alluxio.master.table.PartitionScheme
-
Add a list of partitions.
- addPartitions(Table.AddTablePartitionsEntry) - Method in class alluxio.master.table.Table
-
Add partitions to the current table.
- 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;
- addPartitions(Partition) - Method in class alluxio.proto.journal.Table.AddTablePartitionsEntry.Builder
-
repeated .alluxio.grpc.table.Partition partitions = 4;
- addPartitions(int, Partition) - Method in class alluxio.proto.journal.Table.AddTablePartitionsEntry.Builder
-
repeated .alluxio.grpc.table.Partition partitions = 4;
- addPartitions(Partition.Builder) - Method in class alluxio.proto.journal.Table.AddTablePartitionsEntry.Builder
-
repeated .alluxio.grpc.table.Partition partitions = 4;
- addPartitions(int, Partition.Builder) - Method in class alluxio.proto.journal.Table.AddTablePartitionsEntry.Builder
-
repeated .alluxio.grpc.table.Partition partitions = 4;
- 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;
- addPartitionsBuilder() - Method in class alluxio.proto.journal.Table.AddTablePartitionsEntry.Builder
-
repeated .alluxio.grpc.table.Partition partitions = 4;
- addPartitionsBuilder(int) - Method in class alluxio.proto.journal.Table.AddTablePartitionsEntry.Builder
-
repeated .alluxio.grpc.table.Partition partitions = 4;
- 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;
- addPassedRun(long, MasterBenchSummary) - Method in class alluxio.stress.master.MaxThroughputSummary
-
Adds a passing run to the summary, for a target throughput.
- addPathProperty(String, String, String) - Method in class alluxio.wire.Configuration.Builder
-
Adds a path level property.
- addPersistedFileFingerprints(String) - Method in class alluxio.grpc.FileSystemHeartbeatPOptions.Builder
-
repeated string persistedFileFingerprints = 1;
- addPersistedFileFingerprintsBytes(ByteString) - Method in class alluxio.grpc.FileSystemHeartbeatPOptions.Builder
-
repeated string persistedFileFingerprints = 1;
- addPersistedFiles(long) - Method in class alluxio.grpc.FileSystemHeartbeatPRequest.Builder
-
the list of persisted files
- addPersistFiles(PersistFile) - Method in class alluxio.grpc.PersistCommandOptions.Builder
-
repeated .alluxio.grpc.file.PersistFile persistFiles = 1;
- addPersistFiles(int, PersistFile) - Method in class alluxio.grpc.PersistCommandOptions.Builder
-
repeated .alluxio.grpc.file.PersistFile persistFiles = 1;
- addPersistFiles(PersistFile.Builder) - Method in class alluxio.grpc.PersistCommandOptions.Builder
-
repeated .alluxio.grpc.file.PersistFile persistFiles = 1;
- addPersistFiles(int, PersistFile.Builder) - Method in class alluxio.grpc.PersistCommandOptions.Builder
-
repeated .alluxio.grpc.file.PersistFile persistFiles = 1;
- addPersistFilesBuilder() - Method in class alluxio.grpc.PersistCommandOptions.Builder
-
repeated .alluxio.grpc.file.PersistFile persistFiles = 1;
- addPersistFilesBuilder(int) - Method in class alluxio.grpc.PersistCommandOptions.Builder
-
repeated .alluxio.grpc.file.PersistFile persistFiles = 1;
- addPinnedFileIds(long) - Method in class alluxio.grpc.GetPinnedFileIdsPResponse.Builder
-
TODO(adit): set replacement?
- addPinnedMedia(String) - Method in class alluxio.grpc.SetAttributePOptions.Builder
-
repeated string pinnedMedia = 10;
- addPinnedMediaBytes(ByteString) - Method in class alluxio.grpc.SetAttributePOptions.Builder
-
repeated string pinnedMedia = 10;
- addPoint(RpcTaskResult.Point) - Method in class alluxio.stress.rpc.RpcTaskResult
-
- addPoint(IOTaskResult.Point) - Method in class alluxio.stress.worker.IOTaskResult
-
- 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(InetSocketAddress, InetSocketAddress) - Method in class alluxio.master.transport.GrpcMessagingProxy
-
Adds a new proxy mapping.
- addQuorumServer(NetAddress) - Method in class alluxio.master.journal.raft.RaftJournalSystem
-
Adds a server to the quorum.
- AddQuorumServerRequest - Class in alluxio.grpc
-
Protobuf type alluxio.grpc.meta.AddQuorumServerRequest
- AddQuorumServerRequest.Builder - Class in alluxio.grpc
-
Protobuf type alluxio.grpc.meta.AddQuorumServerRequest
- ADDQUORUMSERVERREQUEST_FIELD_NUMBER - Static variable in class alluxio.grpc.JournalQueryRequest
-
- AddQuorumServerRequestOrBuilder - Interface in alluxio.grpc
-
- 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.AddQuorumServerRequest.Builder
-
- addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.AsyncCacheRequest.Builder
-
- addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.AsyncCacheResponse.Builder
-
- addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.BackupPOptions.Builder
-
- addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.BackupPRequest.Builder
-
- addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.BackupPStatus.Builder
-
- addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.BackupStatusPRequest.Builder
-
- addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.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.CacheRequest.Builder
-
- addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.CacheResponse.Builder
-
- addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.CancelPOptions.Builder
-
- addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.CancelPRequest.Builder
-
- addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.CancelPResponse.Builder
-
- addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.CancelTaskCommand.Builder
-
- addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.CheckAccessPOptions.Builder
-
- addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.CheckAccessPRequest.Builder
-
- addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.CheckAccessPResponse.Builder
-
- addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.CheckConsistencyPOptions.Builder
-
- addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.CheckConsistencyPRequest.Builder
-
- addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.CheckConsistencyPResponse.Builder
-
- addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.CheckpointPOptions.Builder
-
- addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.CheckpointPResponse.Builder
-
- addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.CheckRequest.Builder
-
- addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.CheckResponse.Builder
-
- addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.Chunk.Builder
-
- addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.ClearMetricsPRequest.Builder
-
- addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.ClearMetricsPResponse.Builder
-
- addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.ClearMetricsRequest.Builder
-
- addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.ClearMetricsResponse.Builder
-
- addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.ClientMetrics.Builder
-
- addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.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.DownloadSnapshotPRequest.Builder
-
- addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.DownloadSnapshotPResponse.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.GetJobStatusDetailedPOptions.Builder
-
- addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.GetJobStatusDetailedPRequest.Builder
-
- addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.GetJobStatusDetailedPResponse.Builder
-
- addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.GetJobStatusPOptions.Builder
-
- addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.GetJobStatusPRequest.Builder
-
- addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.GetJobStatusPResponse.Builder
-
- addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.GetMasterIdPOptions.Builder
-
- addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.GetMasterIdPRequest.Builder
-
- addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.GetMasterIdPResponse.Builder
-
- addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.GetMasterInfoPOptions.Builder
-
- addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.GetMasterInfoPResponse.Builder
-
- addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.GetMetricsPOptions.Builder
-
- addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.GetMetricsPResponse.Builder
-
- addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.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.GetSnapshotInfoRequest.Builder
-
- addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.GetSnapshotInfoResponse.Builder
-
- addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.GetSnapshotRequest.Builder
-
- addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.GetStateLockHoldersPOptions.Builder
-
- addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.GetStateLockHoldersPRequest.Builder
-
- addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.GetStateLockHoldersPResponse.Builder
-
- addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.GetStatusPOptions.Builder
-
- addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.GetStatusPRequest.Builder
-
- addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.GetStatusPResponse.Builder
-
- addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.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.JournalQueryRequest.Builder
-
- addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.JournalQueryResponse.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.ResetPrioritiesPOptions.Builder
-
- addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.ResetPrioritiesPRequest.Builder
-
- addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.ResetPrioritiesPResponse.Builder
-
- addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.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.SnapshotData.Builder
-
- addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.SnapshotMetadata.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.TransferLeadershipPOptions.Builder
-
- addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.TransferLeadershipPRequest.Builder
-
- addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.TransferLeadershipPResponse.Builder
-
- addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.TransportMessage.Builder
-
- addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.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.UpdateConfigurationPRequest.Builder
-
- addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.UpdateConfigurationPResponse.Builder
-
- addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.UpdateMountPRequest.Builder
-
- addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.UpdateMountPResponse.Builder
-
- addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.UpdateUfsModePOptions.Builder
-
- addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.UpdateUfsModePRequest.Builder
-
- addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.UpdateUfsModePResponse.Builder
-
- addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.UploadSnapshotPRequest.Builder
-
- addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.UploadSnapshotPResponse.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.AddTablePartitionsEntry.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
-
- Address(String, int) - Constructor for class alluxio.wire.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.QuorumElectCommand
-
- ADDRESS_OPTION_NAME - Static variable in class alluxio.cli.fsadmin.journal.QuorumRemoveCommand
-
- ADDRESS_VALUE - Static variable in enum alluxio.grpc.WorkerInfoField
-
ADDRESS = 1;
- ADDRESSES_FIELD_NUMBER - Static variable in class alluxio.grpc.GetWorkerReportPOptions
-
- addServerInfo(QuorumServerInfo) - Method in class alluxio.grpc.GetQuorumInfoPResponse.Builder
-
repeated .alluxio.grpc.journal.QuorumServerInfo serverInfo = 2;
- addServerInfo(int, QuorumServerInfo) - Method in class alluxio.grpc.GetQuorumInfoPResponse.Builder
-
repeated .alluxio.grpc.journal.QuorumServerInfo serverInfo = 2;
- addServerInfo(QuorumServerInfo.Builder) - Method in class alluxio.grpc.GetQuorumInfoPResponse.Builder
-
repeated .alluxio.grpc.journal.QuorumServerInfo serverInfo = 2;
- addServerInfo(int, QuorumServerInfo.Builder) - Method in class alluxio.grpc.GetQuorumInfoPResponse.Builder
-
repeated .alluxio.grpc.journal.QuorumServerInfo serverInfo = 2;
- addServerInfoBuilder() - Method in class alluxio.grpc.GetQuorumInfoPResponse.Builder
-
repeated .alluxio.grpc.journal.QuorumServerInfo serverInfo = 2;
- addServerInfoBuilder(int) - Method in class alluxio.grpc.GetQuorumInfoPResponse.Builder
-
repeated .alluxio.grpc.journal.QuorumServerInfo serverInfo = 2;
- addService(ServiceType, GrpcService) - Method in class alluxio.grpc.GrpcServerBuilder
-
Add a service to this server.
- addService(GrpcService) - Method in class alluxio.grpc.GrpcServerBuilder
-
Add a service to this server.
- addSetBlocks(long) - Method in class alluxio.proto.journal.File.UpdateInodeFileEntry.Builder
-
Overwrite the blocks list
- addSinglePath(AlluxioURI) - Method in class alluxio.master.file.meta.AsyncUfsAbsentPathCache
-
- addSinglePath(AlluxioURI) - Method in class alluxio.master.file.meta.NoopUfsAbsentPathCache
-
- addSinglePath(AlluxioURI) - Method in interface alluxio.master.file.meta.UfsAbsentPathCache
-
Add a single path to the absent cache synchronously.
- 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;
- addStatus(Status) - Method in class alluxio.grpc.ListAllPOptions.Builder
-
repeated .alluxio.grpc.job.Status status = 1;
- addStatus(AlluxioURI, UfsStatus) - Method in class alluxio.underfs.UfsStatusCache
-
Add a new status to the cache.
- addStorage(String) - Method in class alluxio.grpc.StorageList.Builder
-
a lost storage path
- addStorageBytes(ByteString) - Method in class alluxio.grpc.StorageList.Builder
-
a lost storage path
- addStorageTiers(String) - Method in class alluxio.grpc.RegisterWorkerPRequest.Builder
-
the list of storage tiers
- addStorageTiersBytes(ByteString) - Method in class alluxio.grpc.RegisterWorkerPRequest.Builder
-
the list of storage tiers
- addSummaryPerStatus(StatusSummary) - Method in class alluxio.grpc.JobServiceSummary.Builder
-
repeated .alluxio.grpc.job.StatusSummary summaryPerStatus = 1;
- addSummaryPerStatus(int, StatusSummary) - Method in class alluxio.grpc.JobServiceSummary.Builder
-
repeated .alluxio.grpc.job.StatusSummary summaryPerStatus = 1;
- addSummaryPerStatus(StatusSummary.Builder) - Method in class alluxio.grpc.JobServiceSummary.Builder
-
repeated .alluxio.grpc.job.StatusSummary summaryPerStatus = 1;
- addSummaryPerStatus(int, StatusSummary.Builder) - Method in class alluxio.grpc.JobServiceSummary.Builder
-
repeated .alluxio.grpc.job.StatusSummary summaryPerStatus = 1;
- addSummaryPerStatusBuilder() - Method in class alluxio.grpc.JobServiceSummary.Builder
-
repeated .alluxio.grpc.job.StatusSummary summaryPerStatus = 1;
- addSummaryPerStatusBuilder(int) - Method in class alluxio.grpc.JobServiceSummary.Builder
-
repeated .alluxio.grpc.job.StatusSummary summaryPerStatus = 1;
- 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, Object) - Method in class alluxio.job.plan.meta.PlanInfo
-
Registers a task.
- addTaskInfos(JobInfo) - Method in class alluxio.grpc.JobHeartbeatPRequest.Builder
-
repeated .alluxio.grpc.job.JobInfo taskInfos = 2;
- addTaskInfos(int, JobInfo) - Method in class alluxio.grpc.JobHeartbeatPRequest.Builder
-
repeated .alluxio.grpc.job.JobInfo taskInfos = 2;
- addTaskInfos(JobInfo.Builder) - Method in class alluxio.grpc.JobHeartbeatPRequest.Builder
-
repeated .alluxio.grpc.job.JobInfo taskInfos = 2;
- addTaskInfos(int, JobInfo.Builder) - Method in class alluxio.grpc.JobHeartbeatPRequest.Builder
-
repeated .alluxio.grpc.job.JobInfo taskInfos = 2;
- addTaskInfosBuilder() - Method in class alluxio.grpc.JobHeartbeatPRequest.Builder
-
repeated .alluxio.grpc.job.JobInfo taskInfos = 2;
- addTaskInfosBuilder(int) - Method in class alluxio.grpc.JobHeartbeatPRequest.Builder
-
repeated .alluxio.grpc.job.JobInfo taskInfos = 2;
- addTempBlockMeta(TempBlockMeta) - Method in class alluxio.worker.block.BlockMetadataManager
-
Adds a temp block.
- addTempBlockMeta(TempBlockMeta) - Method in class alluxio.worker.block.meta.DefaultStorageDir
-
- addTempBlockMeta(TempBlockMeta) - Method in interface alluxio.worker.block.meta.StorageDir
-
Adds the metadata of a new block into this storage dir.
- addThreadCountResults(int, ClientIOTaskResult.ThreadCountResult) - Method in class alluxio.stress.client.ClientIOTaskResult
-
- addThreadCountResults(int, FuseIOTaskResult.ThreadCountResult) - Method in class alluxio.stress.fuse.FuseIOTaskResult
-
- addThreads(String) - Method in class alluxio.grpc.GetStateLockHoldersPResponse.Builder
-
repeated string threads = 1;
- addThreadsBytes(ByteString) - Method in class alluxio.grpc.GetStateLockHoldersPResponse.Builder
-
repeated string threads = 1;
- addTiers(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
- addWorkerAddresses(NetAddress) - Method in class alluxio.grpc.MasterInfo.Builder
-
repeated .alluxio.grpc.NetAddress workerAddresses = 9;
- addWorkerAddresses(int, NetAddress) - Method in class alluxio.grpc.MasterInfo.Builder
-
repeated .alluxio.grpc.NetAddress workerAddresses = 9;
- addWorkerAddresses(NetAddress.Builder) - Method in class alluxio.grpc.MasterInfo.Builder
-
repeated .alluxio.grpc.NetAddress workerAddresses = 9;
- addWorkerAddresses(int, NetAddress.Builder) - Method in class alluxio.grpc.MasterInfo.Builder
-
repeated .alluxio.grpc.NetAddress workerAddresses = 9;
- addWorkerAddressesBuilder() - Method in class alluxio.grpc.MasterInfo.Builder
-
repeated .alluxio.grpc.NetAddress workerAddresses = 9;
- addWorkerAddressesBuilder(int) - Method in class alluxio.grpc.MasterInfo.Builder
-
repeated .alluxio.grpc.NetAddress workerAddresses = 9;
- addWorkerHealths(JobWorkerHealth) - Method in class alluxio.grpc.GetAllWorkerHealthPResponse.Builder
-
repeated .alluxio.grpc.job.JobWorkerHealth workerHealths = 1;
- addWorkerHealths(int, JobWorkerHealth) - Method in class alluxio.grpc.GetAllWorkerHealthPResponse.Builder
-
repeated .alluxio.grpc.job.JobWorkerHealth workerHealths = 1;
- addWorkerHealths(JobWorkerHealth.Builder) - Method in class alluxio.grpc.GetAllWorkerHealthPResponse.Builder
-
repeated .alluxio.grpc.job.JobWorkerHealth workerHealths = 1;
- addWorkerHealths(int, JobWorkerHealth.Builder) - Method in class alluxio.grpc.GetAllWorkerHealthPResponse.Builder
-
repeated .alluxio.grpc.job.JobWorkerHealth workerHealths = 1;
- addWorkerHealthsBuilder() - Method in class alluxio.grpc.GetAllWorkerHealthPResponse.Builder
-
repeated .alluxio.grpc.job.JobWorkerHealth workerHealths = 1;
- addWorkerHealthsBuilder(int) - Method in class alluxio.grpc.GetAllWorkerHealthPResponse.Builder
-
repeated .alluxio.grpc.job.JobWorkerHealth workerHealths = 1;
- addWorkerInfos(WorkerInfo) - Method in class alluxio.grpc.GetWorkerInfoListPResponse.Builder
-
repeated .alluxio.grpc.block.WorkerInfo workerInfos = 1;
- addWorkerInfos(int, WorkerInfo) - Method in class alluxio.grpc.GetWorkerInfoListPResponse.Builder
-
repeated .alluxio.grpc.block.WorkerInfo workerInfos = 1;
- addWorkerInfos(WorkerInfo.Builder) - Method in class alluxio.grpc.GetWorkerInfoListPResponse.Builder
-
repeated .alluxio.grpc.block.WorkerInfo workerInfos = 1;
- addWorkerInfos(int, WorkerInfo.Builder) - Method in class alluxio.grpc.GetWorkerInfoListPResponse.Builder
-
repeated .alluxio.grpc.block.WorkerInfo workerInfos = 1;
- addWorkerInfosBuilder() - Method in class alluxio.grpc.GetWorkerInfoListPResponse.Builder
-
repeated .alluxio.grpc.block.WorkerInfo workerInfos = 1;
- addWorkerInfosBuilder(int) - Method in class alluxio.grpc.GetWorkerInfoListPResponse.Builder
-
repeated .alluxio.grpc.block.WorkerInfo workerInfos = 1;
- addWorkerLostStorageInfo(WorkerLostStorageInfo) - Method in class alluxio.grpc.GetWorkerLostStoragePResponse.Builder
-
repeated .alluxio.grpc.block.WorkerLostStorageInfo workerLostStorageInfo = 1;
- addWorkerLostStorageInfo(int, WorkerLostStorageInfo) - Method in class alluxio.grpc.GetWorkerLostStoragePResponse.Builder
-
repeated .alluxio.grpc.block.WorkerLostStorageInfo workerLostStorageInfo = 1;
- addWorkerLostStorageInfo(WorkerLostStorageInfo.Builder) - Method in class alluxio.grpc.GetWorkerLostStoragePResponse.Builder
-
repeated .alluxio.grpc.block.WorkerLostStorageInfo workerLostStorageInfo = 1;
- addWorkerLostStorageInfo(int, WorkerLostStorageInfo.Builder) - Method in class alluxio.grpc.GetWorkerLostStoragePResponse.Builder
-
repeated .alluxio.grpc.block.WorkerLostStorageInfo workerLostStorageInfo = 1;
- addWorkerLostStorageInfoBuilder() - Method in class alluxio.grpc.GetWorkerLostStoragePResponse.Builder
-
repeated .alluxio.grpc.block.WorkerLostStorageInfo workerLostStorageInfo = 1;
- addWorkerLostStorageInfoBuilder(int) - Method in class alluxio.grpc.GetWorkerLostStoragePResponse.Builder
-
repeated .alluxio.grpc.block.WorkerLostStorageInfo workerLostStorageInfo = 1;
- addZookeeperAddresses(String) - Method in class alluxio.grpc.MasterInfo.Builder
-
Empty means zookeeper is not enabled
- addZookeeperAddressesBytes(ByteString) - Method in class alluxio.grpc.MasterInfo.Builder
-
Empty means zookeeper is not enabled
- AdlUnderFileSystem - Class in alluxio.underfs.adl
-
A Microsoft Azure Data Lake Storage Gen 1 Implementation.
- AdlUnderFileSystem(AlluxioURI, UnderFileSystemConfiguration, Configuration) - Constructor for class alluxio.underfs.adl.AdlUnderFileSystem
-
- AdlUnderFileSystemFactory - Class in alluxio.underfs.adl
-
- AdlUnderFileSystemFactory() - Constructor for class alluxio.underfs.adl.AdlUnderFileSystemFactory
-
- advance() - Method in interface alluxio.master.journal.JournalReader
-
Advances the reader to the next element.
- advance() - Method in class alluxio.master.journal.ufs.UfsJournalReader
-
- affectedPaths() - Method in interface alluxio.job.JobConfig
-
- affectedPaths() - Method in class alluxio.job.plan.load.LoadConfig
-
- affectedPaths() - Method in class alluxio.job.plan.migrate.MigrateConfig
-
- affectedPaths() - Method in class alluxio.job.plan.persist.PersistConfig
-
- affectedPaths() - Method in class alluxio.job.plan.replicate.EvictConfig
-
- affectedPaths() - Method in class alluxio.job.plan.replicate.MoveConfig
-
- affectedPaths() - Method in class alluxio.job.plan.replicate.ReplicateConfig
-
- affectedPaths() - Method in class alluxio.job.plan.transform.CompactConfig
-
- affectedPaths() - Method in class alluxio.job.workflow.composite.CompositeConfig
-
- affectedPaths() - Method in class alluxio.stress.job.StressBenchConfig
-
- AFFECTEDPATHS_FIELD_NUMBER - Static variable in class alluxio.grpc.JobInfo
-
- afterConnect() - Method in class alluxio.AbstractClient
-
This method is called after the connection is made to the remote.
- afterConnect() - Method in class alluxio.client.block.RetryHandlingBlockMasterClient
-
- afterConnect() - Method in class alluxio.client.file.RetryHandlingFileSystemMasterClient
-
- afterConnect() - Method in class alluxio.client.job.RetryHandlingJobMasterClient
-
- afterConnect() - Method in class alluxio.client.journal.RetryHandlingJournalMasterClient
-
- afterConnect() - Method in class alluxio.client.meta.RetryHandlingMetaMasterClient
-
- afterConnect() - Method in class alluxio.client.meta.RetryHandlingMetaMasterConfigClient
-
- afterConnect() - Method in class alluxio.client.metrics.RetryHandlingMetricsMasterClient
-
- afterConnect() - Method in class alluxio.client.table.RetryHandlingTableMasterClient
-
- afterConnect() - Method in class alluxio.master.file.FileSystemMasterClient
-
- afterConnect() - Method in class alluxio.master.journal.raft.RaftJournalServiceClient
-
- afterConnect() - Method in class alluxio.master.meta.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.
- AGENT_OUTPUT_PATH - Static variable in class alluxio.stress.BaseParameters
-
- aggregate(Iterable<RpcTaskResult>) - Method in class alluxio.stress.rpc.RpcTaskResult.Aggregator
-
- aggregate(Iterable<T>) - Method in interface alluxio.stress.TaskResult.Aggregator
-
Aggregates multiple instances of a
TaskResult
to a summary.
- AggregateException - Exception in alluxio.exception
-
Represents a collection of exceptions.
- AggregateException(Collection<Exception>) - Constructor for exception alluxio.exception.AggregateException
-
- aggregator() - Method in class alluxio.stress.client.ClientIOTaskResult
-
- aggregator() - Method in class alluxio.stress.fuse.FuseIOTaskResult
-
- aggregator() - Method in class alluxio.stress.jobservice.JobServiceBenchTaskResult
-
- aggregator() - Method in class alluxio.stress.master.MasterBenchTaskResult
-
- aggregator() - Method in class alluxio.stress.rpc.RpcTaskResult
-
- Aggregator() - Constructor for class alluxio.stress.rpc.RpcTaskResult.Aggregator
-
- aggregator() - Method in interface alluxio.stress.TaskResult
-
- aggregator() - Method in class alluxio.stress.worker.IOTaskResult
-
- aggregator() - Method in class alluxio.stress.worker.WorkerBenchTaskResult
-
- aligned(BlockStoreLocation, BlockStoreLocation, BlockOrder, Function<Long, Boolean>) - Method in interface alluxio.worker.block.annotator.BlockIterator
-
Used to detect presence of an overlap between two locations.
- aligned(BlockStoreLocation, BlockStoreLocation, BlockOrder, Function<Long, Boolean>) - Method in class alluxio.worker.block.annotator.DefaultBlockIterator
-
- aligned(BlockStoreLocation, BlockStoreLocation, BlockOrder, Function<Long, Boolean>) - Method in class alluxio.worker.block.annotator.EmulatingBlockIterator
-
- AlignTask - Class in alluxio.worker.block.management.tier
-
A BlockStore management task that swaps blocks between tiers in order to align
tiers based on block annotation policy.
- AlignTask(BlockStore, BlockMetadataManager, BlockMetadataEvictorView, StoreLoadTracker, ExecutorService) - Constructor for class alluxio.worker.block.management.tier.AlignTask
-
Creates a new align task.
- 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, boolean) - 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, boolean) - Method in class alluxio.worker.block.allocator.GreedyAllocator
-
- allocateBlockWithView(long, long, BlockStoreLocation, BlockMetadataView, boolean) - Method in class alluxio.worker.block.allocator.MaxFreeAllocator
-
- allocateBlockWithView(long, long, BlockStoreLocation, BlockMetadataView, boolean) - Method in class alluxio.worker.block.allocator.RoundRobinAllocator
-
- AllocateOptions - Class in alluxio.worker.block
-
Used to specify various options while allocating space.
- Allocator - Interface in alluxio.worker.block.allocator
-
Interface for the allocation policy of Alluxio managed data.
- Allocator.Factory - Class in alluxio.worker.block.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.
- ALLOW_DIFF_PART_LOC_PREFIX - Static variable in class alluxio.table.under.hive.Property
-
- ALLOW_DIFF_PART_LOC_PREFIX - Static variable in class alluxio.table.under.hive.Property.Name
-
- 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.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.fs.command.job - package alluxio.cli.fs.command.job
-
- alluxio.cli.fsadmin - package alluxio.cli.fsadmin
-
- alluxio.cli.fsadmin.command - package alluxio.cli.fsadmin.command
-
- alluxio.cli.fsadmin.doctor - package alluxio.cli.fsadmin.doctor
-
- alluxio.cli.fsadmin.journal - package alluxio.cli.fsadmin.journal
-
- alluxio.cli.fsadmin.metrics - package alluxio.cli.fsadmin.metrics
-
- alluxio.cli.fsadmin.pathconf - package alluxio.cli.fsadmin.pathconf
-
- alluxio.cli.fsadmin.report - package alluxio.cli.fsadmin.report
-
- alluxio.cli.hdfs - package alluxio.cli.hdfs
-
- alluxio.cli.hms - package alluxio.cli.hms
-
- alluxio.cli.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.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.hive - package alluxio.client.hive
-
- alluxio.client.job - package alluxio.client.job
-
- alluxio.client.journal - package alluxio.client.journal
-
- alluxio.client.meta - package alluxio.client.meta
-
- alluxio.client.metrics - package alluxio.client.metrics
-
- alluxio.client.quota - package alluxio.client.quota
-
- alluxio.client.table - package alluxio.client.table
-
- alluxio.clock - package alluxio.clock
-
- alluxio.collections - package alluxio.collections
-
- alluxio.common - package alluxio.common
-
- alluxio.concurrent - package alluxio.concurrent
-
- alluxio.concurrent.jsr - package alluxio.concurrent.jsr
-
- alluxio.conf - package alluxio.conf
-
- alluxio.conf.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.fuse.auth - package alluxio.fuse.auth
-
- 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.jnifuse - package alluxio.jnifuse
-
- alluxio.jnifuse.constants - package alluxio.jnifuse.constants
-
- alluxio.jnifuse.struct - package alluxio.jnifuse.struct
-
- alluxio.jnifuse.utils - package alluxio.jnifuse.utils
-
- alluxio.job - package alluxio.job
-
- alluxio.job.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.stress - package alluxio.job.plan.stress
-
- 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.orc - package alluxio.job.plan.transform.format.orc
-
- 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.proxy.s3.logging - package alluxio.proxy.s3.logging
-
- 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.stress - package alluxio.stress
-
- alluxio.stress.cli - package alluxio.stress.cli
-
- alluxio.stress.cli.client - package alluxio.stress.cli.client
-
- alluxio.stress.cli.fuse - package alluxio.stress.cli.fuse
-
- alluxio.stress.cli.report - package alluxio.stress.cli.report
-
- alluxio.stress.cli.suite - package alluxio.stress.cli.suite
-
- alluxio.stress.cli.worker - package alluxio.stress.cli.worker
-
- alluxio.stress.client - package alluxio.stress.client
-
- alluxio.stress.common - package alluxio.stress.common
-
- alluxio.stress.fuse - package alluxio.stress.fuse
-
- alluxio.stress.graph - package alluxio.stress.graph
-
- alluxio.stress.job - package alluxio.stress.job
-
- alluxio.stress.jobservice - package alluxio.stress.jobservice
-
- alluxio.stress.master - package alluxio.stress.master
-
- alluxio.stress.rpc - package alluxio.stress.rpc
-
- alluxio.stress.worker - package alluxio.stress.worker
-
- 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.glue - package alluxio.table.under.glue
-
- 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.abfs - package alluxio.underfs.abfs
-
- alluxio.underfs.adl - package alluxio.underfs.adl
-
- alluxio.underfs.cephfs - package alluxio.underfs.cephfs
-
- alluxio.underfs.cephfshadoop - package alluxio.underfs.cephfshadoop
-
- alluxio.underfs.cos - package alluxio.underfs.cos
-
- alluxio.underfs.cosn - package alluxio.underfs.cosn
-
- alluxio.underfs.gcs - package alluxio.underfs.gcs
-
- alluxio.underfs.gcs.v2 - package alluxio.underfs.gcs.v2
-
- alluxio.underfs.hdfs - package alluxio.underfs.hdfs
-
- alluxio.underfs.hdfs.acl - package alluxio.underfs.hdfs.acl
-
- alluxio.underfs.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.ozone - package alluxio.underfs.ozone
-
- 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.network.tls - package alluxio.util.network.tls
-
- alluxio.util.proto - package alluxio.util.proto
-
- alluxio.util.webui - package alluxio.util.webui
-
- alluxio.web - package alluxio.web
-
- alluxio.wire - package alluxio.wire
-
- alluxio.worker - package alluxio.worker
-
Worker process and utils for working with the worker remotely.
- alluxio.worker.block - package alluxio.worker.block
-
- alluxio.worker.block.allocator - package alluxio.worker.block.allocator
-
- alluxio.worker.block.annotator - package alluxio.worker.block.annotator
-
- 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.management - package alluxio.worker.block.management
-
- alluxio.worker.block.management.tier - package alluxio.worker.block.management.tier
-
- alluxio.worker.block.meta - package alluxio.worker.block.meta
-
- alluxio.worker.block.reviewer - package alluxio.worker.block.reviewer
-
- 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
-
- AlluxioException(Throwable) - Constructor for exception alluxio.exception.AlluxioException
-
- AlluxioException(String) - Constructor for exception alluxio.exception.AlluxioException
-
- AlluxioException(String, Throwable) - Constructor for exception alluxio.exception.AlluxioException
-
- 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.
- AlluxioForkJoinWorkerThreadFactory(String, boolean) - Constructor for class alluxio.concurrent.jsr.ForkJoinPool.AlluxioForkJoinWorkerThreadFactory
-
- AlluxioFuse - Class in alluxio.fuse
-
Main entry point to Alluxio-FUSE.
- AlluxioFuseFileSystem - Class in alluxio.fuse
-
Main FUSE implementation class.
- AlluxioFuseFileSystem(FileSystem, FuseMountOptions, AlluxioConfiguration) - Constructor for class alluxio.fuse.AlluxioFuseFileSystem
-
- AlluxioFuseUtils - Class in alluxio.fuse
-
Utility methods for Alluxio-FUSE.
- AlluxioFuseUtils.FuseCallable - Interface in alluxio.fuse
-
An interface representing a callable for FUSE APIs.
- 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
-
- AlluxioJniFuseFileSystem - Class in alluxio.fuse
-
Main FUSE implementation class.
- AlluxioJniFuseFileSystem(FileSystem, FuseMountOptions, AlluxioConfiguration) - Constructor for class alluxio.fuse.AlluxioJniFuseFileSystem
-
- 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
-
- 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
-
- 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
-
- 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
-
- 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
-
- 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
-
- 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
-
- 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
-
- 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
-
- AlluxioURI(String, Authority, String) - Constructor for class alluxio.AlluxioURI
-
- AlluxioURI(String, Authority, String, Map<String, String>) - Constructor for class alluxio.AlluxioURI
-
- AlluxioURI(AlluxioURI, AlluxioURI) - Constructor for class alluxio.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
-
- 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 - Static variable in interface alluxio.master.file.meta.UfsAbsentPathCache
-
- ALWAYS_VALUE - Static variable in enum alluxio.grpc.LoadMetadataPType
-
Always load metadata.
- AlwaysHealthyJobWorkerHealthReporter - Class in alluxio.worker.job.command
-
- 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.
- anyDirInAnyTierWithMedium(String) - Static method in class alluxio.worker.block.BlockStoreLocation
-
Convenience method to return the block store location representing any dir in any tier
with specific medium.
- anyDirInTier(String) - Static method in class alluxio.worker.block.BlockStoreLocation
-
Convenience method to return the block store location representing any dir in the tier.
- 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
-
- 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
-
- append(Journal.JournalEntry) - Method in interface alluxio.master.journal.JournalContext
-
- append(Journal.JournalEntry) - Method in class alluxio.master.journal.MasterJournalContext
-
- append(Journal.JournalEntry) - Method in class alluxio.master.journal.MergeJournalContext
-
- append(Journal.JournalEntry) - Method in class alluxio.master.journal.NoopJournalContext
-
- append(Journal.JournalEntry) - Method in interface alluxio.master.journal.sink.JournalSink
-
Appends a new journal entry written to the journal.
- append(Journal.JournalEntry) - Method in class alluxio.master.journal.StateChangeJournalContext
-
- append(LoggingEvent) - Method in class alluxio.metrics.EventCounter
-
Add the number of corresponding level log.
- append(ByteBuffer) - Method in class alluxio.worker.block.io.BlockWriter
-
Appends data to the end of a block from an input
ByteBuffer
.
- append(ByteBuf) - Method in class alluxio.worker.block.io.BlockWriter
-
Appends buf.readableBytes() bytes to the end of this block writer from the given buf.
- append(DataBuffer) - Method in class alluxio.worker.block.io.BlockWriter
-
Appends buffer.readableBytes() bytes to the end of this block writer from the given buffer.
- append(ByteBuffer) - Method in class alluxio.worker.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
-
- appendEntry(Journal.JournalEntry) - Method in class alluxio.master.journalv0.AsyncJournalWriter
-
- appendPath(URI, String) - Static method in class alluxio.util.URIUtils
-
Appends the given path to the given base URI.
- appendPathOrDie(URI, String) - Static method in class alluxio.util.URIUtils
-
Appends the given path to the given base URI.
- ApplicableUfsType - Annotation Type in alluxio.cli
-
An enum standing for a UFS type.
- ApplicableUfsType.Type - Enum in alluxio.cli
-
UFS types.
- AppLoginModule - Class in alluxio.security.login
-
An app login module that creates a user based on the user name provided through application
configuration.
- AppLoginModule() - Constructor for class alluxio.security.login.AppLoginModule
-
- AppLoginModule.AppCallbackHandler - Class in alluxio.security.login
-
- apply(A, B, C) - Method in interface alluxio.collections.TwoKeyConcurrentMap.TriFunction
-
- apply(long, long, String, FileStat, long) - Static method in class alluxio.jnifuse.FuseFillDir
-
- apply(Clients) - Method in class alluxio.master.backcompat.FsTestOp
-
- apply(FileSystem) - Method in class alluxio.master.backcompat.FsTestOp
-
- apply(FileSystem) - Method in class alluxio.master.backcompat.ops.AsyncPersist
-
- apply(FileSystem) - Method in class alluxio.master.backcompat.ops.CreateDirectory
-
- apply(FileSystem) - Method in class alluxio.master.backcompat.ops.CreateFile
-
- apply(FileSystem) - Method in class alluxio.master.backcompat.ops.Delete
-
- apply(FileSystem) - Method in class alluxio.master.backcompat.ops.Mount
-
- apply(FileSystem) - Method in class alluxio.master.backcompat.ops.PersistDirectory
-
- apply(Clients) - Method in class alluxio.master.backcompat.ops.PersistFile
-
- apply(FileSystem) - Method in class alluxio.master.backcompat.ops.Rename
-
- apply(FileSystem) - Method in class alluxio.master.backcompat.ops.SetAcl
-
- apply(Clients) - Method in class alluxio.master.backcompat.ops.UpdateUfsMode
-
- apply(Clients) - Method in interface alluxio.master.backcompat.TestOp
-
Applies the test operation.
- apply() - Method in interface alluxio.master.table.transform.TransformManager.ThrowingSupplier
-
- applyAndJournal(Supplier<JournalContext>, File.AddSyncPointEntry) - Method in class alluxio.master.file.activesync.ActiveSyncManager
-
- applyAndJournal(Supplier<JournalContext>, File.RemoveSyncPointEntry) - Method in class alluxio.master.file.activesync.ActiveSyncManager
-
- 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(TransactionContext) - Method in class alluxio.master.journal.raft.JournalStateMachine
-
Applies a journal entry commit to the state machine.
- applyToEither(CompletionStage<? extends T>, Function<? super T, U>) - Method in class alluxio.concurrent.jsr.CompletableFuture
-
- applyToEither(CompletionStage<? extends T>, Function<? super T, U>) - Method in interface alluxio.concurrent.jsr.CompletionStage
-
Returns a new CompletionStage that, when either this or the other given stage complete
normally, is executed with the corresponding result as argument to the supplied function.
- applyToEitherAsync(CompletionStage<? extends T>, Function<? super T, U>) - Method in class alluxio.concurrent.jsr.CompletableFuture
-
- applyToEitherAsync(CompletionStage<? extends T>, Function<? super T, U>, Executor) - Method in class alluxio.concurrent.jsr.CompletableFuture
-
- applyToEitherAsync(CompletionStage<? extends T>, Function<? super T, U>) - Method in interface alluxio.concurrent.jsr.CompletionStage
-
Returns a new CompletionStage that, when either this or the other given stage complete
normally, is executed using this stage's default asynchronous execution facility, with the
corresponding result as argument to the supplied function.
- applyToEitherAsync(CompletionStage<? extends T>, Function<? super T, U>, Executor) - Method in interface alluxio.concurrent.jsr.CompletionStage
-
Returns a new CompletionStage that, when either this or the other given stage complete
normally, is executed using the supplied executor, with the corresponding result as argument to
the supplied function.
- applyTransaction(TransactionContext) - Method in class alluxio.master.journal.raft.JournalStateMachine
-
- approximateContentHash(long, long) - Static method in class alluxio.util.UnderFileSystemUtils
-
Returns an approximate content hash, using the length and modification time.
- 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_FIELD_NUMBER - Static variable in class alluxio.grpc.CacheRequest
-
- 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.
- AsyncBlockRemover(BlockWorker, int, BlockingQueue<Long>, Set<Long>) - Constructor for class alluxio.worker.block.AsyncBlockRemover
-
Constructor of AsyncBlockRemover.
- 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) - Method in interface alluxio.worker.block.BlockWorker
-
- asyncCache(AsyncCacheRequest) - Method in class alluxio.worker.block.DefaultBlockWorker
-
- asyncCache(AsyncCacheRequest, StreamObserver<AsyncCacheResponse>) - Method in class alluxio.worker.grpc.BlockWorkerClientServiceHandler
-
- AsyncCacheRequest - Class in alluxio.grpc
-
Request for caching a block asynchronously
Deprecated and will be removed in v3.0
- AsyncCacheRequest.Builder - Class in alluxio.grpc
-
Request for caching a block asynchronously
Deprecated and will be removed in v3.0
- AsyncCacheRequestOrBuilder - Interface in alluxio.grpc
-
- AsyncCacheResponse - Class in alluxio.grpc
-
Response for an async cache request
- AsyncCacheResponse.Builder - Class in alluxio.grpc
-
Response for an async cache request
- AsyncCacheResponseOrBuilder - Interface in alluxio.grpc
-
- AsyncJournalWriter - Class in alluxio.master.journal
-
This enables async journal writing, as well as some batched journal flushing.
- AsyncJournalWriter(JournalWriter, Supplier<Set<JournalSink>>) - Constructor for class alluxio.master.journal.AsyncJournalWriter
-
- AsyncJournalWriter(JournalWriter, Supplier<Set<JournalSink>>, String) - Constructor for class alluxio.master.journal.AsyncJournalWriter
-
- AsyncJournalWriter - Class in alluxio.master.journalv0
-
This enables async journal writing, as well as some batched journal flushing.
- AsyncJournalWriter(JournalWriter) - Constructor for class alluxio.master.journalv0.AsyncJournalWriter
-
- AsyncPersist - Class in alluxio.master.backcompat.ops
-
Test for async persist functionality.
- AsyncPersist() - Constructor for class alluxio.master.backcompat.ops.AsyncPersist
-
- AsyncPersistHandler - Interface in alluxio.master.file.async
-
The handler that handles the scheduled async persist requests on files, and decides which worker
to take the persistence task.
- AsyncPersistHandler.Factory - Class in alluxio.master.file.async
-
- 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
-
- asyncUpdateFileAccessTime(AlluxioURI) - Method in class alluxio.client.file.MetadataCachingBaseFileSystem
-
Asynchronously update file's last access time.
- AsyncUserAccessAuditLogWriter - Class in alluxio.master.audit
-
- AsyncUserAccessAuditLogWriter() - Constructor for class alluxio.master.audit.AsyncUserAccessAuditLogWriter
-
- AtomicFileOutputStream - Class in alluxio.underfs
-
- AtomicFileOutputStream(String, AtomicFileOutputStreamCallback, CreateOptions) - Constructor for class alluxio.underfs.AtomicFileOutputStream
-
- AtomicFileOutputStreamCallback - Interface in alluxio.underfs
-
- 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, FileSystemContext) - Constructor for class alluxio.cli.table.command.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
-
- 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
-
- AuthenticatedUserInfo(String) - Constructor for class alluxio.security.authentication.AuthenticatedUserInfo
-
- AuthenticatedUserInfo(String, String) - Constructor for class alluxio.security.authentication.AuthenticatedUserInfo
-
- AuthenticatedUserInfo(String, String, String) - Constructor for class alluxio.security.authentication.AuthenticatedUserInfo
-
- AuthenticatedUserInjector - Class in alluxio.security.authentication
-
- AuthenticatedUserInjector(AuthenticationServer) - Constructor for class alluxio.security.authentication.AuthenticatedUserInjector
-
- 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
-
- 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
-
- authority() - Method in class alluxio.grpc.GrpcChannel
-
- Authority - Interface in alluxio.uri
-
This interface represents the authority part of a URI.
- AuthPolicy - Interface in alluxio.fuse.auth
-
Fuse Auth Policy Interface.
- AuthPolicyFactory - Class in alluxio.fuse.auth
-
Fuse Auth Policy Factory.
- AuthPolicyFactory() - Constructor for class alluxio.fuse.auth.AuthPolicyFactory
-
- AuthType - Enum in alluxio.security.authentication
-
Different authentication types for Alluxio.
- available() - Method in class alluxio.hadoop.AlluxioHdfsInputStream
-
- available() - Method in class alluxio.hadoop.HdfsFileInputStream
-
- available() - Method in class alluxio.underfs.cephfs.CephInputStream
-
- available() - Method in class alluxio.underfs.hdfs.HdfsPositionedUnderFileInputStream
-
- available() - Static method in class alluxio.underfs.UnderFileSystemFactoryRegistry
-
Returns a read-only view of the available base factories.
- AVAILABLE_VALUE - Static variable in enum alluxio.grpc.QuorumServerState
-
AVAILABLE = 1;
- AVG_COL_LEN_FIELD_NUMBER - Static variable in class alluxio.grpc.table.BinaryColumnStatsData
-
- AVG_COL_LEN_FIELD_NUMBER - Static variable in class alluxio.grpc.table.StringColumnStatsData
-
- await() - Method in class alluxio.concurrent.CountingLatch
-
Blocked during awaiting the counter to become zero.
- await(String) - Static method in class alluxio.heartbeat.HeartbeatScheduler
-
Waits for the given thread to be ready to be scheduled.
- await(String, long, TimeUnit) - Static method in class alluxio.heartbeat.HeartbeatScheduler
-
Waits until the given thread can be executed, throwing an unchecked exception of the given
timeout expires.
- awaitLosePrimacy() - Method in class alluxio.master.journal.ufs.UfsJournal
-
Transitions the journal from primary to secondary mode.
- awaitQuiescence(long, TimeUnit) - Method in class alluxio.concurrent.jsr.ForkJoinPool
-
- 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
-
- AWS_GLUE_ACCESS_KEY - Static variable in class alluxio.table.under.glue.Property
-
- AWS_GLUE_ACCESS_KEY - Static variable in class alluxio.table.under.glue.Property.Name
-
- AWS_GLUE_SECRET_KEY - Static variable in class alluxio.table.under.glue.Property
-
- AWS_GLUE_SECRET_KEY - Static variable in class alluxio.table.under.glue.Property.Name
-
- AWS_PROXY_HOST - Static variable in class alluxio.table.under.glue.Property
-
- AWS_PROXY_HOST - Static variable in class alluxio.table.under.glue.Property.Name
-
- AWS_PROXY_PASSWORD - Static variable in class alluxio.table.under.glue.Property
-
- AWS_PROXY_PASSWORD - Static variable in class alluxio.table.under.glue.Property.Name
-
- AWS_PROXY_PORT - Static variable in class alluxio.table.under.glue.Property
-
- AWS_PROXY_PORT - Static variable in class alluxio.table.under.glue.Property.Name
-
- AWS_PROXY_PROTOCOL - Static variable in class alluxio.table.under.glue.Property
-
- AWS_PROXY_PROTOCOL - Static variable in class alluxio.table.under.glue.Property.Name
-
- AWS_PROXY_USER_NAME - Static variable in class alluxio.table.under.glue.Property
-
- AWS_PROXY_USER_NAME - Static variable in class alluxio.table.under.glue.Property.Name
-
- cache(CacheRequest) - Method in interface alluxio.client.block.stream.BlockWorkerClient
-
Caches a block.
- cache(CacheRequest) - Method in class alluxio.client.block.stream.DefaultBlockWorkerClient
-
- cache(CacheRequest) - Method in class alluxio.grpc.BlockWorkerGrpc.BlockWorkerBlockingStub
-
- cache(CacheRequest) - Method in class alluxio.grpc.BlockWorkerGrpc.BlockWorkerFutureStub
-
- cache(CacheRequest, StreamObserver<CacheResponse>) - Method in class alluxio.grpc.BlockWorkerGrpc.BlockWorkerImplBase
-
- cache(CacheRequest, StreamObserver<CacheResponse>) - Method in class alluxio.grpc.BlockWorkerGrpc.BlockWorkerStub
-
- Cache<K,V> - Class in alluxio.master.metastore.caching
-
Base class for write-back caches which asynchronously evict entries to backing stores.
- Cache(CacheConfiguration, String, MetricKey, MetricKey, MetricKey, MetricKey, MetricKey) - Constructor for class alluxio.master.metastore.caching.Cache
-
- Cache - Class in alluxio.proto.client
-
- cache(CacheRequest) - Method in interface alluxio.worker.block.BlockWorker
-
Submits the cache request to cache manager to execute.
- cache(CacheRequest) - Method in class alluxio.worker.block.DefaultBlockWorker
-
- cache(CacheRequest, StreamObserver<CacheResponse>) - Method in class alluxio.worker.grpc.BlockWorkerClientServiceHandler
-
- 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_MANAGER_EXECUTOR - Static variable in class alluxio.worker.grpc.GrpcExecutors
-
- CACHE_PROMOTE_VALUE - Static variable in enum alluxio.grpc.ReadPType
-
CACHE_PROMOTE = 3;
- CACHE_THROUGH_VALUE - Static variable in enum alluxio.grpc.WritePType
-
CACHE_THROUGH = 3;
- CACHE_UFS_SESSION_ID - Static variable in class alluxio.Sessions
-
- CACHE_VALUE - Static variable in enum alluxio.grpc.ReadPType
-
CACHE = 2;
- CACHE_WORKER_SESSION_ID - Static variable in class alluxio.Sessions
-
- CACHEABLE_FIELD_NUMBER - Static variable in class alluxio.grpc.FileInfo
-
- CACHEABLE_FIELD_NUMBER - Static variable in class alluxio.proto.journal.File.InodeFileEntry
-
- CACHEABLE_FIELD_NUMBER - Static variable in class alluxio.proto.journal.File.UpdateInodeFileEntry
-
- CacheConfiguration - Class in alluxio.master.metastore.caching
-
Cache configuration.
- CacheConfiguration.Builder - Class in alluxio.master.metastore.caching
-
Cache configuration builder.
- CacheContext - Class in alluxio.client.file
-
Cache related context.
- CacheContext() - Constructor for class alluxio.client.file.CacheContext
-
Expected to be inherited in PrestoDB or other local cache caller.
- CachedGroupMapping - Class in alluxio.security.group
-
Class to map user to groups.
- CachedGroupMapping(GroupMappingService, long) - Constructor for class alluxio.security.group.CachedGroupMapping
-
- cachedThreadPool(String) - Static method in class alluxio.util.executor.ExecutorServiceFactories
-
- CacheEvictor - Interface in alluxio.client.file.cache.evictor
-
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.
- CacheManager.State - Enum in alluxio.client.file.cache
-
State of a cache.
- CacheManagerWithShadowCache - Class in alluxio.client.file.cache
-
A wrapper class of CacheManager with shadow cache.
- CacheManagerWithShadowCache(CacheManager, AlluxioConfiguration) - Constructor for class alluxio.client.file.cache.CacheManagerWithShadowCache
-
- CacheManagerWithShadowCache.PageIdFunnel - Enum in alluxio.client.file.cache
-
Funnel for PageId.
- CacheQuota - Class in alluxio.client.quota
-
Data structure that stores and returns cache size in number of bytes associated with a
cache scope.
- CacheQuota(Map<CacheScope.Level, Long>) - Constructor for class alluxio.client.quota.CacheQuota
-
- CacheQuota() - Constructor for class alluxio.client.quota.CacheQuota
-
Empty cache quota.
- CacheRequest - Class in alluxio.grpc
-
Request for caching a block synchronously/asynchronously
next available id: 7
- CacheRequest.Builder - Class in alluxio.grpc
-
Request for caching a block synchronously/asynchronously
next available id: 7
- CacheRequestManager - Class in alluxio.worker.block
-
Handles client requests to synchronously/asynchronously cache blocks.
- CacheRequestManager(ExecutorService, BlockWorker, FileSystemContext) - Constructor for class alluxio.worker.block.CacheRequestManager
-
- CacheRequestOrBuilder - Interface in alluxio.grpc
-
- CacheResponse - Class in alluxio.grpc
-
Response for an async cache request
- CacheResponse.Builder - Class in alluxio.grpc
-
Response for an async cache request
- CacheResponseOrBuilder - Interface in alluxio.grpc
-
- CacheScope - Class in alluxio.client.quota
-
This class defines "Scope" of a cache quota.
- CacheScope.Level - Enum in alluxio.client.quota
-
Level of a scope.
- CACHESIZE_FIELD_NUMBER - Static variable in class alluxio.proto.client.Cache.PPageStoreCommonOptions
-
- CachingBlockMasterClient - Class in alluxio.stress
-
Use this class to avoid the map-list conversion at the client side.
- CachingBlockMasterClient(MasterClientContext, List<LocationBlockIdListEntry>) - Constructor for class alluxio.stress.CachingBlockMasterClient
-
Creates a new instance and caches the converted proto.
- CachingInodeStore - Class in alluxio.master.metastore.caching
-
An inode store which caches inode tree metadata and delegates to another inode store for cache
misses.
- CachingInodeStore(InodeStore, InodeLockManager) - Constructor for class alluxio.master.metastore.caching.CachingInodeStore
-
- calculateCost(String, Map<String, Long>) - Static method in class alluxio.master.metrics.CloudCostUtils
-
Calculate the saved cost from the perUfs Operations saved map.
- calculateObjectSize(Object) - Method in class alluxio.util.ObjectSizeCalculator
-
Given an object, returns the total allocated size, in bytes, of the object
and all other objects reachable from it.
- call() - Method in interface alluxio.AbstractClient.RpcCallable
-
The task where RPC happens.
- call() - Method in class alluxio.cli.BasicCheckpoint
-
- call() - Method in class alluxio.cli.BasicNonByteBufferOperations
-
- call() - Method in class alluxio.cli.BasicOperations
-
- call(Logger, AlluxioFuseUtils.FuseCallable, String, String, Object...) - Static method in class alluxio.fuse.AlluxioFuseUtils
-
- call() - Method in interface alluxio.fuse.AlluxioFuseUtils.FuseCallable
-
The RPC implementation.
- call(String, S3RestUtils.RestCallable<T>) - Static method in class alluxio.proxy.s3.S3RestUtils
-
- 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
-
- 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
-
- call(Logger, RpcUtils.RpcCallableThrowsIOException<T>, String, boolean, String, StreamObserver<T>, Object...) - Static method in class alluxio.RpcUtils
-
- 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
-
- CallTracker - Interface in alluxio.master.file.contexts
-
An interface for RPC level call tracking.
- CallTracker.Type - Enum in alluxio.master.file.contexts
-
Defines call-tracker types.
- cancel() - Method in class alluxio.client.block.stream.BlockOutStream
-
- cancel() - Method in class alluxio.client.block.stream.BlockWorkerDataWriter
-
- cancel() - Method in class alluxio.client.block.stream.GrpcBlockingStream
-
Cancels the stream.
- cancel() - Method in class alluxio.client.block.stream.GrpcDataWriter
-
- cancel() - Method in class alluxio.client.block.stream.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
-
- 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.
- cancelAllPrefetch() - Method in class alluxio.underfs.UfsStatusCache
-
Interrupts and cancels any currently running prefetch jobs.
- 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
-
- canHandleShutdownHooks() - Static method in class alluxio.jnifuse.utils.SecurityUtils
-
- canUseReservedSpace() - Method in class alluxio.worker.block.AllocateOptions
-
- CAPACITY - Static variable in class alluxio.stress.cli.RpcBenchPreparationUtils
-
- Capacity - Class in alluxio.wire
-
Class that represents the available, free, and total capacity.
- Capacity() - Constructor for class alluxio.wire.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;
- CAPACITY_MEM - Static variable in class alluxio.stress.cli.RpcBenchPreparationUtils
-
- 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
-
- cascadingEvict(long, BlockStoreLocation, EvictionPlan, Evictor.Mode) - Method in class alluxio.worker.block.evictor.AbstractEvictor
-
Deprecated.
A recursive implementation of cascading eviction.
- castToIOException(Throwable) - Static method in class alluxio.util.CommonUtils
-
- CATALOG_ID - Static variable in class alluxio.table.under.glue.Property
-
- CATALOG_ID - Static variable in class alluxio.table.under.glue.Property.Name
-
- 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
-
- CDH_PREFIX - Static variable in class alluxio.cli.hdfs.HdfsVersionValidationTask
-
- CephfsHadoopUnderFileSystemFactory - Class in alluxio.underfs.cephfshadoop
-
- CephfsHadoopUnderFileSystemFactory() - Constructor for class alluxio.underfs.cephfshadoop.CephfsHadoopUnderFileSystemFactory
-
- CephFSUnderFileSystem - Class in alluxio.underfs.cephfs
-
- CephFSUnderFileSystem(AlluxioURI, CephMount, UnderFileSystemConfiguration) - Constructor for class alluxio.underfs.cephfs.CephFSUnderFileSystem
-
- CephFSUnderFileSystemFactory - Class in alluxio.underfs.cephfs
-
- CephFSUnderFileSystemFactory() - Constructor for class alluxio.underfs.cephfs.CephFSUnderFileSystemFactory
-
- CephInputStream - Class in alluxio.underfs.cephfs
-
A stream for reading a file from CephFS.
- CephInputStream(CephMount, int, long) - Constructor for class alluxio.underfs.cephfs.CephInputStream
-
Create a new CephInputStream.
- CephOutputStream - Class in alluxio.underfs.cephfs
-
A stream for writing a file into CephFS.
- CephOutputStream(CephMount, int) - Constructor for class alluxio.underfs.cephfs.CephOutputStream
-
Construct the CephOutputStream.
- 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
-
- 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() - Method in class alluxio.cli.fs.command.job.JobAttempt
-
Returns the status of the job attempt.
- check(Clients) - Method in class alluxio.master.backcompat.FsTestOp
-
- check(FileSystem) - Method in class alluxio.master.backcompat.FsTestOp
-
- check(FileSystem) - Method in class alluxio.master.backcompat.ops.AsyncPersist
-
- check(FileSystem) - Method in class alluxio.master.backcompat.ops.CreateDirectory
-
- check(FileSystem) - Method in class alluxio.master.backcompat.ops.CreateFile
-
- check(FileSystem) - Method in class alluxio.master.backcompat.ops.Delete
-
- check(FileSystem) - Method in class alluxio.master.backcompat.ops.Mount
-
- check(FileSystem) - Method in class alluxio.master.backcompat.ops.PersistDirectory
-
- check(Clients) - Method in class alluxio.master.backcompat.ops.PersistFile
-
- check(FileSystem) - Method in class alluxio.master.backcompat.ops.Rename
-
- check(FileSystem) - Method in class alluxio.master.backcompat.ops.SetAcl
-
- check(Clients) - Method in class alluxio.master.backcompat.ops.UpdateUfsMode
-
- check(Clients) - Method in interface alluxio.master.backcompat.TestOp
-
Verifies the result of the test operation.
- checkAccess(AlluxioURI, CheckAccessPOptions) - Method in class alluxio.client.file.BaseFileSystem
-
- checkAccess(AlluxioURI, CheckAccessPOptions) - Method in class alluxio.client.file.DelegatingFileSystem
-
- checkAccess(AlluxioURI, CheckAccessPOptions) - Method in interface alluxio.client.file.FileSystem
-
Checks access to a path.
- checkAccess(AlluxioURI, CheckAccessPOptions) - Method in interface alluxio.client.file.FileSystemMasterClient
-
Check access to a path.
- checkAccess(AlluxioURI, CheckAccessPOptions) - Method in class alluxio.client.file.RetryHandlingFileSystemMasterClient
-
- checkAccess(CheckAccessPRequest) - Method in class alluxio.grpc.FileSystemMasterClientServiceGrpc.FileSystemMasterClientServiceBlockingStub
-
Checks access to path.
- checkAccess(CheckAccessPRequest) - Method in class alluxio.grpc.FileSystemMasterClientServiceGrpc.FileSystemMasterClientServiceFutureStub
-
Checks access to path.
- checkAccess(CheckAccessPRequest, StreamObserver<CheckAccessPResponse>) - Method in class alluxio.grpc.FileSystemMasterClientServiceGrpc.FileSystemMasterClientServiceImplBase
-
Checks access to path.
- checkAccess(CheckAccessPRequest, StreamObserver<CheckAccessPResponse>) - Method in class alluxio.grpc.FileSystemMasterClientServiceGrpc.FileSystemMasterClientServiceStub
-
Checks access to path.
- checkAccess(AlluxioURI, CheckAccessContext) - Method in class alluxio.master.file.DefaultFileSystemMaster
-
- checkAccess(AlluxioURI, CheckAccessContext) - Method in interface alluxio.master.file.FileSystemMaster
-
Checks access to path.
- checkAccess(CheckAccessPRequest, StreamObserver<CheckAccessPResponse>) - Method in class alluxio.master.file.FileSystemMasterClientServiceHandler
-
- CheckAccessContext - Class in alluxio.master.file.contexts
-
- checkAccessDefaults(AlluxioConfiguration) - Static method in class alluxio.util.FileSystemOptions
-
- CheckAccessPOptions - Class in alluxio.grpc
-
Protobuf type alluxio.grpc.file.CheckAccessPOptions
- CheckAccessPOptions.Builder - Class in alluxio.grpc
-
Protobuf type alluxio.grpc.file.CheckAccessPOptions
- CheckAccessPOptionsOrBuilder - Interface in alluxio.grpc
-
- CheckAccessPRequest - Class in alluxio.grpc
-
Protobuf type alluxio.grpc.file.CheckAccessPRequest
- CheckAccessPRequest.Builder - Class in alluxio.grpc
-
Protobuf type alluxio.grpc.file.CheckAccessPRequest
- CheckAccessPRequestOrBuilder - Interface in alluxio.grpc
-
- CheckAccessPResponse - Class in alluxio.grpc
-
Protobuf type alluxio.grpc.file.CheckAccessPResponse
- CheckAccessPResponse.Builder - Class in alluxio.grpc
-
Protobuf type alluxio.grpc.file.CheckAccessPResponse
- CheckAccessPResponseOrBuilder - Interface in alluxio.grpc
-
- checkConflicts() - Method in class alluxio.cli.hdfs.HdfsConfValidationTask
-
- checkConsistency(AlluxioURI, CheckConsistencyPOptions) - Method in interface alluxio.client.file.FileSystemMasterClient
-
Checks the consistency of Alluxio metadata against the under storage for all files and
directories in a given subtree.
- checkConsistency(AlluxioURI, CheckConsistencyPOptions) - Method in class alluxio.client.file.RetryHandlingFileSystemMasterClient
-
- checkConsistency(CheckConsistencyPRequest) - 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
-
- 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.
- 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.
- checkNameservice() - Method in class alluxio.cli.hdfs.HdfsConfValidationTask
-
- checkNumOfArgsEquals(Command, CommandLine, int) - Static method in class alluxio.cli.CommandUtils
-
Checks the number of non-option arguments equals n for command.
- checkNumOfArgsNoLessThan(Command, CommandLine, int) - Static method in class alluxio.cli.CommandUtils
-
Checks the number of non-option arguments is no less than n for command.
- checkNumOfArgsNoMoreThan(Command, CommandLine, int) - Static method in class alluxio.cli.CommandUtils
-
Checks the number of non-option arguments is no more than n for command.
- checkParentPermission(Mode.Bits, LockedInodePath) - Method in class alluxio.master.file.DefaultPermissionChecker
-
- checkParentPermission(Mode.Bits, LockedInodePath) - Method in interface alluxio.master.file.PermissionChecker
-
Checks whether a user has permission to perform a specific action on the parent of the given
path; if parent directory does not exist, treats the closest ancestor directory of the path as
its parent and checks permission on it.
- 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
-
- 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.
- chmod(String, long) - Method in class alluxio.fuse.AlluxioJniFuseFileSystem
-
- chmod(String, long) - Method in class alluxio.fuse.StackFS
-
- chmod(String, long) - Method in interface alluxio.jnifuse.FuseFileSystem
-
- chmodCallback(String, long) - Method in class alluxio.jnifuse.AbstractFuseFileSystem
-
- ChmodCommand - Class in alluxio.cli.fs.command
-
Changes the permission of a file or directory specified by args.
- ChmodCommand(FileSystemContext) - Constructor for class alluxio.cli.fs.command.ChmodCommand
-
- chown(String, long, long) - Method in class alluxio.fuse.AlluxioFuseFileSystem
-
Changes the user and group ownership of an Alluxio file.
- chown(String, long, long) - Method in class alluxio.fuse.AlluxioJniFuseFileSystem
-
- chown(String, long, long) - Method in class alluxio.fuse.StackFS
-
- chown(String, long, long) - Method in interface alluxio.jnifuse.FuseFileSystem
-
- chownCallback(String, long, long) - Method in class alluxio.jnifuse.AbstractFuseFileSystem
-
- ChownCommand - Class in alluxio.cli.fs.command
-
Changes the owner of a file or directory specified by args.
- ChownCommand(FileSystemContext) - Constructor for class alluxio.cli.fs.command.ChownCommand
-
- Chunk - Class in alluxio.grpc
-
The data chunk.
- Chunk.Builder - Class in alluxio.grpc
-
The data chunk.
- CHUNK_FIELD_NUMBER - Static variable in class alluxio.grpc.ReadResponse
-
- CHUNK_FIELD_NUMBER - Static variable in class alluxio.grpc.SnapshotData
-
- CHUNK_FIELD_NUMBER - Static variable in class alluxio.grpc.WriteRequest
-
- CHUNK_SIZE_FIELD_NUMBER - Static variable in class alluxio.grpc.ReadRequest
-
- ChunkOrBuilder - Interface in alluxio.grpc
-
- chunkSize() - Method in class alluxio.client.block.stream.BlockWorkerDataWriter
-
- chunkSize() - Method in interface alluxio.client.block.stream.DataWriter
-
- chunkSize() - Method in class alluxio.client.block.stream.GrpcDataWriter
-
- chunkSize() - Method in class alluxio.client.block.stream.LocalFileDataWriter
-
- chunkSize() - Method in class alluxio.client.block.stream.UfsFallbackLocalFileDataWriter
-
- CLASS_NAME_FIELD - Static variable in interface alluxio.util.JsonSerializable
-
This must match the java field for the class name.
- cleanDirectBuffer(ByteBuffer) - Static method in class alluxio.util.io.BufferUtils
-
Forces to unmap a direct buffer if this buffer is no longer used.
- cleanPath(String) - Static method in class alluxio.util.io.PathUtils
-
Checks and normalizes the given path.
- cleanup() - Method in class alluxio.concurrent.ManagedBlockingUfsForwarder
-
- cleanup(Collection<Long>) - Method in class alluxio.master.job.workflow.WorkflowTracker
-
Recursively cleanup the parent workflows given plans to be removed from the PlanTracker.
- cleanup() - Method in class alluxio.stress.cli.Benchmark
-
Perform post-run cleanups.
- cleanup() - Method in class alluxio.stress.cli.GetPinnedFileIdsBench
-
- cleanup() - Method in class alluxio.stress.cli.RpcBench
-
- cleanup() - Method in class alluxio.underfs.cephfs.CephFSUnderFileSystem
-
- cleanup() - Method in class alluxio.underfs.hdfs.HdfsUnderFileSystem
-
- cleanup() - Method in class alluxio.underfs.local.LocalUnderFileSystem
-
- cleanup() - Method in class alluxio.underfs.ObjectUnderFileSystem
-
- cleanup() - Method in class alluxio.underfs.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
-
- cleanupSessionTempBlocks(long, List<Long>) - Method in class alluxio.worker.block.meta.DefaultStorageDir
-
- cleanupSessionTempBlocks(long, List<Long>) - Method in interface 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.AddQuorumServerRequest.Builder
-
- clear() - Method in class alluxio.grpc.AsyncCacheRequest.Builder
-
- clear() - Method in class alluxio.grpc.AsyncCacheResponse.Builder
-
- clear() - Method in class alluxio.grpc.BackupPOptions.Builder
-
- clear() - Method in class alluxio.grpc.BackupPRequest.Builder
-
- clear() - Method in class alluxio.grpc.BackupPStatus.Builder
-
- clear() - Method in class alluxio.grpc.BackupStatusPRequest.Builder
-
- clear() - Method in class alluxio.grpc.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.CacheRequest.Builder
-
- clear() - Method in class alluxio.grpc.CacheResponse.Builder
-
- clear() - Method in class alluxio.grpc.CancelPOptions.Builder
-
- clear() - Method in class alluxio.grpc.CancelPRequest.Builder
-
- clear() - Method in class alluxio.grpc.CancelPResponse.Builder
-
- clear() - Method in class alluxio.grpc.CancelTaskCommand.Builder
-
- clear() - Method in class alluxio.grpc.CheckAccessPOptions.Builder
-
- clear() - Method in class alluxio.grpc.CheckAccessPRequest.Builder
-
- clear() - Method in class alluxio.grpc.CheckAccessPResponse.Builder
-
- clear() - Method in class alluxio.grpc.CheckConsistencyPOptions.Builder
-
- clear() - Method in class alluxio.grpc.CheckConsistencyPRequest.Builder
-
- clear() - Method in class alluxio.grpc.CheckConsistencyPResponse.Builder
-
- clear() - Method in class alluxio.grpc.CheckpointPOptions.Builder
-
- clear() - Method in class alluxio.grpc.CheckpointPResponse.Builder
-
- clear() - Method in class alluxio.grpc.CheckRequest.Builder
-
- clear() - Method in class alluxio.grpc.CheckResponse.Builder
-
- clear() - Method in class alluxio.grpc.Chunk.Builder
-
- clear() - Method in class alluxio.grpc.ClearMetricsPRequest.Builder
-
- clear() - Method in class alluxio.grpc.ClearMetricsPResponse.Builder
-
- clear() - Method in class alluxio.grpc.ClearMetricsRequest.Builder
-
- clear() - Method in class alluxio.grpc.ClearMetricsResponse.Builder
-
- clear() - Method in class alluxio.grpc.ClientMetrics.Builder
-
- clear() - Method in class alluxio.grpc.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.DownloadSnapshotPRequest.Builder
-
- clear() - Method in class alluxio.grpc.DownloadSnapshotPResponse.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.GetJobStatusDetailedPOptions.Builder
-
- clear() - Method in class alluxio.grpc.GetJobStatusDetailedPRequest.Builder
-
- clear() - Method in class alluxio.grpc.GetJobStatusDetailedPResponse.Builder
-
- clear() - Method in class alluxio.grpc.GetJobStatusPOptions.Builder
-
- clear() - Method in class alluxio.grpc.GetJobStatusPRequest.Builder
-
- clear() - Method in class alluxio.grpc.GetJobStatusPResponse.Builder
-
- clear() - Method in class alluxio.grpc.GetMasterIdPOptions.Builder
-
- clear() - Method in class alluxio.grpc.GetMasterIdPRequest.Builder
-
- clear() - Method in class alluxio.grpc.GetMasterIdPResponse.Builder
-
- clear() - Method in class alluxio.grpc.GetMasterInfoPOptions.Builder
-
- clear() - Method in class alluxio.grpc.GetMasterInfoPResponse.Builder
-
- clear() - Method in class alluxio.grpc.GetMetricsPOptions.Builder
-
- clear() - Method in class alluxio.grpc.GetMetricsPResponse.Builder
-
- clear() - Method in class alluxio.grpc.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.GetSnapshotInfoRequest.Builder
-
- clear() - Method in class alluxio.grpc.GetSnapshotInfoResponse.Builder
-
- clear() - Method in class alluxio.grpc.GetSnapshotRequest.Builder
-
- clear() - Method in class alluxio.grpc.GetStateLockHoldersPOptions.Builder
-
- clear() - Method in class alluxio.grpc.GetStateLockHoldersPRequest.Builder
-
- clear() - Method in class alluxio.grpc.GetStateLockHoldersPResponse.Builder
-
- clear() - Method in class alluxio.grpc.GetStatusPOptions.Builder
-
- clear() - Method in class alluxio.grpc.GetStatusPRequest.Builder
-
- clear() - Method in class alluxio.grpc.GetStatusPResponse.Builder
-
- clear() - Method in class alluxio.grpc.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.JournalQueryRequest.Builder
-
- clear() - Method in class alluxio.grpc.JournalQueryResponse.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.ResetPrioritiesPOptions.Builder
-
- clear() - Method in class alluxio.grpc.ResetPrioritiesPRequest.Builder
-
- clear() - Method in class alluxio.grpc.ResetPrioritiesPResponse.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.SnapshotData.Builder
-
- clear() - Method in class alluxio.grpc.SnapshotMetadata.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.TransferLeadershipPOptions.Builder
-
- clear() - Method in class alluxio.grpc.TransferLeadershipPRequest.Builder
-
- clear() - Method in class alluxio.grpc.TransferLeadershipPResponse.Builder
-
- clear() - Method in class alluxio.grpc.TransportMessage.Builder
-
- clear() - Method in class alluxio.grpc.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.UpdateConfigurationPRequest.Builder
-
- clear() - Method in class alluxio.grpc.UpdateConfigurationPResponse.Builder
-
- clear() - Method in class alluxio.grpc.UpdateMountPRequest.Builder
-
- clear() - Method in class alluxio.grpc.UpdateMountPResponse.Builder
-
- clear() - Method in class alluxio.grpc.UpdateUfsModePOptions.Builder
-
- clear() - Method in class alluxio.grpc.UpdateUfsModePRequest.Builder
-
- clear() - Method in class alluxio.grpc.UpdateUfsModePResponse.Builder
-
- clear() - Method in class alluxio.grpc.UploadSnapshotPRequest.Builder
-
- clear() - Method in class alluxio.grpc.UploadSnapshotPResponse.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.AddTablePartitionsEntry.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;
- clearAddQuorumServerRequest() - Method in class alluxio.grpc.JournalQueryRequest.Builder
-
optional .alluxio.grpc.meta.AddQuorumServerRequest addQuorumServerRequest = 3;
- 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;
- clearAddTablePartitions() - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
-
optional .alluxio.proto.journal.AddTablePartitionsEntry add_table_partitions = 51;
- clearAddTransformJobInfo() - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
-
optional .alluxio.proto.journal.AddTransformJobInfoEntry add_transform_job_info = 46;
- clearAffectedPaths() - Method in class alluxio.grpc.JobInfo.Builder
-
repeated string affectedPaths = 14;
- clearAll() - Method in class alluxio.grpc.table.AllOrNoneSet.Builder
-
optional bool all = 1;
- clearAllMetrics() - Static method in class alluxio.metrics.MetricsSystem
-
Resets the metric registry and removes all the metrics.
- clearAllOrNone() - Method in class alluxio.grpc.table.Domain.Builder
-
.alluxio.grpc.table.AllOrNoneSet all_or_none = 3;
- 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;
- clearAsync() - Method in class alluxio.grpc.CacheRequest.Builder
-
optional bool async = 6;
- clearAsyncPersistOptions() - Method in class alluxio.grpc.CompleteFilePOptions.Builder
-
optional .alluxio.grpc.file.ScheduleAsyncPersistencePOptions asyncPersistOptions = 2;
- clearAsyncPersistRequest() - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
-
optional .alluxio.proto.journal.AsyncPersistRequestEntry async_persist_request = 16;
- 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
-
.alluxio.grpc.table.BinaryColumnStatsData binary_stats = 5;
- clearBits() - Method in class alluxio.grpc.CheckAccessPOptions.Builder
-
optional .alluxio.grpc.Bits bits = 1;
- clearBitVectors() - Method in class alluxio.grpc.table.BinaryColumnStatsData.Builder
-
optional string bit_vectors = 4;
- clearBitVectors() - Method in class alluxio.grpc.table.BooleanColumnStatsData.Builder
-
optional string bit_vectors = 4;
- clearBitVectors() - Method in class alluxio.grpc.table.DateColumnStatsData.Builder
-
optional string bit_vectors = 5;
- clearBitVectors() - Method in class alluxio.grpc.table.DecimalColumnStatsData.Builder
-
optional string bit_vectors = 5;
- clearBitVectors() - Method in class alluxio.grpc.table.DoubleColumnStatsData.Builder
-
optional string bit_vectors = 5;
- clearBitVectors() - Method in class alluxio.grpc.table.LongColumnStatsData.Builder
-
optional string bit_vectors = 5;
- clearBitVectors() - Method in class alluxio.grpc.table.StringColumnStatsData.Builder
-
optional string bit_vectors = 5;
- 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.CacheRequest.Builder
-
optional int64 block_id = 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
-
.alluxio.grpc.table.BooleanColumnStatsData boolean_stats = 1;
- clearBooleanType() - Method in class alluxio.grpc.table.Value.Builder
-
bool boolean_type = 4;
- clearBucketCount() - Method in class alluxio.grpc.table.layout.hive.HiveBucketProperty.Builder
-
optional int64 bucket_count = 2;
- clearBucketedBy() - Method in class alluxio.grpc.table.layout.hive.HiveBucketProperty.Builder
-
repeated string bucketed_by = 1;
- clearBucketProperty() - Method in class alluxio.grpc.table.layout.hive.Storage.Builder
-
optional .alluxio.grpc.table.layout.HiveBucketProperty bucket_property = 3;
- 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.SnapshotData.Builder
-
optional bytes chunk = 3;
- clearChunk() - Method in class alluxio.grpc.WriteRequest.Builder
-
.alluxio.grpc.block.Chunk chunk = 2;
- clearChunkSize() - Method in class alluxio.grpc.ReadRequest.Builder
-
optional int64 chunk_size = 5;
- 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
-
.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.CheckAccessPOptions.Builder
-
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 2;
- clearCommonOptions() - Method in class alluxio.grpc.CheckConsistencyPOptions.Builder
-
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 1;
- clearCommonOptions() - Method in class alluxio.grpc.CompleteFilePOptions.Builder
-
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 3;
- clearCommonOptions() - Method in class alluxio.grpc.CreateDirectoryPOptions.Builder
-
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 5;
- clearCommonOptions() - Method in class alluxio.grpc.CreateFilePOptions.Builder
-
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 9;
- clearCommonOptions() - Method in class alluxio.grpc.DeletePOptions.Builder
-
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 4;
- clearCommonOptions() - Method in class alluxio.grpc.ExistsPOptions.Builder
-
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 2;
- clearCommonOptions() - Method in class alluxio.grpc.FreePOptions.Builder
-
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 3;
- clearCommonOptions() - Method in class alluxio.grpc.GetNewBlockIdForFilePOptions.Builder
-
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 1;
- clearCommonOptions() - Method in class alluxio.grpc.GetStatusPOptions.Builder
-
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 2;
- clearCommonOptions() - Method in class alluxio.grpc.ListStatusPOptions.Builder
-
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 3;
- clearCommonOptions() - Method in class alluxio.grpc.LoadMetadataPOptions.Builder
-
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 4;
- clearCommonOptions() - Method in class alluxio.grpc.MountPOptions.Builder
-
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 4;
- clearCommonOptions() - Method in class alluxio.grpc.OpenFilePOptions.Builder
-
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 3;
- clearCommonOptions() - Method in class alluxio.grpc.RenamePOptions.Builder
-
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 1;
- clearCommonOptions() - Method in class alluxio.grpc.ScheduleAsyncPersistencePOptions.Builder
-
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 1;
- clearCommonOptions() - Method in class alluxio.grpc.SetAclPOptions.Builder
-
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 1;
- clearCommonOptions() - Method in class alluxio.grpc.SetAttributePOptions.Builder
-
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 9;
- clearCommonOptions() - Method in class alluxio.grpc.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;
- clearContainerHost() - Method in class alluxio.grpc.WorkerNetAddress.Builder
-
optional string containerHost = 7;
- clearContainerId() - Method in class alluxio.proto.journal.File.InodeDirectoryIdGeneratorEntry.Builder
-
optional int64 container_id = 1;
- 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.DownloadSnapshotPResponse.Builder
-
optional .alluxio.grpc.meta.SnapshotData data = 1;
- clearData() - Method in class alluxio.grpc.table.ColumnStatisticsData.Builder
-
- clearData() - Method in class alluxio.grpc.table.ColumnStatisticsInfo.Builder
-
optional .alluxio.grpc.table.ColumnStatisticsData data = 3;
- clearData() - Method in class alluxio.grpc.UploadSnapshotPRequest.Builder
-
optional .alluxio.grpc.meta.SnapshotData data = 1;
- clearDatabase() - Method in class alluxio.grpc.table.GetAllDatabasesPResponse.Builder
-
repeated string database = 1;
- clearDatabase() - Method in class alluxio.grpc.table.GetAllTablesPRequest.Builder
-
optional string database = 1;
- clearDataCols() - Method in class alluxio.grpc.table.layout.hive.PartitionInfo.Builder
-
repeated .alluxio.grpc.table.FieldSchema data_cols = 6;
- clearDataPort() - Method in class alluxio.grpc.WorkerNetAddress.Builder
-
optional int32 dataPort = 3;
- clearDateStats() - Method in class alluxio.grpc.table.ColumnStatisticsData.Builder
-
.alluxio.grpc.table.DateColumnStatsData date_stats = 7;
- clearDaysSinceEpoch() - Method in class alluxio.grpc.table.Date.Builder
-
required int64 days_since_epoch = 1;
- clearDb() - Method in class alluxio.grpc.table.GetDatabasePResponse.Builder
-
optional .alluxio.grpc.table.Database db = 1;
- clearDbName() - Method in class alluxio.grpc.table.AttachDatabasePRequest.Builder
-
optional string db_name = 4;
- clearDbName() - Method in class alluxio.grpc.table.Database.Builder
-
optional string db_name = 1;
- clearDbName() - Method in class alluxio.grpc.table.DetachDatabasePRequest.Builder
-
optional string db_name = 1;
- clearDbName() - Method in class alluxio.grpc.table.GetDatabasePRequest.Builder
-
optional string db_name = 1;
- clearDbName() - Method in class alluxio.grpc.table.GetPartitionColumnStatisticsPRequest.Builder
-
optional string db_name = 1;
- clearDbName() - Method in class alluxio.grpc.table.GetTableColumnStatisticsPRequest.Builder
-
optional string db_name = 1;
- clearDbName() - Method in class alluxio.grpc.table.GetTablePRequest.Builder
-
optional string db_name = 1;
- clearDbName() - Method in class alluxio.grpc.table.layout.hive.PartitionInfo.Builder
-
optional string db_name = 3;
- clearDbName() - Method in class alluxio.grpc.table.ReadTablePRequest.Builder
-
optional string db_name = 1;
- clearDbName() - Method in class alluxio.grpc.table.SyncDatabasePRequest.Builder
-
optional string db_name = 1;
- clearDbName() - Method in class alluxio.grpc.table.TableInfo.Builder
-
optional string db_name = 1;
- clearDbName() - Method in class alluxio.grpc.table.TransformJobInfo.Builder
-
optional string db_name = 1;
- clearDbName() - Method in class alluxio.grpc.table.TransformTablePRequest.Builder
-
optional string db_name = 1;
- clearDbName() - Method in class alluxio.proto.journal.Table.AddTableEntry.Builder
-
optional string db_name = 1;
- clearDbName() - Method in class alluxio.proto.journal.Table.AddTablePartitionsEntry.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
-
.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
-
.alluxio.grpc.table.DoubleColumnStatsData double_stats = 3;
- clearDoubleType() - Method in class alluxio.grpc.table.Value.Builder
-
double double_type = 2;
- clearDoubleValue() - Method in class alluxio.grpc.MetricValue.Builder
-
optional double doubleValue = 1;
- 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;
- clearEof() - Method in class alluxio.grpc.SnapshotData.Builder
-
optional bool eof = 5;
- clearEquatable() - Method in class alluxio.grpc.table.Domain.Builder
-
.alluxio.grpc.table.EquatableValueSet equatable = 2;
- clearErrorMessage() - Method in class alluxio.grpc.JobInfo.Builder
-
optional string errorMessage = 2;
- clearErrors() - Method in class alluxio.grpc.ConfigCheckReport.Builder
-
- clearErrorType() - Method in class alluxio.grpc.JobInfo.Builder
-
optional string errorType = 15;
- 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.AddQuorumServerRequest.Builder
-
- clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.AsyncCacheRequest.Builder
-
- clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.AsyncCacheResponse.Builder
-
- clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.BackupPOptions.Builder
-
- clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.BackupPRequest.Builder
-
- clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.BackupPStatus.Builder
-
- clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.BackupStatusPRequest.Builder
-
- clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.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.CacheRequest.Builder
-
- clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.CacheResponse.Builder
-
- clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.CancelPOptions.Builder
-
- clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.CancelPRequest.Builder
-
- clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.CancelPResponse.Builder
-
- clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.CancelTaskCommand.Builder
-
- clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.CheckAccessPOptions.Builder
-
- clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.CheckAccessPRequest.Builder
-
- clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.CheckAccessPResponse.Builder
-
- clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.CheckConsistencyPOptions.Builder
-
- clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.CheckConsistencyPRequest.Builder
-
- clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.CheckConsistencyPResponse.Builder
-
- clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.CheckpointPOptions.Builder
-
- clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.CheckpointPResponse.Builder
-
- clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.CheckRequest.Builder
-
- clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.CheckResponse.Builder
-
- clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.Chunk.Builder
-
- clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.ClearMetricsPRequest.Builder
-
- clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.ClearMetricsPResponse.Builder
-
- clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.ClearMetricsRequest.Builder
-
- clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.ClearMetricsResponse.Builder
-
- clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.ClientMetrics.Builder
-
- clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.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.DownloadSnapshotPRequest.Builder
-
- clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.DownloadSnapshotPResponse.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.GetJobStatusDetailedPOptions.Builder
-
- clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.GetJobStatusDetailedPRequest.Builder
-
- clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.GetJobStatusDetailedPResponse.Builder
-
- clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.GetJobStatusPOptions.Builder
-
- clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.GetJobStatusPRequest.Builder
-
- clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.GetJobStatusPResponse.Builder
-
- clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.GetMasterIdPOptions.Builder
-
- clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.GetMasterIdPRequest.Builder
-
- clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.GetMasterIdPResponse.Builder
-
- clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.GetMasterInfoPOptions.Builder
-
- clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.GetMasterInfoPResponse.Builder
-
- clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.GetMetricsPOptions.Builder
-
- clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.GetMetricsPResponse.Builder
-
- clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.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.GetSnapshotInfoRequest.Builder
-
- clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.GetSnapshotInfoResponse.Builder
-
- clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.GetSnapshotRequest.Builder
-
- clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.GetStateLockHoldersPOptions.Builder
-
- clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.GetStateLockHoldersPRequest.Builder
-
- clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.GetStateLockHoldersPResponse.Builder
-
- clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.GetStatusPOptions.Builder
-
- clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.GetStatusPRequest.Builder
-
- clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.GetStatusPResponse.Builder
-
- clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.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.JournalQueryRequest.Builder
-
- clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.JournalQueryResponse.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.ResetPrioritiesPOptions.Builder
-
- clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.ResetPrioritiesPRequest.Builder
-
- clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.ResetPrioritiesPResponse.Builder
-
- clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.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.SnapshotData.Builder
-
- clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.SnapshotMetadata.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.TransferLeadershipPOptions.Builder
-
- clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.TransferLeadershipPRequest.Builder
-
- clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.TransferLeadershipPResponse.Builder
-
- clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.TransportMessage.Builder
-
- clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.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.UpdateConfigurationPRequest.Builder
-
- clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.UpdateConfigurationPResponse.Builder
-
- clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.UpdateMountPRequest.Builder
-
- clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.UpdateMountPResponse.Builder
-
- clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.UpdateUfsModePOptions.Builder
-
- clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.UpdateUfsModePRequest.Builder
-
- clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.UpdateUfsModePResponse.Builder
-
- clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.UploadSnapshotPRequest.Builder
-
- clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.UploadSnapshotPResponse.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.AddTablePartitionsEntry.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;
- clearIsLeader() - Method in class alluxio.grpc.QuorumServerInfo.Builder
-
optional bool isLeader = 3;
- 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.GetJobStatusDetailedPRequest.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;
- clearJobIdOnly() - Method in class alluxio.grpc.ListAllPOptions.Builder
-
optional bool jobIdOnly = 3;
- clearJobIds() - Method in class alluxio.grpc.ListAllPResponse.Builder
-
repeated int64 jobIds = 1;
- clearJobInfo() - Method in class alluxio.grpc.GetJobStatusDetailedPResponse.Builder
-
optional .alluxio.grpc.job.JobInfo jobInfo = 1;
- clearJobInfo() - Method in class alluxio.grpc.GetJobStatusPResponse.Builder
-
optional .alluxio.grpc.job.JobInfo jobInfo = 1;
- clearJobInfos() - Method in class alluxio.grpc.ListAllPResponse.Builder
-
repeated .alluxio.grpc.job.JobInfo jobInfos = 2;
- 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;
- clearLatest() - Method in class alluxio.grpc.GetSnapshotInfoResponse.Builder
-
optional .alluxio.grpc.meta.SnapshotMetadata latest = 1;
- 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.CacheRequest.Builder
-
optional int64 length = 5;
- 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.
- clearLoadMetadataOnly() - Method in class alluxio.grpc.ListStatusPOptions.Builder
-
No data will be transferred.
- 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;
- clearLoadType() - Method in class alluxio.grpc.LoadMetadataPOptions.Builder
-
optional .alluxio.grpc.file.LoadMetadataPType loadType = 5;
- clearLocalFileSystem() - Method in class alluxio.grpc.BackupPOptions.Builder
-
optional bool localFileSystem = 1;
- clearLocation() - Method in class alluxio.grpc.table.Database.Builder
-
optional string location = 3;
- clearLocation() - Method in class alluxio.grpc.table.layout.hive.Storage.Builder
-
optional string location = 2;
- 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
-
.alluxio.grpc.table.LongColumnStatsData long_stats = 2;
- clearLongType() - Method in class alluxio.grpc.table.Value.Builder
-
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.FileInfo.Builder
-
repeated string mediumType = 33;
- clearMediumType() - Method in class alluxio.grpc.MoveBlockRequest.Builder
-
optional string medium_type = 2;
- clearMediumType() - Method in class alluxio.grpc.WriteRequestCommand.Builder
-
optional string medium_type = 8;
- clearMediumType() - Method in class alluxio.proto.journal.File.InodeDirectoryEntry.Builder
-
repeated string medium_type = 18;
- clearMediumType() - Method in class alluxio.proto.journal.File.InodeFileEntry.Builder
-
repeated string medium_type = 26;
- clearMediumType() - Method in class alluxio.proto.journal.File.UpdateInodeEntry.Builder
-
repeated string medium_type = 16;
- clearMediumType() - Method in class alluxio.proto.meta.Block.BlockLocation.Builder
-
optional string mediumType = 3;
- clearMediumType() - Method in class alluxio.proto.meta.InodeMeta.Inode.Builder
-
repeated string medium_type = 27;
- clearMessage() - Method in class alluxio.grpc.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.BlockWorkerClientServiceHandler
-
- 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.grpc.MountPointInfo.Builder
-
optional int64 mountId = 8;
- 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
- clearName() - Method in class alluxio.grpc.ListAllPOptions.Builder
-
optional string name = 2;
- clearName() - Method in class alluxio.grpc.Metric.Builder
-
optional string name = 3;
- clearName() - Method in class alluxio.grpc.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.SnapshotData.Builder
-
optional int64 offset = 4;
- 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.DownloadSnapshotPRequest.Builder
-
optional int64 offsetReceived = 1;
- clearOffsetReceived() - Method in class alluxio.grpc.ReadRequest.Builder
-
Read receipt
- clearOffsetReceived() - Method in class alluxio.grpc.UploadSnapshotPResponse.Builder
-
optional int64 offsetReceived = 1;
- clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.AddQuorumServerRequest.Builder
-
- clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.AsyncCacheRequest.Builder
-
- clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.AsyncCacheResponse.Builder
-
- clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.BackupPOptions.Builder
-
- clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.BackupPRequest.Builder
-
- clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.BackupPStatus.Builder
-
- clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.BackupStatusPRequest.Builder
-
- clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.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.CacheRequest.Builder
-
- clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.CacheResponse.Builder
-
- clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.CancelPOptions.Builder
-
- clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.CancelPRequest.Builder
-
- clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.CancelPResponse.Builder
-
- clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.CancelTaskCommand.Builder
-
- clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.CheckAccessPOptions.Builder
-
- clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.CheckAccessPRequest.Builder
-
- clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.CheckAccessPResponse.Builder
-
- clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.CheckConsistencyPOptions.Builder
-
- clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.CheckConsistencyPRequest.Builder
-
- clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.CheckConsistencyPResponse.Builder
-
- clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.CheckpointPOptions.Builder
-
- clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.CheckpointPResponse.Builder
-
- clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.CheckRequest.Builder
-
- clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.CheckResponse.Builder
-
- clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.Chunk.Builder
-
- clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.ClearMetricsPRequest.Builder
-
- clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.ClearMetricsPResponse.Builder
-
- clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.ClearMetricsRequest.Builder
-
- clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.ClearMetricsResponse.Builder
-
- clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.ClientMetrics.Builder
-
- clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.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.DownloadSnapshotPRequest.Builder
-
- clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.DownloadSnapshotPResponse.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.GetJobStatusDetailedPOptions.Builder
-
- clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.GetJobStatusDetailedPRequest.Builder
-
- clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.GetJobStatusDetailedPResponse.Builder
-
- clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.GetJobStatusPOptions.Builder
-
- clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.GetJobStatusPRequest.Builder
-
- clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.GetJobStatusPResponse.Builder
-
- clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.GetMasterIdPOptions.Builder
-
- clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.GetMasterIdPRequest.Builder
-
- clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.GetMasterIdPResponse.Builder
-
- clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.GetMasterInfoPOptions.Builder
-
- clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.GetMasterInfoPResponse.Builder
-
- clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.GetMetricsPOptions.Builder
-
- clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.GetMetricsPResponse.Builder
-
- clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.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.GetSnapshotInfoRequest.Builder
-
- clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.GetSnapshotInfoResponse.Builder
-
- clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.GetSnapshotRequest.Builder
-
- clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.GetStateLockHoldersPOptions.Builder
-
- clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.GetStateLockHoldersPRequest.Builder
-
- clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.GetStateLockHoldersPResponse.Builder
-
- clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.GetStatusPOptions.Builder
-
- clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.GetStatusPRequest.Builder
-
- clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.GetStatusPResponse.Builder
-
- clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.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.JournalQueryRequest.Builder
-
- clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.JournalQueryResponse.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.ResetPrioritiesPOptions.Builder
-
- clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.ResetPrioritiesPRequest.Builder
-
- clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.ResetPrioritiesPResponse.Builder
-
- clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.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.SnapshotData.Builder
-
- clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.SnapshotMetadata.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.TransferLeadershipPOptions.Builder
-
- clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.TransferLeadershipPRequest.Builder
-
- clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.TransferLeadershipPResponse.Builder
-
- clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.TransportMessage.Builder
-
- clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.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.UpdateConfigurationPRequest.Builder
-
- clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.UpdateConfigurationPResponse.Builder
-
- clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.UpdateMountPRequest.Builder
-
- clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.UpdateMountPResponse.Builder
-
- clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.UpdateUfsModePOptions.Builder
-
- clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.UpdateUfsModePRequest.Builder
-
- clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.UpdateUfsModePResponse.Builder
-
- clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.UploadSnapshotPRequest.Builder
-
- clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.UploadSnapshotPResponse.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.AddTablePartitionsEntry.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.CacheRequest.Builder
-
optional .alluxio.proto.dataserver.OpenUfsBlockOptions open_ufs_block_options = 4;
- clearOpenUfsBlockOptions() - Method in class alluxio.grpc.ReadRequest.Builder
-
This is only set for UFS block read.
- 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.CheckAccessPRequest.Builder
-
optional .alluxio.grpc.file.CheckAccessPOptions options = 2;
- clearOptions() - Method in class alluxio.grpc.CheckConsistencyPRequest.Builder
-
optional .alluxio.grpc.file.CheckConsistencyPOptions options = 2;
- clearOptions() - Method in class alluxio.grpc.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.GetJobStatusDetailedPRequest.Builder
-
optional .alluxio.grpc.job.GetJobStatusDetailedPOptions options = 2;
- clearOptions() - Method in class alluxio.grpc.GetJobStatusPRequest.Builder
-
optional .alluxio.grpc.job.GetJobStatusPOptions options = 2;
- clearOptions() - Method in class alluxio.grpc.GetMasterIdPRequest.Builder
-
optional .alluxio.grpc.meta.GetMasterIdPOptions options = 2;
- clearOptions() - Method in class alluxio.grpc.GetNewBlockIdForFilePRequest.Builder
-
optional .alluxio.grpc.file.GetNewBlockIdForFilePOptions options = 2;
- clearOptions() - Method in class alluxio.grpc.GetPinnedFileIdsPRequest.Builder
-
optional .alluxio.grpc.file.GetPinnedFileIdsPOptions options = 1;
- clearOptions() - Method in class alluxio.grpc.GetQuorumInfoPRequest.Builder
-
optional .alluxio.grpc.journal.GetQuorumInfoPOptions options = 1;
- clearOptions() - Method in class alluxio.grpc.GetStateLockHoldersPRequest.Builder
-
optional .alluxio.grpc.file.GetStateLockHoldersPOptions options = 1;
- clearOptions() - Method in class alluxio.grpc.GetStatusPRequest.Builder
-
optional .alluxio.grpc.file.GetStatusPOptions options = 2;
- clearOptions() - Method in class alluxio.grpc.GetUfsInfoPRequest.Builder
-
optional .alluxio.grpc.file.GetUfsInfoPOptions options = 2;
- clearOptions() - Method in class alluxio.grpc.GetWorkerIdPRequest.Builder
-
optional .alluxio.grpc.block.GetWorkerIdPOptions options = 2;
- clearOptions() - Method in class alluxio.grpc.JobHeartbeatPRequest.Builder
-
optional .alluxio.grpc.job.JobHeartbeatPOptions options = 3;
- clearOptions() - Method in class alluxio.grpc.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.ResetPrioritiesPRequest.Builder
-
optional .alluxio.grpc.journal.ResetPrioritiesPOptions options = 1;
- clearOptions() - Method in class alluxio.grpc.RunPRequest.Builder
-
optional .alluxio.grpc.job.RunPOptions options = 2;
- clearOptions() - Method in class alluxio.grpc.ScheduleAsyncPersistencePRequest.Builder
-
optional .alluxio.grpc.file.ScheduleAsyncPersistencePOptions options = 2;
- clearOptions() - Method in class alluxio.grpc.SetAclPRequest.Builder
-
the method options
- clearOptions() - Method in class alluxio.grpc.SetAttributePRequest.Builder
-
optional .alluxio.grpc.file.SetAttributePOptions options = 2;
- clearOptions() - Method in class alluxio.grpc.SetPathConfigurationPRequest.Builder
-
optional .alluxio.grpc.meta.SetPathConfigurationPOptions options = 3;
- clearOptions() - Method in class alluxio.grpc.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.TransferLeadershipPRequest.Builder
-
optional .alluxio.grpc.journal.TransferLeadershipPOptions options = 1;
- clearOptions() - Method in class alluxio.grpc.UnmountPRequest.Builder
-
optional .alluxio.grpc.file.UnmountPOptions options = 2;
- clearOptions() - Method in class alluxio.grpc.UpdateMountPRequest.Builder
-
optional .alluxio.grpc.file.MountPOptions options = 3;
- clearOptions() - Method in class alluxio.grpc.UpdateUfsModePRequest.Builder
-
optional .alluxio.grpc.file.UpdateUfsModePOptions options = 2;
- 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;
- clearPartitions() - Method in class alluxio.proto.journal.Table.AddTablePartitionsEntry.Builder
-
repeated .alluxio.grpc.table.Partition partitions = 4;
- clearPartitionSpec() - Method in class alluxio.grpc.table.Partition.Builder
-
optional .alluxio.grpc.table.PartitionSpec partition_spec = 1;
- clearPartitionStatistics() - Method in class alluxio.grpc.table.GetPartitionColumnStatisticsPResponse.Builder
-
- clearPartNames() - Method in class alluxio.grpc.table.GetPartitionColumnStatisticsPRequest.Builder
-
repeated string part_names = 4;
- clearPath() - Method in class alluxio.grpc.CheckAccessPRequest.Builder
-
optional string path = 1;
- clearPath() - Method in class alluxio.grpc.CheckConsistencyPRequest.Builder
-
the root of the subtree to check
- clearPath() - Method in class alluxio.grpc.CompleteFilePRequest.Builder
-
the path of the file
- clearPath() - Method in class alluxio.grpc.CreateDirectoryPRequest.Builder
-
the path of the directory
- clearPath() - Method in class alluxio.grpc.CreateFilePRequest.Builder
-
the path of the file
- clearPath() - Method in class alluxio.grpc.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;
- clearPriority() - Method in class alluxio.grpc.QuorumServerInfo.Builder
-
optional int32 priority = 4;
- 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.grpc.UpdateConfigurationPRequest.Builder
-
- clearProperties() - Method in class alluxio.proto.journal.File.AddMountPointEntry.Builder
-
repeated .alluxio.proto.journal.StringPairEntry properties = 4;
- clearProperties() - Method in class alluxio.proto.journal.Meta.PathPropertiesEntry.Builder
-
- clearRange() - Method in class alluxio.grpc.table.Domain.Builder
-
.alluxio.grpc.table.RangeSet range = 1;
- clearRanges() - Method in class alluxio.grpc.table.RangeSet.Builder
-
repeated .alluxio.grpc.table.Range ranges = 1;
- clearRawValue() - Method in class alluxio.grpc.GetConfigurationPOptions.Builder
-
optional bool rawValue = 1;
- clearReadOnly() - Method in class alluxio.grpc.MountPointInfo.Builder
-
optional bool readOnly = 5;
- clearReadOnly() - Method in class alluxio.grpc.MountPOptions.Builder
-
optional bool readOnly = 1;
- clearReadOnly() - Method in class alluxio.proto.journal.File.AddMountPointEntry.Builder
-
optional bool readOnly = 3;
- clearReadType() - Method in class alluxio.grpc.OpenFilePOptions.Builder
-
optional .alluxio.grpc.file.ReadPType readType = 1;
- clearRecentActivities() - Method in class alluxio.grpc.JobServiceSummary.Builder
-
repeated .alluxio.grpc.job.JobInfo recentActivities = 2;
- clearRecentFailures() - Method in class alluxio.grpc.JobServiceSummary.Builder
-
repeated .alluxio.grpc.job.JobInfo recentFailures = 3;
- clearRecursive() - Method in class alluxio.grpc.CreateDirectoryPOptions.Builder
-
optional bool recursive = 1;
- clearRecursive() - Method in class alluxio.grpc.CreateFilePOptions.Builder
-
optional bool recursive = 2;
- clearRecursive() - Method in class alluxio.grpc.DeletePOptions.Builder
-
optional bool recursive = 1;
- clearRecursive() - Method in class alluxio.grpc.FreePOptions.Builder
-
optional bool recursive = 1;
- clearRecursive() - Method in class alluxio.grpc.ListStatusPOptions.Builder
-
optional bool recursive = 4;
- clearRecursive() - Method in class alluxio.grpc.LoadMetadataPOptions.Builder
-
whether to load metadata recursively
- clearRecursive() - Method in class alluxio.grpc.SetAclPOptions.Builder
-
optional bool recursive = 2;
- clearRecursive() - Method in class alluxio.grpc.SetAttributePOptions.Builder
-
optional bool recursive = 6;
- clearRecursive() - Method in class alluxio.proto.journal.File.DeleteFileEntry.Builder
-
Deprecated, we now write one journal entry per inode removed
- clearRecursive() - Method in class alluxio.proto.journal.File.SetAclEntry.Builder
-
optional bool recursive = 5;
- clearRegisterCommand() - Method in class alluxio.grpc.JobCommand.Builder
-
optional .alluxio.grpc.job.RegisterCommand registerCommand = 3;
- clearRemovedBlockIds() - Method in class alluxio.grpc.BlockHeartbeatPRequest.Builder
-
the list of removed block ids
- clearRemovePathProperties() - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
-
optional .alluxio.proto.journal.RemovePathPropertiesEntry remove_path_properties = 41;
- clearRemoveSyncPoint() - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
-
optional .alluxio.proto.journal.RemoveSyncPointEntry remove_sync_point = 33;
- 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.AddQuorumServerRequest.Builder
-
optional .alluxio.grpc.NetAddress serverAddress = 1;
- clearServerAddress() - Method in class alluxio.grpc.QuorumServerInfo.Builder
-
optional .alluxio.grpc.NetAddress serverAddress = 1;
- clearServerAddress() - Method in class alluxio.grpc.RemoveQuorumServerPRequest.Builder
-
optional .alluxio.grpc.NetAddress serverAddress = 2;
- clearServerAddress() - Method in class alluxio.grpc.TransferLeadershipPRequest.Builder
-
optional .alluxio.grpc.NetAddress serverAddress = 2;
- clearServerInfo() - Method in class alluxio.grpc.GetQuorumInfoPResponse.Builder
-
repeated .alluxio.grpc.journal.QuorumServerInfo serverInfo = 2;
- clearServerState() - Method in class alluxio.grpc.QuorumServerInfo.Builder
-
optional .alluxio.grpc.journal.QuorumServerState serverState = 2;
- clearServiceType() - Method in class alluxio.grpc.GetServiceVersionPRequest.Builder
-
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;
- clearSnapshotIndex() - Method in class alluxio.grpc.SnapshotData.Builder
-
optional int64 snapshotIndex = 2;
- clearSnapshotIndex() - Method in class alluxio.grpc.SnapshotMetadata.Builder
-
optional int64 snapshotIndex = 2;
- clearSnapshotInfoRequest() - Method in class alluxio.grpc.JournalQueryRequest.Builder
-
optional .alluxio.grpc.meta.GetSnapshotInfoRequest snapshotInfoRequest = 1;
- clearSnapshotInfoResponse() - Method in class alluxio.grpc.JournalQueryResponse.Builder
-
optional .alluxio.grpc.meta.GetSnapshotInfoResponse snapshotInfoResponse = 1;
- clearSnapshotRequest() - Method in class alluxio.grpc.JournalQueryRequest.Builder
-
optional .alluxio.grpc.meta.GetSnapshotRequest snapshotRequest = 2;
- clearSnapshotTerm() - Method in class alluxio.grpc.SnapshotData.Builder
-
optional int64 snapshotTerm = 1;
- clearSnapshotTerm() - Method in class alluxio.grpc.SnapshotMetadata.Builder
-
optional int64 snapshotTerm = 1;
- clearSortedBy() - Method in class alluxio.grpc.table.layout.hive.HiveBucketProperty.Builder
-
repeated .alluxio.grpc.table.layout.SortingColumn sorted_by = 3;
- clearSource() - Method in class alluxio.grpc.ClientMetrics.Builder
-
optional string source = 1;
- clearSource() - Method in class alluxio.grpc.ConfigProperty.Builder
-
optional string source = 2;
- clearSource() - Method in class alluxio.grpc.Metric.Builder
-
optional string source = 2;
- clearSourceHost() - Method in class alluxio.grpc.AsyncCacheRequest.Builder
-
TODO(calvin): source host and port should be replace with WorkerNetAddress
- clearSourceHost() - Method in class alluxio.grpc.CacheRequest.Builder
-
TODO(calvin): source host and port should be replace with WorkerNetAddress
- clearSourcePort() - Method in class alluxio.grpc.AsyncCacheRequest.Builder
-
optional int32 source_port = 3;
- clearSourcePort() - Method in class alluxio.grpc.CacheRequest.Builder
-
optional int32 source_port = 3;
- clearSpaceToReserve() - Method in class alluxio.grpc.CreateLocalBlockRequest.Builder
-
optional int64 space_to_reserve = 4;
- clearSpaceToReserve() - Method in class alluxio.grpc.WriteRequestCommand.Builder
-
optional int64 space_to_reserve = 10;
- 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;
- 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.ListAllPOptions.Builder
-
repeated .alluxio.grpc.job.Status status = 1;
- clearStatus() - Method in class alluxio.grpc.StatusSummary.Builder
-
optional .alluxio.grpc.job.Status status = 1;
- clearStatus() - Method in class alluxio.grpc.table.SyncDatabasePResponse.Builder
-
optional .alluxio.grpc.table.SyncStatus status = 2;
- clearStatus() - Method in class alluxio.grpc.UpdateConfigurationPResponse.Builder
-
- clearStatus() - Method in class alluxio.proto.dataserver.Protocol.Response.Builder
-
optional .alluxio.proto.status.PStatus status = 1;
- clearStorage() - Method in class alluxio.grpc.StorageList.Builder
-
a lost storage path
- clearStorage() - Method in class alluxio.grpc.table.layout.hive.PartitionInfo.Builder
-
optional .alluxio.grpc.table.layout.Storage storage = 5;
- clearStorageFormat() - Method in class alluxio.grpc.table.layout.hive.Storage.Builder
-
optional .alluxio.grpc.table.layout.StorageFormat storage_format = 1;
- clearStorageTiers() - Method in class alluxio.grpc.RegisterWorkerPRequest.Builder
-
the list of storage tiers
- clearStringStats() - Method in class alluxio.grpc.table.ColumnStatisticsData.Builder
-
.alluxio.grpc.table.StringColumnStatsData string_stats = 4;
- clearStringType() - Method in class alluxio.grpc.table.Value.Builder
-
string string_type = 3;
- clearStringValue() - Method in class alluxio.grpc.MetricValue.Builder
-
optional string stringValue = 2;
- clearSubject() - Method in class alluxio.grpc.PAclEntry.Builder
-
optional string subject = 2;
- clearSubject() - Method in class alluxio.proto.shared.Acl.AclEntry.Builder
-
optional string subject = 2;
- 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.AddTablePartitionsEntry.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;
- clearThreads() - Method in class alluxio.grpc.GetStateLockHoldersPResponse.Builder
-
repeated string threads = 1;
- 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.AddTablePartitionsEntry.Builder
-
optional int64 version = 3;
- 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
-
Creates a new Grpc messaging client.
- CLIENT_BLOCK_READ_CHUNK_REMOTE - Static variable in class alluxio.metrics.MetricKey
-
- CLIENT_BYTES_READ_LOCAL - Static variable in class alluxio.metrics.MetricKey
-
- CLIENT_BYTES_READ_LOCAL_THROUGHPUT - Static variable in class alluxio.metrics.MetricKey
-
- CLIENT_BYTES_WRITTEN_LOCAL - Static variable in class alluxio.metrics.MetricKey
-
- CLIENT_BYTES_WRITTEN_LOCAL_THROUGHPUT - Static variable in class alluxio.metrics.MetricKey
-
- CLIENT_BYTES_WRITTEN_UFS - Static variable in class alluxio.metrics.MetricKey
-
- CLIENT_CACHE_BYTES_EVICTED - Static variable in class alluxio.metrics.MetricKey
-
- CLIENT_CACHE_BYTES_READ_CACHE - Static variable in class alluxio.metrics.MetricKey
-
- CLIENT_CACHE_BYTES_READ_EXTERNAL - Static variable in class alluxio.metrics.MetricKey
-
- CLIENT_CACHE_BYTES_REQUESTED_EXTERNAL - Static variable in class alluxio.metrics.MetricKey
-
- CLIENT_CACHE_BYTES_WRITTEN_CACHE - Static variable in class alluxio.metrics.MetricKey
-
- CLIENT_CACHE_CLEAN_ERRORS - Static variable in class alluxio.metrics.MetricKey
-
- CLIENT_CACHE_CLEANUP_GET_ERRORS - Static variable in class alluxio.metrics.MetricKey
-
- CLIENT_CACHE_CLEANUP_PUT_ERRORS - Static variable in class alluxio.metrics.MetricKey
-
- CLIENT_CACHE_CREATE_ERRORS - Static variable in class alluxio.metrics.MetricKey
-
- CLIENT_CACHE_DELETE_ERRORS - Static variable in class alluxio.metrics.MetricKey
-
- CLIENT_CACHE_DELETE_FROM_STORE_ERRORS - Static variable in class alluxio.metrics.MetricKey
-
- CLIENT_CACHE_DELETE_NON_EXISTING_PAGE_ERRORS - Static variable in class alluxio.metrics.MetricKey
-
- CLIENT_CACHE_DELETE_NOT_READY_ERRORS - Static variable in class alluxio.metrics.MetricKey
-
- CLIENT_CACHE_GET_ERRORS - Static variable in class alluxio.metrics.MetricKey
-
- CLIENT_CACHE_GET_NOT_READY_ERRORS - Static variable in class alluxio.metrics.MetricKey
-
- CLIENT_CACHE_GET_STORE_READ_ERRORS - Static variable in class alluxio.metrics.MetricKey
-
- CLIENT_CACHE_HIT_RATE - Static variable in class alluxio.metrics.MetricKey
-
- CLIENT_CACHE_PAGE_READ_CACHE_TIME_NS - Static variable in class alluxio.metrics.MetricKey
-
- CLIENT_CACHE_PAGE_READ_EXTERNAL_TIME_NS - Static variable in class alluxio.metrics.MetricKey
-
- CLIENT_CACHE_PAGES - Static variable in class alluxio.metrics.MetricKey
-
- CLIENT_CACHE_PAGES_EVICTED - Static variable in class alluxio.metrics.MetricKey
-
- CLIENT_CACHE_PUT_ASYNC_REJECTION_ERRORS - Static variable in class alluxio.metrics.MetricKey
-
- CLIENT_CACHE_PUT_BENIGN_RACING_ERRORS - Static variable in class alluxio.metrics.MetricKey
-
- CLIENT_CACHE_PUT_ERRORS - Static variable in class alluxio.metrics.MetricKey
-
- CLIENT_CACHE_PUT_EVICTION_ERRORS - Static variable in class alluxio.metrics.MetricKey
-
- CLIENT_CACHE_PUT_INSUFFICIENT_SPACE_ERRORS - Static variable in class alluxio.metrics.MetricKey
-
- CLIENT_CACHE_PUT_NOT_READY_ERRORS - Static variable in class alluxio.metrics.MetricKey
-
- CLIENT_CACHE_PUT_STORE_DELETE_ERRORS - Static variable in class alluxio.metrics.MetricKey
-
- CLIENT_CACHE_PUT_STORE_WRITE_ERRORS - Static variable in class alluxio.metrics.MetricKey
-
- CLIENT_CACHE_PUT_STORE_WRITE_NO_SPACE_ERRORS - Static variable in class alluxio.metrics.MetricKey
-
- CLIENT_CACHE_SHADOW_CACHE_BYTES - Static variable in class alluxio.metrics.MetricKey
-
- CLIENT_CACHE_SHADOW_CACHE_BYTES_HIT - Static variable in class alluxio.metrics.MetricKey
-
- CLIENT_CACHE_SHADOW_CACHE_BYTES_READ - Static variable in class alluxio.metrics.MetricKey
-
- CLIENT_CACHE_SHADOW_CACHE_FALSE_POSITIVE_RATIO - Static variable in class alluxio.metrics.MetricKey
-
- CLIENT_CACHE_SHADOW_CACHE_PAGES - Static variable in class alluxio.metrics.MetricKey
-
- CLIENT_CACHE_SHADOW_CACHE_PAGES_HIT - Static variable in class alluxio.metrics.MetricKey
-
- CLIENT_CACHE_SHADOW_CACHE_PAGES_READ - Static variable in class alluxio.metrics.MetricKey
-
- CLIENT_CACHE_SPACE_AVAILABLE - Static variable in class alluxio.metrics.MetricKey
-
- CLIENT_CACHE_SPACE_USED - Static variable in class alluxio.metrics.MetricKey
-
- CLIENT_CACHE_SPACE_USED_COUNT - Static variable in class alluxio.metrics.MetricKey
-
- CLIENT_CACHE_STATE - Static variable in class alluxio.metrics.MetricKey
-
- CLIENT_CACHE_STORE_DELETE_TIMEOUT - Static variable in class alluxio.metrics.MetricKey
-
- CLIENT_CACHE_STORE_GET_TIMEOUT - Static variable in class alluxio.metrics.MetricKey
-
- CLIENT_CACHE_STORE_PUT_TIMEOUT - Static variable in class alluxio.metrics.MetricKey
-
- CLIENT_CACHE_STORE_THREADS_REJECTED - Static variable in class alluxio.metrics.MetricKey
-
- CLIENT_META_DATA_CACHE_SIZE - Static variable in class alluxio.metrics.MetricKey
-
- CLIENT_VALUE - Static variable in enum alluxio.grpc.Scope
-
CLIENT = 4;
- clientClosed(BlockClient, BlockStoreLocation) - Method in interface alluxio.worker.block.io.BlockClientListener
-
Called when an open block client is closed.
- clientClosed(BlockClient, BlockStoreLocation) - Method in class alluxio.worker.block.management.DefaultStoreLoadTracker
-
- 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
-
- ClientIOOperation - Enum in alluxio.stress.client
-
The operations for the client io stress tests.
- ClientIOOperationConverter() - Constructor for class alluxio.stress.client.ClientIOParameters.ClientIOOperationConverter
-
- ClientIOParameters - Class in alluxio.stress.client
-
This holds all the parameters.
- ClientIOParameters() - Constructor for class alluxio.stress.client.ClientIOParameters
-
- ClientIOParameters.ClientIOOperationConverter - Class in alluxio.stress.client
-
- ClientIOTaskResult - Class in alluxio.stress.client
-
The task result for the master stress tests.
- ClientIOTaskResult() - Constructor for class alluxio.stress.client.ClientIOTaskResult
-
Creates an instance.
- ClientIOTaskResult.GraphGenerator - Class in alluxio.stress.client
-
The graph generator for this summary.
- ClientIOTaskResult.ThreadCountResult - Class in alluxio.stress.client
-
A result for a single thread count test.
- ClientIOWritePolicy - Class in alluxio.stress.cli.client
-
A write type for restricting the writes to a set number of workers.
- ClientIOWritePolicy(AlluxioConfiguration) - Constructor for class alluxio.stress.cli.client.ClientIOWritePolicy
-
- 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
-
- ClientMetrics - Class in alluxio.grpc
-
Protobuf type alluxio.grpc.metric.ClientMetrics
- ClientMetrics.Builder - Class in alluxio.grpc
-
Protobuf type alluxio.grpc.metric.ClientMetrics
- CLIENTMETRICS_FIELD_NUMBER - Static variable in class alluxio.grpc.MetricsHeartbeatPOptions
-
- ClientMetricsOrBuilder - Interface in alluxio.grpc
-
- clientOpened(BlockClient, BlockStoreLocation) - Method in interface alluxio.worker.block.io.BlockClientListener
-
Called when a new block client is opened.
- clientOpened(BlockClient, BlockStoreLocation) - Method in class alluxio.worker.block.management.DefaultStoreLoadTracker
-
- 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
-
- Clients - Class in alluxio.multi.process
-
Container for various Alluxio clients.
- Clients(FileSystem, FileSystemMasterClient, MetaMasterClient, BlockMasterClient) - Constructor for class alluxio.multi.process.Clients
-
- clone() - Method in class alluxio.grpc.AddQuorumServerRequest.Builder
-
- clone() - Method in class alluxio.grpc.AsyncCacheRequest.Builder
-
- clone() - Method in class alluxio.grpc.AsyncCacheResponse.Builder
-
- clone() - Method in class alluxio.grpc.BackupPOptions.Builder
-
- clone() - Method in class alluxio.grpc.BackupPRequest.Builder
-
- clone() - Method in class alluxio.grpc.BackupPStatus.Builder
-
- clone() - Method in class alluxio.grpc.BackupStatusPRequest.Builder
-
- clone() - Method in class alluxio.grpc.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.CacheRequest.Builder
-
- clone() - Method in class alluxio.grpc.CacheResponse.Builder
-
- clone() - Method in class alluxio.grpc.CancelPOptions.Builder
-
- clone() - Method in class alluxio.grpc.CancelPRequest.Builder
-
- clone() - Method in class alluxio.grpc.CancelPResponse.Builder
-
- clone() - Method in class alluxio.grpc.CancelTaskCommand.Builder
-
- clone() - Method in class alluxio.grpc.CheckAccessPOptions.Builder
-
- clone() - Method in class alluxio.grpc.CheckAccessPRequest.Builder
-
- clone() - Method in class alluxio.grpc.CheckAccessPResponse.Builder
-
- clone() - Method in class alluxio.grpc.CheckConsistencyPOptions.Builder
-
- clone() - Method in class alluxio.grpc.CheckConsistencyPRequest.Builder
-
- clone() - Method in class alluxio.grpc.CheckConsistencyPResponse.Builder
-
- clone() - Method in class alluxio.grpc.CheckpointPOptions.Builder
-
- clone() - Method in class alluxio.grpc.CheckpointPResponse.Builder
-
- clone() - Method in class alluxio.grpc.CheckRequest.Builder
-
- clone() - Method in class alluxio.grpc.CheckResponse.Builder
-
- clone() - Method in class alluxio.grpc.Chunk.Builder
-
- clone() - Method in class alluxio.grpc.ClearMetricsPRequest.Builder
-
- clone() - Method in class alluxio.grpc.ClearMetricsPResponse.Builder
-
- clone() - Method in class alluxio.grpc.ClearMetricsRequest.Builder
-
- clone() - Method in class alluxio.grpc.ClearMetricsResponse.Builder
-
- clone() - Method in class alluxio.grpc.ClientMetrics.Builder
-
- clone() - Method in class alluxio.grpc.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.DownloadSnapshotPRequest.Builder
-
- clone() - Method in class alluxio.grpc.DownloadSnapshotPResponse.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.GetJobStatusDetailedPOptions.Builder
-
- clone() - Method in class alluxio.grpc.GetJobStatusDetailedPRequest.Builder
-
- clone() - Method in class alluxio.grpc.GetJobStatusDetailedPResponse.Builder
-
- clone() - Method in class alluxio.grpc.GetJobStatusPOptions.Builder
-
- clone() - Method in class alluxio.grpc.GetJobStatusPRequest.Builder
-
- clone() - Method in class alluxio.grpc.GetJobStatusPResponse.Builder
-
- clone() - Method in class alluxio.grpc.GetMasterIdPOptions.Builder
-
- clone() - Method in class alluxio.grpc.GetMasterIdPRequest.Builder
-
- clone() - Method in class alluxio.grpc.GetMasterIdPResponse.Builder
-
- clone() - Method in class alluxio.grpc.GetMasterInfoPOptions.Builder
-
- clone() - Method in class alluxio.grpc.GetMasterInfoPResponse.Builder
-
- clone() - Method in class alluxio.grpc.GetMetricsPOptions.Builder
-
- clone() - Method in class alluxio.grpc.GetMetricsPResponse.Builder
-
- clone() - Method in class alluxio.grpc.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.GetSnapshotInfoRequest.Builder
-
- clone() - Method in class alluxio.grpc.GetSnapshotInfoResponse.Builder
-
- clone() - Method in class alluxio.grpc.GetSnapshotRequest.Builder
-
- clone() - Method in class alluxio.grpc.GetStateLockHoldersPOptions.Builder
-
- clone() - Method in class alluxio.grpc.GetStateLockHoldersPRequest.Builder
-
- clone() - Method in class alluxio.grpc.GetStateLockHoldersPResponse.Builder
-
- clone() - Method in class alluxio.grpc.GetStatusPOptions.Builder
-
- clone() - Method in class alluxio.grpc.GetStatusPRequest.Builder
-
- clone() - Method in class alluxio.grpc.GetStatusPResponse.Builder
-
- clone() - Method in class alluxio.grpc.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.JournalQueryRequest.Builder
-
- clone() - Method in class alluxio.grpc.JournalQueryResponse.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.ResetPrioritiesPOptions.Builder
-
- clone() - Method in class alluxio.grpc.ResetPrioritiesPRequest.Builder
-
- clone() - Method in class alluxio.grpc.ResetPrioritiesPResponse.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.SnapshotData.Builder
-
- clone() - Method in class alluxio.grpc.SnapshotMetadata.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.TransferLeadershipPOptions.Builder
-
- clone() - Method in class alluxio.grpc.TransferLeadershipPRequest.Builder
-
- clone() - Method in class alluxio.grpc.TransferLeadershipPResponse.Builder
-
- clone() - Method in class alluxio.grpc.TransportMessage.Builder
-
- clone() - Method in class alluxio.grpc.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.UpdateConfigurationPRequest.Builder
-
- clone() - Method in class alluxio.grpc.UpdateConfigurationPResponse.Builder
-
- clone() - Method in class alluxio.grpc.UpdateMountPRequest.Builder
-
- clone() - Method in class alluxio.grpc.UpdateMountPResponse.Builder
-
- clone() - Method in class alluxio.grpc.UpdateUfsModePOptions.Builder
-
- clone() - Method in class alluxio.grpc.UpdateUfsModePRequest.Builder
-
- clone() - Method in class alluxio.grpc.UpdateUfsModePResponse.Builder
-
- clone() - Method in class alluxio.grpc.UploadSnapshotPRequest.Builder
-
- clone() - Method in class alluxio.grpc.UploadSnapshotPResponse.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.AddTablePartitionsEntry.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
-
- cloneByteBufferList(List<ByteBuffer>) - Static method in class alluxio.util.io.BufferUtils
-
- 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.BlockWorkerDataReader
-
- close() - Method in class alluxio.client.block.stream.BlockWorkerDataReader.Factory
-
- close() - Method in class alluxio.client.block.stream.BlockWorkerDataWriter
-
- close() - Method in class alluxio.client.block.stream.BufferCachingGrpcDataReader
-
- close() - Method in class alluxio.client.block.stream.DefaultBlockWorkerClient
-
- close() - Method in class alluxio.client.block.stream.GrpcBlockingStream
-
Closes the outbound stream.
- close() - Method in class alluxio.client.block.stream.GrpcDataReader
-
- close() - Method in class alluxio.client.block.stream.GrpcDataReader.Factory
-
- close() - Method in class alluxio.client.block.stream.GrpcDataWriter
-
- close() - Method in class alluxio.client.block.stream.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.SharedGrpcDataReader
-
- close() - Method in class alluxio.client.block.stream.SharedGrpcDataReader.Factory
-
- 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.CacheManagerWithShadowCache
-
- close() - Method in class alluxio.client.file.cache.LocalCacheFileInStream
-
- close() - Method in class alluxio.client.file.cache.LocalCacheManager
-
- close() - Method in class alluxio.client.file.cache.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.cache.TimeBoundPageStore
-
- close() - Method in class alluxio.client.file.ConfigHashSync
-
- close() - Method in class alluxio.client.file.DelegatingFileSystem
-
- close() - Method in class alluxio.client.file.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.collections.LockPool
-
- close() - Method in class alluxio.concurrent.ManagedBlockingUfsForwarder
-
- close() - Method in class alluxio.fuse.CreateFileEntry
-
Closes the underlying open streams.
- close() - Method in class alluxio.fuse.OpenFileEntry
-
Closes the underlying open streams.
- close() - Method in interface alluxio.grpc.BufferRepository
-
Closes the repository and all its buffers.
- close() - Method in class alluxio.grpc.DataMessageMarshaller
-
- close() - Method in class alluxio.grpc.GrpcConnection
-
Releases the connection to the pool.
- close() - Method in class alluxio.hadoop.AbstractFileSystem
-
- close() - Method in class alluxio.hadoop.AlluxioHdfsInputStream
-
- close() - Method in class alluxio.hadoop.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.orc.OrcReader
-
- 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.InodeLockManager
-
- close() - Method in class alluxio.master.file.meta.InodePathPair
-
- close() - Method in class alluxio.master.file.meta.InodeTree
-
Close resources associated with this tree instance.
- close() - Method in class alluxio.master.file.meta.InodeTreeBufferedIterator
-
- close() - Method in class alluxio.master.file.meta.LockedInodePath
-
- close() - Method in class alluxio.master.file.meta.LockedInodePathList
-
- close() - Method in class alluxio.master.file.meta.SimpleInodeLockList
-
- close() - Method in class alluxio.master.file.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.MergeJournalContext
-
- close() - Method in class alluxio.master.journal.noop.NoopJournal
-
- close() - Method in class alluxio.master.journal.NoopJournalContext
-
- close() - Method in class alluxio.master.journal.raft.BufferedJournalApplier
-
Resets the suspend applier.
- close() - Method in class alluxio.master.journal.raft.JournalStateMachine
-
- close() - Method in class alluxio.master.journal.raft.LocalFirstRaftClient
-
- 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.raft.SnapshotReplicationManager
-
Close the manager and release its resources.
- 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.JournalSpaceMonitor
-
- 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
-
Closes the client.
- close() - Method in class alluxio.master.transport.GrpcMessagingClientConnection
-
- close() - Method in class alluxio.master.transport.GrpcMessagingConnection
-
Closes the connection.
- close() - Method in class alluxio.master.transport.GrpcMessagingContext
-
Closes the context.
- close() - Method in class alluxio.master.transport.GrpcMessagingServer
-
Closes the connection to the server if exists.
- close() - Method in class alluxio.master.transport.GrpcMessagingTransport
-
Closes the opened clients and servers.
- close() - Method in interface alluxio.master.transport.Listener
-
Closes the listener.
- close() - Method in class alluxio.master.transport.Listeners.ListenerHolder
-
- close() - Method in class alluxio.master.ZkMasterInquireClient
-
- close() - Method in class alluxio.metrics.EventCounter
-
Release any resources allocated within the appender such as file
handles, network connections, etc.
- close() - Method in class alluxio.metrics.MetricsSystem.MultiTimerContext
-
Updates the timer with the difference between current and start time.
- close() - Method in class alluxio.multi.process.Master
-
- close() - Method in class alluxio.multi.process.Worker
-
- close() - Method in class alluxio.proxy.s3.RangeFileInStream
-
- CLOSE - Static variable in class alluxio.proxy.StreamsRestServiceHandler
-
- close(Integer) - Method in class alluxio.proxy.StreamsRestServiceHandler
-
- close() - Method in class alluxio.Registry
-
Closes all
Server
s 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
-
- 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.cephfs.CephFSUnderFileSystem
-
- close() - Method in class alluxio.underfs.cephfs.CephInputStream
-
- close() - Method in class alluxio.underfs.cephfs.CephOutputStream
-
- close() - Method in class alluxio.underfs.cos.COSOutputStream
-
Closes this output stream.
- close() - Method in class alluxio.underfs.gcs.GCSInputStream
-
- close() - Method in class alluxio.underfs.gcs.GCSOutputStream
-
- close() - Method in class alluxio.underfs.gcs.v2.GCSV2InputStream
-
- close() - Method in class alluxio.underfs.gcs.v2.GCSV2OutputStream
-
- close() - Method in class alluxio.underfs.hdfs.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.FuseManager
-
- close() - Method in class alluxio.worker.block.io.BlockClient
-
- close() - Method in class alluxio.worker.block.io.DelegatingBlockReader
-
- close() - Method in class alluxio.worker.block.io.LocalFileBlockReader
-
- close() - Method in class alluxio.worker.block.io.LocalFileBlockWriter
-
- close() - Method in class alluxio.worker.block.io.StoreBlockReader
-
- close() - Method in class alluxio.worker.block.io.StoreBlockWriter
-
- close() - Method in class alluxio.worker.block.management.ManagementTaskCoordinator
-
- close() - Method in class alluxio.worker.block.PinListSync
-
- close() - Method in class alluxio.worker.block.RemoteBlockReader
-
- close() - Method in class alluxio.worker.block.TieredBlockStore
-
- 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.
- CloseableIterator<T> - Class in alluxio.resource
-
A CloseableIterator<T>
is an iterator which requires cleanup when it is no longer in use.
- CloseableIterator(Iterator<T>) - Constructor for class alluxio.resource.CloseableIterator
-
- 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
-
- 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.DefaultHiveClientPool
-
- closeUfsBlock(long, long) - Method in class alluxio.worker.block.DefaultBlockWorker
-
Closes a UFS block for a client session.
- CloudCostUtils - Class in alluxio.master.metrics
-
This class contains utilities to compute cloud cost savings.
- CLUSTER - Static variable in class alluxio.metrics.MetricsSystem
-
- CLUSTER_ACTIVE_RPC_READ_COUNT - Static variable in class alluxio.metrics.MetricKey
-
- CLUSTER_ACTIVE_RPC_WRITE_COUNT - Static variable in class alluxio.metrics.MetricKey
-
- CLUSTER_BYTES_READ_DIRECT - Static variable in class alluxio.metrics.MetricKey
-
- CLUSTER_BYTES_READ_DIRECT_THROUGHPUT - Static variable in class alluxio.metrics.MetricKey
-
- CLUSTER_BYTES_READ_DOMAIN - Static variable in class alluxio.metrics.MetricKey
-
- CLUSTER_BYTES_READ_DOMAIN_THROUGHPUT - Static variable in class alluxio.metrics.MetricKey
-
- CLUSTER_BYTES_READ_LOCAL - Static variable in class alluxio.metrics.MetricKey
-
- CLUSTER_BYTES_READ_LOCAL_THROUGHPUT - Static variable in class alluxio.metrics.MetricKey
-
- CLUSTER_BYTES_READ_REMOTE - Static variable in class alluxio.metrics.MetricKey
-
- CLUSTER_BYTES_READ_REMOTE_THROUGHPUT - Static variable in class alluxio.metrics.MetricKey
-
- CLUSTER_BYTES_READ_UFS - Static variable in class alluxio.metrics.MetricKey
-
- CLUSTER_BYTES_READ_UFS_ALL - Static variable in class alluxio.metrics.MetricKey
-
- CLUSTER_BYTES_READ_UFS_THROUGHPUT - Static variable in class alluxio.metrics.MetricKey
-
- CLUSTER_BYTES_WRITTEN_DOMAIN - Static variable in class alluxio.metrics.MetricKey
-
- CLUSTER_BYTES_WRITTEN_DOMAIN_THROUGHPUT - Static variable in class alluxio.metrics.MetricKey
-
- CLUSTER_BYTES_WRITTEN_LOCAL - Static variable in class alluxio.metrics.MetricKey
-
- CLUSTER_BYTES_WRITTEN_LOCAL_THROUGHPUT - Static variable in class alluxio.metrics.MetricKey
-
- CLUSTER_BYTES_WRITTEN_REMOTE - Static variable in class alluxio.metrics.MetricKey
-
- CLUSTER_BYTES_WRITTEN_REMOTE_THROUGHPUT - Static variable in class alluxio.metrics.MetricKey
-
- CLUSTER_BYTES_WRITTEN_UFS - Static variable in class alluxio.metrics.MetricKey
-
- CLUSTER_BYTES_WRITTEN_UFS_ALL - Static variable in class alluxio.metrics.MetricKey
-
- CLUSTER_BYTES_WRITTEN_UFS_THROUGHPUT - Static variable in class alluxio.metrics.MetricKey
-
- CLUSTER_CACHE_HIT_RATE - Static variable in class alluxio.metrics.MetricKey
-
- CLUSTER_CAPACITY_FREE - Static variable in class alluxio.metrics.MetricKey
-
- CLUSTER_CAPACITY_TOTAL - Static variable in class alluxio.metrics.MetricKey
-
- CLUSTER_CAPACITY_USED - Static variable in class alluxio.metrics.MetricKey
-
- CLUSTER_DEFAULT - Static variable in class alluxio.conf.Source
-
- CLUSTER_FLAG - Static variable in class alluxio.stress.BaseParameters
-
- CLUSTER_ID_FIELD_NUMBER - Static variable in class alluxio.proto.journal.Meta.ClusterInfoEntry
-
- CLUSTER_INFO_FIELD_NUMBER - Static variable in class alluxio.proto.journal.Journal.JournalEntry
-
- CLUSTER_LIMIT_FLAG - Static variable in class alluxio.stress.BaseParameters
-
- CLUSTER_LOST_WORKERS - Static variable in class alluxio.metrics.MetricKey
-
- CLUSTER_ROOT_UFS_CAPACITY_FREE - Static variable in class alluxio.metrics.MetricKey
-
- CLUSTER_ROOT_UFS_CAPACITY_TOTAL - Static variable in class alluxio.metrics.MetricKey
-
- CLUSTER_ROOT_UFS_CAPACITY_USED - Static variable in class alluxio.metrics.MetricKey
-
- CLUSTER_START_DELAY_FLAG - Static variable in class alluxio.stress.BaseParameters
-
- CLUSTER_WORKERS - Static variable in class alluxio.metrics.MetricKey
-
- ClusterConfConsistencyValidationTask - Class in alluxio.cli
-
Task for validating Alluxio configuration consistency in the cluster.
- ClusterConfConsistencyValidationTask(AlluxioConfiguration) - Constructor for class alluxio.cli.ClusterConfConsistencyValidationTask
-
- 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
-
- 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
-
- 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
-
- 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
-
- CollectJvmInfoCommand - Class in alluxio.cli.bundler.command
-
Command that collects information about the JVMs.
- CollectJvmInfoCommand(FileSystemContext) - Constructor for class alluxio.cli.bundler.command.CollectJvmInfoCommand
-
- CollectLogCommand - Class in alluxio.cli.bundler.command
-
Command to collect Alluxio logs.
- CollectLogCommand(FileSystemContext) - Constructor for class alluxio.cli.bundler.command.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
-
- 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
-
- 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
-
- 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
-
- commitBlockLocked(long, long, boolean) - Method in interface alluxio.worker.block.BlockStore
-
- commitBlockLocked(long, long, boolean) - Method in class alluxio.worker.block.TieredBlockStore
-
- 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.DefaultBlockMeta
-
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.CheckAccessPOptions
-
- COMMONOPTIONS_FIELD_NUMBER - Static variable in class alluxio.grpc.CheckConsistencyPOptions
-
- COMMONOPTIONS_FIELD_NUMBER - Static variable in class alluxio.grpc.CompleteFilePOptions
-
- COMMONOPTIONS_FIELD_NUMBER - Static variable in class alluxio.grpc.CreateDirectoryPOptions
-
- COMMONOPTIONS_FIELD_NUMBER - Static variable in class alluxio.grpc.CreateFilePOptions
-
- COMMONOPTIONS_FIELD_NUMBER - Static variable in class alluxio.grpc.DeletePOptions
-
- COMMONOPTIONS_FIELD_NUMBER - Static variable in class alluxio.grpc.ExistsPOptions
-
- COMMONOPTIONS_FIELD_NUMBER - Static variable in class alluxio.grpc.FreePOptions
-
- COMMONOPTIONS_FIELD_NUMBER - Static variable in class alluxio.grpc.GetNewBlockIdForFilePOptions
-
- COMMONOPTIONS_FIELD_NUMBER - Static variable in class alluxio.grpc.GetStatusPOptions
-
- COMMONOPTIONS_FIELD_NUMBER - Static variable in class alluxio.grpc.ListStatusPOptions
-
- COMMONOPTIONS_FIELD_NUMBER - Static variable in class alluxio.grpc.LoadMetadataPOptions
-
- COMMONOPTIONS_FIELD_NUMBER - Static variable in class alluxio.grpc.MountPOptions
-
- COMMONOPTIONS_FIELD_NUMBER - Static variable in class alluxio.grpc.OpenFilePOptions
-
- COMMONOPTIONS_FIELD_NUMBER - Static variable in class alluxio.grpc.RenamePOptions
-
- COMMONOPTIONS_FIELD_NUMBER - Static variable in class alluxio.grpc.ScheduleAsyncPersistencePOptions
-
- COMMONOPTIONS_FIELD_NUMBER - Static variable in class alluxio.grpc.SetAclPOptions
-
- COMMONOPTIONS_FIELD_NUMBER - Static variable in class alluxio.grpc.SetAttributePOptions
-
- COMMONOPTIONS_FIELD_NUMBER - Static variable in class alluxio.grpc.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.
- CompactAction - Class in alluxio.table.common.transform.action
-
The definition of the compact action.
- CompactAction.CompactActionFactory - Class in alluxio.table.common.transform.action
-
Factory to create an instance.
- CompactActionFactory() - Constructor for class alluxio.table.common.transform.action.CompactAction.CompactActionFactory
-
- CompactConfig - Class in alluxio.job.plan.transform
-
Configuration for a job to compact files directly under a directory.
- CompactConfig(PartitionInfo, String, PartitionInfo, 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
-
- 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
-
- comparator() - Method in enum alluxio.worker.block.annotator.BlockOrder
-
- 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.
- compareTo(BlockSortedField) - Method in class alluxio.worker.block.annotator.LRFUAnnotator.LRFUSortedField
-
- compareTo(BlockSortedField) - Method in class alluxio.worker.block.annotator.LRUAnnotator.LRUSortedField
-
- 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
-
- 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.
- completeExceptionally(Exception) - Static method in class alluxio.master.journal.raft.RaftJournalUtils
-
Creates a future that is completed exceptionally.
- 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
-
- 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
-
- CompleteMultipartUploadResult(String, String, String, String) - Constructor for class alluxio.proxy.s3.CompleteMultipartUploadResult
-
- 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(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.
- 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
-
- CompositeExecution(CompositeConfig) - Constructor for class alluxio.job.workflow.composite.CompositeExecution
-
Default constructor.
- CompositeExecutionFactory - Class in alluxio.job.workflow.composite
-
- CompositeExecutionFactory() - Constructor for class alluxio.job.workflow.composite.CompositeExecutionFactory
-
- CompositeInodeLockList - Class in alluxio.master.file.meta
-
Manages the locks for a list of inodes, based off an existing lock list.
- CompositeInodeLockList(InodeLockList, boolean) - Constructor for class alluxio.master.file.meta.CompositeInodeLockList
-
Constructs a new lock list, using an existing lock list as the base list.
- CompoundCheckpointFormat - Class in alluxio.master.journal.checkpoint
-
Format for compound checkpoints.
- CompoundCheckpointFormat() - Constructor for class alluxio.master.journal.checkpoint.CompoundCheckpointFormat
-
- CompoundCheckpointFormat.CompoundCheckpointReader - Class in alluxio.master.journal.checkpoint
-
Reader for compound checkpoints.
- CompoundCheckpointFormat.CompoundCheckpointReader.Entry - Class in alluxio.master.journal.checkpoint
-
A compound checkpoint entry.
- CompoundCheckpointReader(CheckpointInputStream) - Constructor for class alluxio.master.journal.checkpoint.CompoundCheckpointFormat.CompoundCheckpointReader
-
- compress(String, File...) - Static method in class alluxio.cli.bundler.TarUtils
-
Compresses a list of files to one destination.
- 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.
- computeTimeData() - Method in class alluxio.stress.common.SummaryStatistics
-
- concat(CloseableIterator<T>, CloseableIterator<T>) - Static method in class alluxio.resource.CloseableIterator
-
Combines two iterators into a single iterator.
- concat(List<CloseableIterator<T>>) - Static method in class alluxio.resource.CloseableIterator
-
Concatenate iterators.
- concatPath(Object, Object) - Static method in class alluxio.util.io.PathUtils
-
- concatPath(Object, Object...) - Static method in class alluxio.util.io.PathUtils
-
- concatUfsPath(String, String) - Static method in class alluxio.util.io.PathUtils
-
- ConcurrentHashSet<T> - Class in alluxio.collections
-
A concurrent hash set.
- ConcurrentHashSet() - Constructor for class alluxio.collections.ConcurrentHashSet
-
- ConcurrentHashSet(int, float, int) - Constructor for class alluxio.collections.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 - Static variable in class alluxio.stress.worker.UfsIOParameters
-
- CONF_DIR - Static variable in class alluxio.conf.PropertyKey
-
- CONF_DIR - Static variable in class alluxio.conf.PropertyKey.Name
-
- CONF_DYNAMIC_UPDATE_ENABLED - Static variable in class alluxio.conf.PropertyKey
-
- CONF_DYNAMIC_UPDATE_ENABLED - Static variable in class alluxio.conf.PropertyKey.Name
-
- CONF_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
-
- ConfigCheckReport(Map<Scope, List<InconsistentProperty>>, Map<Scope, List<InconsistentProperty>>, ConfigStatus) - Constructor for class alluxio.wire.ConfigCheckReport
-
- ConfigCheckReport(ConfigCheckReport) - Constructor for class alluxio.wire.ConfigCheckReport
-
- 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
-
- 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
-
- ConfigRecord(PropertyKey, String, String) - Constructor for class alluxio.master.meta.checkconf.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
-
- 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(InetSocketAddress) - Method in class alluxio.master.transport.GrpcMessagingClient
-
Creates a client and connects to the given address.
- connect(StreamObserver<TransportMessage>) - Method in class alluxio.master.transport.GrpcMessagingServiceClientHandler
-
RPC for establishing bi-di stream between client/server.
- connectFromMaster(String) - Method in class alluxio.concurrent.ManagedBlockingUfsForwarder
-
- connectFromMaster(String) - Method in class alluxio.underfs.cephfs.CephFSUnderFileSystem
-
- connectFromMaster(String) - Method in class alluxio.underfs.hdfs.HdfsUnderFileSystem
-
- connectFromMaster(String) - Method in class alluxio.underfs.local.LocalUnderFileSystem
-
- connectFromMaster(String) - Method in class alluxio.underfs.ObjectUnderFileSystem
-
- connectFromMaster(String) - Method in interface alluxio.underfs.UnderFileSystem
-
Takes any necessary actions required to establish a connection to the under file system from
the given master host e.g.
- connectFromMaster(String) - Method in class alluxio.underfs.UnderFileSystemWithLogging
-
- connectFromMaster(String) - Method in class alluxio.underfs.web.WebUnderFileSystem
-
- connectFromWorker(String) - Method in class alluxio.concurrent.ManagedBlockingUfsForwarder
-
- connectFromWorker(String) - Method in class alluxio.underfs.cephfs.CephFSUnderFileSystem
-
- connectFromWorker(String) - Method in class alluxio.underfs.hdfs.HdfsUnderFileSystem
-
- connectFromWorker(String) - Method in class alluxio.underfs.local.LocalUnderFileSystem
-
- connectFromWorker(String) - Method in class alluxio.underfs.ObjectUnderFileSystem
-
- connectFromWorker(String) - Method in interface alluxio.underfs.UnderFileSystem
-
Takes any necessary actions required to establish a connection to the under file system from
the given worker host e.g.
- connectFromWorker(String) - Method in class alluxio.underfs.UnderFileSystemWithLogging
-
- 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.master.NoopUfsManager
-
- connectUfs(UnderFileSystem) - Method in class alluxio.underfs.AbstractUfsManager
-
Takes any necessary actions required to establish a connection to the under file system.
- connectUfs(UnderFileSystem) - Method in class alluxio.underfs.JobUfsManager
-
- connectUfs(UnderFileSystem) - Method in class alluxio.underfs.MasterUfsManager
-
- connectUfs(UnderFileSystem) - Method in class alluxio.underfs.WorkerUfsManager
-
- 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
-
- 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
-
- constantExecutorServiceFactory(ExecutorService) - Static method in class alluxio.util.executor.ExecutorServiceFactories
-
- Constants - Class in alluxio
-
System wide constants.
- Constraint - Class in alluxio.grpc.table
-
Protobuf type alluxio.grpc.table.Constraint
- Constraint.Builder - Class in alluxio.grpc.table
-
Protobuf type alluxio.grpc.table.Constraint
- CONSTRAINT_FIELD_NUMBER - Static variable in class alluxio.grpc.table.ReadTablePRequest
-
- ConstraintOrBuilder - Interface in alluxio.grpc.table
-
- CONTAINER_ID_FIELD_NUMBER - Static variable in class alluxio.proto.journal.File.InodeDirectoryIdGeneratorEntry
-
- CONTAINERHOST_FIELD_NUMBER - Static variable in class alluxio.grpc.WorkerNetAddress
-
- ContainerIdGenerable - Interface in alluxio.master.block
-
Provides generation of container IDs.
- contains(Object) - Method in class alluxio.collections.ConcurrentHashSet
-
- contains(Object) - Method in class alluxio.collections.DelegatingSet
-
- contains(T) - Method in class alluxio.collections.DirectedAcyclicGraph
-
Checks if a node with the given payload is in the DAG.
- contains(IndexDefinition<T, V>, V) - Method in class alluxio.collections.IndexedSet
-
Whether there is an object with the specified index field value in the set.
- contains(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.
- containsLocalIp(List<InetSocketAddress>, AlluxioConfiguration) - Static method in class alluxio.util.network.NetworkAddressUtils
-
- containsLostStorage(String) - Method in class alluxio.grpc.BlockHeartbeatPRequest.Builder
-
the map of lost storage paths on all tiers
- containsLostStorage(String) - Method in class alluxio.grpc.BlockHeartbeatPRequest
-
the map of lost storage paths on all tiers
- containsLostStorage(String) - Method in interface alluxio.grpc.BlockHeartbeatPRequestOrBuilder
-
the map of lost storage paths on all tiers
- containsLostStorage(String) - Method in class alluxio.grpc.RegisterWorkerPRequest.Builder
-
the map of tier alias to a list of lost storage paths.
- containsLostStorage(String) - Method in class alluxio.grpc.RegisterWorkerPRequest
-
the map of tier alias to a list of lost storage paths.
- containsLostStorage(String) - Method in interface alluxio.grpc.RegisterWorkerPRequestOrBuilder
-
the map of tier alias to a list of lost storage paths.
- containsLostStorage(String) - Method in class alluxio.grpc.WorkerLostStorageInfo.Builder
-
a map from tier alias to the lost storage paths
- containsLostStorage(String) - Method in class alluxio.grpc.WorkerLostStorageInfo
-
a map from tier alias to the lost storage paths
- containsLostStorage(String) - Method in interface alluxio.grpc.WorkerLostStorageInfoOrBuilder
-
a map from tier alias to the lost storage paths
- containsMetrics(String) - Method in class alluxio.grpc.GetMetricsPResponse.Builder
-
map<string, .alluxio.grpc.metric.MetricValue> metrics = 1;
- containsMetrics(String) - Method in class alluxio.grpc.GetMetricsPResponse
-
map<string, .alluxio.grpc.metric.MetricValue> metrics = 1;
- containsMetrics(String) - Method in interface alluxio.grpc.GetMetricsPResponseOrBuilder
-
map<string, .alluxio.grpc.metric.MetricValue> metrics = 1;
- containsMountPoint(AlluxioURI, boolean) - Method in class alluxio.master.file.meta.MountTable
-
- containsMountPoints(String) - Method in class alluxio.grpc.GetMountTablePResponse.Builder
-
map<string, .alluxio.grpc.file.MountPointInfo> mountPoints = 1;
- containsMountPoints(String) - Method in class alluxio.grpc.GetMountTablePResponse
-
map<string, .alluxio.grpc.file.MountPointInfo> mountPoints = 1;
- containsMountPoints(String) - Method in interface alluxio.grpc.GetMountTablePResponseOrBuilder
-
map<string, .alluxio.grpc.file.MountPointInfo> mountPoints = 1;
- containsObject(T) - Method in interface alluxio.collections.FieldIndex
-
Returns whether there is an object in the set.
- containsObject(T) - Method in class alluxio.collections.NonUniqueFieldIndex
-
- containsObject(T) - Method in class alluxio.collections.UniqueFieldIndex
-
- containsOptions(String) - Method in class alluxio.grpc.table.AttachDatabasePRequest.Builder
-
map<string, string> options = 5;
- containsOptions(String) - Method in class alluxio.grpc.table.AttachDatabasePRequest
-
map<string, string> options = 5;
- containsOptions(String) - Method in interface alluxio.grpc.table.AttachDatabasePRequestOrBuilder
-
map<string, string> options = 5;
- containsParameter(String) - Method in class alluxio.grpc.table.Database.Builder
-
map<string, string> parameter = 4;
- containsParameter(String) - Method in class alluxio.grpc.table.Database
-
map<string, string> parameter = 4;
- containsParameter(String) - Method in interface alluxio.grpc.table.DatabaseOrBuilder
-
map<string, string> parameter = 4;
- 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.grpc.UpdateConfigurationPRequest.Builder
-
map<string, string> properties = 1;
- containsProperties(String) - Method in class alluxio.grpc.UpdateConfigurationPRequest
-
map<string, string> properties = 1;
- containsProperties(String) - Method in interface alluxio.grpc.UpdateConfigurationPRequestOrBuilder
-
map<string, string> properties = 1;
- containsProperties(String) - Method in class alluxio.proto.journal.Meta.PathPropertiesEntry.Builder
-
map<string, string> properties = 2;
- containsProperties(String) - Method in class alluxio.proto.journal.Meta.PathPropertiesEntry
-
map<string, string> properties = 2;
- containsProperties(String) - Method in interface alluxio.proto.journal.Meta.PathPropertiesEntryOrBuilder
-
map<string, string> properties = 2;
- containsSerdelibParameters(String) - Method in class alluxio.grpc.table.layout.hive.StorageFormat.Builder
-
map<string, string> serdelib_parameters = 4;
- containsSerdelibParameters(String) - Method in class alluxio.grpc.table.layout.hive.StorageFormat
-
map<string, string> serdelib_parameters = 4;
- containsSerdelibParameters(String) - Method in interface alluxio.grpc.table.layout.hive.StorageFormatOrBuilder
-
map<string, string> serdelib_parameters = 4;
- containsSerdeParameters(String) - Method in class alluxio.grpc.table.layout.hive.Storage.Builder
-
map<string, string> serde_parameters = 5;
- containsSerdeParameters(String) - Method in class alluxio.grpc.table.layout.hive.Storage
-
map<string, string> serde_parameters = 5;
- containsSerdeParameters(String) - Method in interface alluxio.grpc.table.layout.hive.StorageOrBuilder
-
map<string, string> serde_parameters = 5;
- containsStats(String) - Method in class alluxio.grpc.table.Layout.Builder
-
map<string, .alluxio.grpc.table.ColumnStatisticsInfo> stats = 4;
- containsStats(String) - Method in class alluxio.grpc.table.Layout
-
map<string, .alluxio.grpc.table.ColumnStatisticsInfo> stats = 4;
- containsStats(String) - Method in interface alluxio.grpc.table.LayoutOrBuilder
-
map<string, .alluxio.grpc.table.ColumnStatisticsInfo> stats = 4;
- containsStatus(String) - Method in class alluxio.grpc.UpdateConfigurationPResponse.Builder
-
map<string, bool> status = 1;
- containsStatus(String) - Method in class alluxio.grpc.UpdateConfigurationPResponse
-
map<string, bool> status = 1;
- containsStatus(String) - Method in interface alluxio.grpc.UpdateConfigurationPResponseOrBuilder
-
map<string, bool> status = 1;
- containsTablesErrors(String) - Method in class alluxio.grpc.table.SyncStatus.Builder
-
map<string, string> tables_errors = 1;
- containsTablesErrors(String) - Method in class alluxio.grpc.table.SyncStatus
-
map<string, string> tables_errors = 1;
- containsTablesErrors(String) - Method in interface alluxio.grpc.table.SyncStatusOrBuilder
-
map<string, string> tables_errors = 1;
- containsTags(String) - Method in class alluxio.grpc.Metric.Builder
-
map<string, string> tags = 6;
- containsTags(String) - Method in class alluxio.grpc.Metric
-
map<string, string> tags = 6;
- containsTags(String) - Method in interface alluxio.grpc.MetricOrBuilder
-
map<string, string> tags = 6;
- containsTotalBytesOnTiers(String) - Method in class alluxio.grpc.RegisterWorkerPRequest.Builder
-
the map of total bytes on each tier
- containsTotalBytesOnTiers(String) - Method in class alluxio.grpc.RegisterWorkerPRequest
-
the map of total bytes on each tier
- containsTotalBytesOnTiers(String) - Method in interface alluxio.grpc.RegisterWorkerPRequestOrBuilder
-
the map of total bytes on each tier
- 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(String, String, String) - Constructor for class alluxio.proxy.s3.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
-
- ControllableQueue() - Constructor for class alluxio.util.executor.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.stress.client.ClientIOParameters.ClientIOOperationConverter
-
- convert(String) - Method in class alluxio.stress.fuse.FuseIOParameters.FuseIOOperationConverter
-
- convert(String) - Method in class alluxio.stress.jobservice.JobServiceBenchParameters.OperationConverter
-
- convert(String) - Method in class alluxio.stress.master.MasterBenchParameters.OperationConverter
-
- convertAclToStringEntries() - Method in class alluxio.wire.FileInfo
-
- convertBlockListMapToProto(Map<BlockStoreLocation, List<Long>>) - Method in class alluxio.stress.CachingBlockMasterClient
-
- convertBlockListMapToProto(Map<BlockStoreLocation, List<Long>>) - Method in class alluxio.worker.block.BlockMasterClient
-
Converts the block list map to a proto list.
- convertByteArrayToStringWithoutEscape(byte[], int, int) - Static method in class alluxio.util.webui.WebUtils
-
Converts a byte array to string.
- convertDefaultAclToStringEntries() - Method in class alluxio.wire.FileInfo
-
- convertFromByteString(Map<String, ByteString>) - Static method in class alluxio.util.CommonUtils
-
- convertMsToClockTime(long) - Static method in class alluxio.util.CommonUtils
-
Converts milliseconds to clock time.
- convertMsToDate(long, String) - Static method in class alluxio.util.CommonUtils
-
Converts a millisecond number to a formatted date String.
- convertResults(List<ValidationTaskResult>) - Static method in interface alluxio.cli.ValidationTool
-
- 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
-
- 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
-
- copyAndMaskProperties(MountPOptions.Builder, Map<String, String>) - Method in class alluxio.RpcSensitiveConfigMask
-
- 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.gcs.v2.GCSV2UnderFileSystem
-
- 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
-
- CopyObjectResult - Class in alluxio.proxy.s3
-
Result of an S3 Copy.
- CopyObjectResult(String, long) - Constructor for class alluxio.proxy.s3.CopyObjectResult
-
- copyProperties() - Method in interface alluxio.conf.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
-
- 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.
- CosNUnderFileSystemFactory - Class in alluxio.underfs.cosn
-
- CosNUnderFileSystemFactory() - Constructor for class alluxio.underfs.cosn.CosNUnderFileSystemFactory
-
- COSOutputStream - Class in alluxio.underfs.cos
-
A stream for writing a file into COS.
- COSOutputStream(String, String, COSClient, List<String>) - Constructor for class alluxio.underfs.cos.COSOutputStream
-
- COSTMAP - Static variable in class alluxio.master.metrics.CloudCostUtils
-
- COSUnderFileSystem - Class in alluxio.underfs.cos
-
- COSUnderFileSystem(AlluxioURI, COSClient, String, String, UnderFileSystemConfiguration) - Constructor for class alluxio.underfs.cos.COSUnderFileSystem
-
- COSUnderFileSystemFactory - Class in alluxio.underfs.cos
-
- COSUnderFileSystemFactory() - Constructor for class alluxio.underfs.cos.COSUnderFileSystemFactory
-
- COUNT_FIELD_NUMBER - Static variable in class alluxio.grpc.StatusSummary
-
- COUNT_FORMAT - Static variable in class alluxio.cli.fs.command.CountCommand
-
- 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(Map<Object, Object>) - Method in class alluxio.cli.HdfsValidationToolFactory
-
- create(Map<Object, Object>) - Static method in class alluxio.cli.HmsValidationTool
-
- create(Map<Object, Object>) - Method in class alluxio.cli.HmsValidationToolFactory
-
- create(Map<Object, Object>) - Method in interface alluxio.cli.ValidationToolFactory
-
- create(String, Map<Object, Object>) - Method in class alluxio.cli.ValidationToolRegistry
-
- 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
-
- create(String, AlluxioConfiguration) - Static method in class alluxio.client.block.policy.BlockLocationPolicy.Factory
-
- create(FileSystemContext, BlockInfo, WorkerNetAddress, BlockInStream.BlockInStreamSource, InStreamOptions) - Static method in class alluxio.client.block.stream.BlockInStream
-
- create(UserState, GrpcServerAddress, AlluxioConfiguration) - Static method in class alluxio.client.block.stream.BlockWorkerClient.Factory
-
Creates a new block worker client.
- create(long, long) - Method in class alluxio.client.block.stream.BlockWorkerDataReader.Factory
-
- create(FileSystemContext, long, long, OutStreamOptions) - Static method in class alluxio.client.block.stream.BlockWorkerDataWriter
-
- create(FileSystemContext, WorkerNetAddress, ReadRequest) - Static method in class alluxio.client.block.stream.BufferCachingGrpcDataReader
-
- create(long, long) - Method in interface alluxio.client.block.stream.DataReader.Factory
-
- 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, long, OutStreamOptions) - Static method in class alluxio.client.block.stream.LocalFileDataWriter
-
- create(long, long) - Method in class alluxio.client.block.stream.SharedGrpcDataReader.Factory
-
- 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
-
- create(AlluxioConfiguration) - Static method in interface alluxio.client.file.cache.evictor.CacheEvictor
-
- create(AlluxioConfiguration) - Static method in class alluxio.client.file.cache.LocalCacheManager
-
- create(AlluxioConfiguration) - Static method in interface alluxio.client.file.cache.MetaStore
-
- create(PageStoreOptions) - Static method in interface alluxio.client.file.cache.PageStore
-
- create(AlluxioConfiguration) - Static method in class alluxio.client.file.cache.store.PageStoreOptions
-
- 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
-
- create(Subject, AlluxioConfiguration) - Static method in class alluxio.client.file.FileSystemContext
-
- create(Subject, AlluxioConfiguration, BlockWorker) - 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
-
- create(MasterClientContext) - Static method in class alluxio.client.file.FileSystemMasterClient.Factory
-
- 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
-
- create(String) - Static method in class alluxio.client.quota.CacheScope
-
- create(MasterClientContext) - Static method in class alluxio.client.table.TableMasterClient.Factory
-
- 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
-
- 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(String, long, FuseFileInfo) - Method in class alluxio.fuse.AlluxioJniFuseFileSystem
-
- create(FileSystem, AlluxioConfiguration, AbstractFuseFileSystem) - Static method in class alluxio.fuse.auth.AuthPolicyFactory
-
- create(String, long, FuseFileInfo) - Method in class alluxio.fuse.StackFS
-
- create(AlluxioConfiguration) - Static method in class alluxio.grpc.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(String, long, FuseFileInfo) - Method in interface alluxio.jnifuse.FuseFileSystem
-
- 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.orc.OrcReader
-
- 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, PartitionInfo) - Static method in class alluxio.job.plan.transform.format.parquet.ParquetWriter
-
Creates a parquet writer based on the partitionInfo.
- 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 and whether to have dictionary enabled.
- create(TableSchema, AlluxioURI, int, boolean, String) - 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(TableSchema, AlluxioURI, PartitionInfo) - 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
-
- create() - Static method in class alluxio.master.AlluxioMasterProcess.Factory
-
- create(MasterRegistry, CoreMasterContext) - Method in class alluxio.master.block.BlockMasterFactory
-
- create(FileSystemMasterView) - Static method in class alluxio.master.file.async.AsyncPersistHandler.Factory
-
- create(CheckAccessPOptions.Builder) - Static method in class alluxio.master.file.contexts.CheckAccessContext
-
- create(CheckConsistencyPOptions.Builder) - Static method in class alluxio.master.file.contexts.CheckConsistencyContext
-
- create(CompleteFilePOptions.Builder) - Static method in class alluxio.master.file.contexts.CompleteFileContext
-
- create(CreateDirectoryPOptions.Builder) - Static method in class alluxio.master.file.contexts.CreateDirectoryContext
-
- create(CreateFilePOptions.Builder) - Static method in class alluxio.master.file.contexts.CreateFileContext
-
- create(DeletePOptions.Builder) - Static method in class alluxio.master.file.contexts.DeleteContext
-
- create(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(LoadMetadataPOptions.Builder) - Static method in class alluxio.master.file.contexts.LoadMetadataContext
-
- create(MountPOptions.Builder) - Static method in class alluxio.master.file.contexts.MountContext
-
- create(RenamePOptions.Builder) - Static method in class alluxio.master.file.contexts.RenameContext
-
- create(ScheduleAsyncPersistencePOptions.Builder) - Static method in class alluxio.master.file.contexts.ScheduleAsyncPersistenceContext
-
- create(SetAclPOptions.Builder) - Static method in class alluxio.master.file.contexts.SetAclContext
-
- create(SetAttributePOptions.Builder) - Static method in class alluxio.master.file.contexts.SetAttributeContext
-
- create(FileSystemHeartbeatPOptions.Builder) - Static method in class alluxio.master.file.contexts.WorkerHeartbeatContext
-
- create(MasterRegistry, CoreMasterContext) - Method in class alluxio.master.file.FileSystemMasterFactory
-
- create(InodeStore, InodeDirectory) - Static method in class alluxio.master.file.meta.InodeTreeBufferedIterator
-
Creates buffered iterator with closeable interface.
- create(long, long, String, CreateDirectoryContext) - Static method in class alluxio.master.file.meta.MutableInodeDirectory
-
- create(long, long, String, long, CreateFileContext) - Static method in class alluxio.master.file.meta.MutableInodeFile
-
- 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
-
- 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
-
- 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(FileInStream, long, S3RangeSpec) - Static method in class alluxio.proxy.s3.RangeFileInStream.Factory
-
- create(String) - Static method in class alluxio.proxy.s3.S3RangeSpec.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(Properties) - Method in class alluxio.table.common.transform.action.CompactAction.CompactActionFactory
-
- create(Properties) - Method in interface alluxio.table.common.transform.action.TransformActionFactory
-
Creates a new instance of an action based on the properties.
- create(Properties) - Static method in class alluxio.table.common.transform.action.TransformActionRegistry
-
- 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
-
- create(UdbContext, UdbConfiguration) - Static method in class alluxio.table.under.glue.GlueDatabase
-
Create an instance of the Glue database UDB.
- create(UdbContext, UdbConfiguration) - Method in class alluxio.table.under.glue.GlueDatabaseFactory
-
- 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, UnderFileSystemConfiguration) - Method in class alluxio.underfs.abfs.AbfsUnderFileSystemFactory
-
- create(String, UnderFileSystemConfiguration) - Method in class alluxio.underfs.adl.AdlUnderFileSystemFactory
-
- create(String) - Method in class alluxio.underfs.BaseUnderFileSystem
-
- create(String, CreateOptions) - Method in class alluxio.underfs.cephfs.CephFSUnderFileSystem
-
- create(String, UnderFileSystemConfiguration) - Method in class alluxio.underfs.cephfs.CephFSUnderFileSystemFactory
-
- create(String, UnderFileSystemConfiguration) - Method in class alluxio.underfs.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
-
- 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(AlluxioConfiguration) - Static method in class alluxio.util.network.tls.SslContextProvider.Factory
-
- create(BlockMetadataView) - Static method in class alluxio.worker.block.allocator.Allocator.Factory
-
- create() - Static method in class alluxio.worker.block.annotator.BlockAnnotator.Factory
-
- create(WorkerRegistry, UfsManager) - Method in class alluxio.worker.block.BlockWorkerFactory
-
- create(BlockMetadataEvictorView, Allocator) - Static method in class alluxio.worker.block.evictor.Evictor.Factory
-
- create() - Static method in class alluxio.worker.block.reviewer.Reviewer.Factory
-
- create(UnderFileSystemBlockMeta, long, boolean, BlockStore, UfsManager, UfsInputStreamCache, String) - Static method in class alluxio.worker.block.UnderFileSystemBlockReader
-
- create(JobMasterClientContext) - Static method in class alluxio.worker.job.JobMasterClient.Factory
-
- 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.cli.S3ASpecificOperations
-
Test for creating and aborting a multipart file.
- createAsyncGlueClient(UdbConfiguration) - Static method in class alluxio.table.under.glue.GlueDatabase
-
This method allows user to test udb glue client with remote glue server.
- createAtomicTest() - Method in class alluxio.cli.UnderFileSystemCommonOperations
-
Test for creating file atomic.
- createAwsCredentialsProvider(UnderFileSystemConfiguration) - Static method in class alluxio.underfs.s3a.S3AUnderFileSystem
-
- createBlock(long, long, AllocateOptions) - 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, int, String, long) - Method in interface alluxio.worker.block.BlockWorker
-
Creates a block in Alluxio managed space.
- createBlock(long, long, int, String, long) - Method in class alluxio.worker.block.DefaultBlockWorker
-
- createBlock(long, long, AllocateOptions) - 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
-
- createBlockPath(String, String) - Static method in class alluxio.util.io.FileUtils
-
Creates the local block path and all the parent directories.
- createBlockReader(BlockReadRequest) - Method in interface alluxio.worker.block.BlockWorker
-
Creates the block reader to read from Alluxio block or UFS block.
- createBlockReader(BlockReadRequest) - Method in class alluxio.worker.block.DefaultBlockWorker
-
- createBlockWriter(long, long) - Method in interface alluxio.worker.block.BlockWorker
-
- createBlockWriter(long, long) - Method in class alluxio.worker.block.DefaultBlockWorker
-
- createBucket(String, String) - Method in class alluxio.proxy.s3.S3RestServiceHandler
-
- createCallback(String, long, ByteBuffer) - Method in class alluxio.jnifuse.AbstractFuseFileSystem
-
- createConfiguration(UnderFileSystemConfiguration) - Static method in class alluxio.underfs.adl.AdlUnderFileSystem
-
Prepares the configuration for this Adl as an HDFS configuration.
- createConfiguration(UnderFileSystemConfiguration) - Static method in class alluxio.underfs.hdfs.HdfsUnderFileSystem
-
Prepares the Hadoop configuration necessary to successfully obtain a FileSystem
instance that can access the provided path.
- createConfiguration(UnderFileSystemConfiguration, Boolean) - Static method in class alluxio.underfs.wasb.WasbUnderFileSystem
-
Prepares the configuration for this Wasb as an HDFS configuration.
- CREATED_VALUE - Static variable in enum alluxio.grpc.Status
-
CREATED = 1;
- createDeleteFileConjuctionTest() - Method in class alluxio.cli.UnderFileSystemCommonOperations
-
Test for creating and deleting file conjunction.
- createDir(String) - Static method in class alluxio.util.io.FileUtils
-
Creates an empty directory and its intermediate directories if necessary.
- createDirect(String, CreateOptions) - Method in interface alluxio.underfs.AtomicFileOutputStreamCallback
-
Creates a file in the under file system with the specified
CreateOptions
.
- createDirect(String, CreateOptions) - Method in class alluxio.underfs.cephfs.CephFSUnderFileSystem
-
- createDirect(String, CreateOptions) - Method in class alluxio.underfs.hdfs.HdfsUnderFileSystem
-
- createDirect(String, CreateOptions) - Method in class alluxio.underfs.local.LocalUnderFileSystem
-
- createDirectory(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
-
- 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.MetadataCachingBaseFileSystem
-
- 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 - 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
-
- 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.cli.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.gcs.v2.GCSV2UnderFileSystem
-
- 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.cli.UnderFileSystemCommonOperations
-
Test for creating empty file.
- createEventLoop(ChannelType, int, String, boolean) - Static method in class alluxio.util.network.NettyUtils
-
- 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
-
- 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.MetadataCachingBaseFileSystem
-
- 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 - 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
-
- createFileDefaults(AlluxioConfiguration) - Static method in class alluxio.util.FileSystemOptions
-
- CreateFileEntry<T extends OutputStream> - Class in alluxio.fuse
-
Convenience class to encapsulate output stream
and its information (path, id) for create alluxio file.
- CreateFileEntry(long, String, T) - Constructor for class alluxio.fuse.CreateFileEntry
-
- createFileId(long) - Static method in class alluxio.util.IdUtils
-
Creates an id for a file based on the given id of the container.
- createFileLessThanOnePartTest() - Method in class alluxio.cli.S3ASpecificOperations
-
Test for creating a file with data less than one part.
- CreateFilePOptions - Class in alluxio.grpc
-
Protobuf type alluxio.grpc.file.CreateFilePOptions
- CreateFilePOptions.Builder - Class in alluxio.grpc
-
Protobuf type alluxio.grpc.file.CreateFilePOptions
- CreateFilePOptionsOrBuilder - Interface in alluxio.grpc
-
- CreateFilePRequest - Class in alluxio.grpc
-
Protobuf type alluxio.grpc.file.CreateFilePRequest
- CreateFilePRequest.Builder - Class in alluxio.grpc
-
Protobuf type alluxio.grpc.file.CreateFilePRequest
- CreateFilePRequestOrBuilder - Interface in alluxio.grpc
-
- CreateFilePResponse - Class in alluxio.grpc
-
Protobuf type alluxio.grpc.file.CreateFilePResponse
- CreateFilePResponse.Builder - Class in alluxio.grpc
-
Protobuf type alluxio.grpc.file.CreateFilePResponse
- CreateFilePResponseOrBuilder - Interface in alluxio.grpc
-
- 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
-
- createFullAccess() - Static method in class alluxio.security.authorization.Mode
-
Creates the "full access" mode.
- CreateHmsClientValidationTask - Class in alluxio.cli.hms
-
A validation task that generates a new Hive Metastore client and verifies the connection.
- CreateHmsClientValidationTask(int, MetastoreValidationTask<?, String>) - Constructor for class alluxio.cli.hms.CreateHmsClientValidationTask
-
- createInstance(AlluxioURI, UnderFileSystemConfiguration) - Static method in class alluxio.underfs.abfs.AbfsUnderFileSystem
-
- createInstance(AlluxioURI, UnderFileSystemConfiguration) - Static method in class alluxio.underfs.adl.AdlUnderFileSystem
-
- createInstance(AlluxioURI, UnderFileSystemConfiguration) - Static method in class alluxio.underfs.cephfs.CephFSUnderFileSystem
-
- createInstance(AlluxioURI, UnderFileSystemConfiguration) - Static method in class alluxio.underfs.cos.COSUnderFileSystem
-
- createInstance(AlluxioURI, UnderFileSystemConfiguration) - Static method in class alluxio.underfs.gcs.GCSUnderFileSystem
-
- createInstance(AlluxioURI, UnderFileSystemConfiguration) - Static method in class alluxio.underfs.gcs.v2.GCSV2UnderFileSystem
-
- createInstance(AlluxioURI, UnderFileSystemConfiguration) - Static method in class alluxio.underfs.hdfs.HdfsUnderFileSystem
-
- createInstance(AlluxioURI, UnderFileSystemConfiguration) - Static method in class alluxio.underfs.oss.OSSUnderFileSystem
-
- createInstance(AlluxioURI, UnderFileSystemConfiguration) - Static method in class alluxio.underfs.s3a.S3AUnderFileSystem
-
- createInstance(AlluxioURI, UnderFileSystemConfiguration) - Static method in class alluxio.underfs.wasb.WasbUnderFileSystem
-
- 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.BlockWorkerClientServiceHandler
-
- 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
-
- 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.
- createMove(BlockStoreLocation, long, BlockStoreLocation) - Static method in class alluxio.worker.block.evictor.BlockTransferInfo
-
- createMultipartFileTest() - Method in class alluxio.cli.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.DefaultHiveClientPool
-
- 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
-
- createNoParentTest() - Method in class alluxio.cli.UnderFileSystemCommonOperations
-
Test for creating file without parent.
- createObject(String) - Method in class alluxio.underfs.cos.COSUnderFileSystem
-
- createObject(String) - Method in class alluxio.underfs.gcs.GCSUnderFileSystem
-
- createObject(String) - Method in class alluxio.underfs.gcs.v2.GCSV2UnderFileSystem
-
- createObject(String) - Method in class alluxio.underfs.kodo.KodoUnderFileSystem
-
- createObject(String) - Method in class alluxio.underfs.ObjectUnderFileSystem
-
- 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, String, String, Integer, Long, InputStream) - Method in class alluxio.proxy.s3.S3RestServiceHandler
-
- createOpenAtPositionTest() - Method in class alluxio.cli.UnderFileSystemCommonOperations
-
Test for creating file and opening at position.
- createOpenEmptyTest() - Method in class alluxio.cli.UnderFileSystemCommonOperations
-
Test for creating and opening empty file.
- createOpenExistingLargeFileTest() - Method in class alluxio.cli.UnderFileSystemCommonOperations
-
Test for creating and open existing large file.
- createOpenFilesLimitValidationTask() - Static method in class alluxio.cli.UserLimitValidationTask
-
Creates a validation task for checking whether the user limit for number of open files
is within reasonable range.
- createOpenLargeTest() - Method in class alluxio.cli.UnderFileSystemCommonOperations
-
Test for creating and opening large file.
- createOpenSkip() - Method in class alluxio.cli.UnderFileSystemCommonOperations
-
Test for create file, open and seek.
- createOpenTest() - Method in class alluxio.cli.UnderFileSystemCommonOperations
-
Test for creating and opening file.
- CreateOptions - Class in alluxio.underfs.options
-
Method options for creating a file in UnderFileSystem.
- createOrGetAppIdFromConfig(AlluxioConfiguration) - Static method in class alluxio.util.IdUtils
-
- createParentTest() - Method in class alluxio.cli.UnderFileSystemCommonOperations
-
Test for creating file with parent.
- createPath(RpcContext, LockedInodePath, CreatePathContext<?, ?>) - Method in class alluxio.master.file.meta.InodeTree
-
Creates a file or directory at path.
- CreatePathContext<T extends com.google.protobuf.GeneratedMessageV3.Builder<?>,K extends CreatePathContext<?,?>> - Class in alluxio.master.file.contexts
-
- 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
-
- 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
-
- 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
-
- createRpcContext(OperationContext) - Method in class alluxio.master.file.DefaultFileSystemMaster
-
- createRpcId() - Static method in class alluxio.util.IdUtils
-
- createSample(String, String, List<String>, List<String>, double) - Method in class alluxio.metrics.sink.RatisNameRewriteSampleBuilder
-
- createSaslHandler(ChannelAuthenticationScheme) - Method in interface alluxio.security.authentication.AuthenticationServer
-
Creates server-side Sasl handler for given scheme.
- createSaslHandler(ChannelAuthenticationScheme) - Method in class alluxio.security.authentication.DefaultAuthenticationServer
-
- createSaslServer(String, String, String, Map<String, ?>, CallbackHandler) - Method in class alluxio.security.authentication.plain.PlainSaslServer.Factory
-
Creates a
SaslServer
using the parameters supplied.
- createSessionId() - Static method in class alluxio.util.IdUtils
-
- createSessionId() - Static method in class alluxio.util.SessionIdUtils
-
- 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
-
- createSwap(BlockStoreLocation, long, BlockStoreLocation, long) - Static method in class alluxio.worker.block.evictor.BlockTransferInfo
-
- 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.
- createTempSnapshotFile(SimpleStateMachineStorage) - Static method in class alluxio.master.journal.raft.RaftJournalUtils
-
Creates a temporary snapshot file.
- createThenDeleteExistingDirectoryTest() - Method in class alluxio.cli.UnderFileSystemCommonOperations
-
Test for creating and deleting existing directory.
- createThenGetExistingDirectoryStatusTest() - Method in class alluxio.cli.UnderFileSystemCommonOperations
-
Test for getting existing directory status.
- createThenGetExistingFileStatusTest() - Method in class alluxio.cli.UnderFileSystemCommonOperations
-
Test for getting existing file status.
- createThenGetExistingStatusTest() - Method in class alluxio.cli.UnderFileSystemCommonOperations
-
Test for getting existing status.
- createUfsBlockReader(long, long, long, boolean, Protocol.OpenUfsBlockOptions) - Method in interface alluxio.worker.block.BlockWorker
-
Creates a block reader to read a UFS block starting from given block offset.
- createUfsBlockReader(long, long, long, boolean, Protocol.OpenUfsBlockOptions) - Method in class alluxio.worker.block.DefaultBlockWorker
-
- createUnstartedStopwatch() - Method in class alluxio.client.file.cache.LocalCacheFileInStream
-
- createUserProcessesLimitValidationTask() - Static method in class alluxio.cli.UserLimitValidationTask
-
Creates a validation task for checking whether the user limit for number of user processes
is within reasonable range.
- 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
-
- CREDENTIAL_FIELD_MASKER - Static variable in class alluxio.RpcSensitiveConfigMask
-
- CredentialPropertyKeys - Class in alluxio.conf
-
This class stores names of property keys whose values are credential.
- CredentialPropertyKeys() - Constructor for class alluxio.conf.CredentialPropertyKeys
-
- 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
-
- 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
-
- 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
-
- 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.
- CustomAuthPolicy - Class in alluxio.fuse.auth
-
A Fuse authentication policy supports user-defined user and group.
- CustomAuthPolicy(FileSystem, AlluxioConfiguration, AbstractFuseFileSystem) - Constructor for class alluxio.fuse.auth.CustomAuthPolicy
-
- 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_COSTMAP - Static variable in class alluxio.master.metrics.CloudCostUtils
-
- GCS_CREDENTIAL_PATH - Static variable in class alluxio.conf.PropertyKey
-
- GCS_CREDENTIAL_PATH - Static variable in class alluxio.conf.PropertyKey.Name
-
- GCS_SECRET_KEY - Static variable in class alluxio.conf.PropertyKey
-
- GCS_SECRET_KEY - Static variable in class alluxio.conf.PropertyKey.Name
-
- GCSInputStream - Class in alluxio.underfs.gcs
-
A stream for reading a file from GCS.
- GCSOutputStream - Class in alluxio.underfs.gcs
-
A stream for writing a file into GCS.
- GCSOutputStream(String, String, GoogleStorageService, List<String>) - Constructor for class alluxio.underfs.gcs.GCSOutputStream
-
Constructs a new stream for writing a file.
- GCSUnderFileSystem - Class in alluxio.underfs.gcs
-
Google Cloud Storage
UnderFileSystem
implementation based on the jets3t library.
- GCSUnderFileSystem(AlluxioURI, GoogleStorageService, String, UnderFileSystemConfiguration) - Constructor for class alluxio.underfs.gcs.GCSUnderFileSystem
-
- GCSUnderFileSystemFactory - Class in alluxio.underfs.gcs
-
- GCSUnderFileSystemFactory() - Constructor for class alluxio.underfs.gcs.GCSUnderFileSystemFactory
-
- GCSUtils - Class in alluxio.underfs.gcs
-
Util functions for GCS under file system.
- GCSV2InputStream - Class in alluxio.underfs.gcs.v2
-
A stream for reading a file from GCS using Google cloud API (GCS input stream version 2).
- GCSV2OutputStream - Class in alluxio.underfs.gcs.v2
-
A stream for writing a file into GCS using Google cloud API (GCS output stream version 2).
- GCSV2OutputStream(String, String, Storage) - Constructor for class alluxio.underfs.gcs.v2.GCSV2OutputStream
-
Constructs a new stream for writing a file.
- GCSV2UnderFileSystem - Class in alluxio.underfs.gcs.v2
-
GCS FS
UnderFileSystem
implementation based on the Google cloud storage library.
- GCSV2UnderFileSystem(AlluxioURI, Storage, String, UnderFileSystemConfiguration) - Constructor for class alluxio.underfs.gcs.v2.GCSV2UnderFileSystem
-
- GeneralWorker(int, int, int, ByteBuffer, boolean, boolean, String) - Constructor for class alluxio.examples.Performance.GeneralWorker
-
- generate() - Static method in class alluxio.cli.docgen.ConfigurationDocGenerator
-
Generates the configuration docs.
- generate() - Static method in class alluxio.cli.docgen.MetricsDocGenerator
-
Writes the supported files for metrics system docs.
- generate(List<? extends Summary>) - Method in class alluxio.stress.client.ClientIOTaskResult.GraphGenerator
-
- generate(List<? extends Summary>) - Method in class alluxio.stress.fuse.FuseIOTaskResult.GraphGenerator
-
- generate(List<? extends Summary>) - Method in class alluxio.stress.GraphGenerator
-
- generate(List<? extends Summary>) - Method in class alluxio.stress.jobservice.JobServiceBenchSummary.GraphGenerator
-
- generate(List<? extends Summary>) - Method in class alluxio.stress.master.MasterBenchSummary.GraphGenerator
-
- generate(List<? extends Summary>) - Method in class alluxio.stress.master.MaxThroughputSummary.GraphGenerator
-
- generate(List<? extends Summary>) - Method in class alluxio.stress.worker.IOTaskSummary.GraphGenerator
-
- generate(List<? extends Summary>) - Method in class alluxio.stress.worker.WorkerBenchSummary.GraphGenerator
-
- 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(String[]) - Method in class alluxio.stress.cli.Benchmark
-
- generateJobConfig(Layout, Layout, boolean) - Method in class alluxio.table.common.transform.action.CompactAction
-
- generateJobConfig(Layout, Layout, boolean) - Method in interface alluxio.table.common.transform.action.TransformAction
-
- 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 - Class in alluxio.stress.cli.report
-
Generates a report from summaries.
- GenerateReport() - Constructor for class alluxio.stress.cli.report.GenerateReport
-
Creates an instance.
- 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, CacheContext) - Method in interface alluxio.client.file.cache.CacheManager
-
Reads a part of a page if the queried page is found in the cache, stores the result in
buffer.
- get(PageId, int, int, byte[], int, CacheContext) - Method in class alluxio.client.file.cache.CacheManagerWithShadowCache
-
- get(PageId, int, int, byte[], int, CacheContext) - 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, int, int, byte[], int, CacheContext) - Method in class alluxio.client.file.cache.NoExceptionCacheManager
-
- get(PageId, byte[]) - Method in interface alluxio.client.file.cache.PageStore
-
Gets a page from the store to the destination buffer.
- get(PageId, int, int, byte[], int) - Method in interface alluxio.client.file.cache.PageStore
-
Gets part of a page from the store to the destination buffer.
- get(PageId, int, int, byte[], int) - Method in class alluxio.client.file.cache.store.LocalPageStore
-
- get(PageId, int, int, byte[], int) - Method in class alluxio.client.file.cache.store.RocksPageStore
-
- get(PageId, int, int, byte[], int) - Method in class alluxio.client.file.cache.TimeBoundPageStore
-
- get() - Static method in class alluxio.client.file.FileSystem.Factory
-
- get(Subject) - Static method in class alluxio.client.file.FileSystem.Factory
-
Get a FileSystem from the cache with a given subject.
- get(Subject, AlluxioConfiguration) - Static method in class alluxio.client.file.FileSystem.Factory
-
- get(FileSystemCache.Key) - Method in class alluxio.client.file.FileSystemCache
-
- 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(K, LockMode, boolean) - 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
-
- 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
-
- 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_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_STATUS - Static variable in class alluxio.job.ServiceConstants
-
- GET_STATUS - Static variable in class alluxio.proxy.PathsRestServiceHandler
-
- getAbsolutePath() - Method in class alluxio.util.webui.UIFileInfo
-
Gets absolute path.
- getAccessAcl() - Method in class alluxio.proto.meta.InodeMeta.Inode.Builder
-
optional .alluxio.proto.shared.AccessControlList access_acl = 10;
- getAccessAcl() - Method in class alluxio.proto.meta.InodeMeta.Inode
-
optional .alluxio.proto.shared.AccessControlList access_acl = 10;
- getAccessAcl() - Method in interface alluxio.proto.meta.InodeMeta.InodeOrBuilder
-
optional .alluxio.proto.shared.AccessControlList access_acl = 10;
- getAccessAclBuilder() - Method in class alluxio.proto.meta.InodeMeta.Inode.Builder
-
optional .alluxio.proto.shared.AccessControlList access_acl = 10;
- getAccessAclOrBuilder() - Method in class alluxio.proto.meta.InodeMeta.Inode.Builder
-
optional .alluxio.proto.shared.AccessControlList access_acl = 10;
- getAccessAclOrBuilder() - Method in class alluxio.proto.meta.InodeMeta.Inode
-
optional .alluxio.proto.shared.AccessControlList access_acl = 10;
- getAccessAclOrBuilder() - Method in interface alluxio.proto.meta.InodeMeta.InodeOrBuilder
-
optional .alluxio.proto.shared.AccessControlList access_acl = 10;
- getAccessControlException() - Method in class alluxio.wire.MasterWebUIBrowse
-
Gets access control exception.
- 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
-
- 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;
- getAddQuorumServerRequest() - Method in class alluxio.grpc.JournalQueryRequest.Builder
-
optional .alluxio.grpc.meta.AddQuorumServerRequest addQuorumServerRequest = 3;
- getAddQuorumServerRequest() - Method in class alluxio.grpc.JournalQueryRequest
-
optional .alluxio.grpc.meta.AddQuorumServerRequest addQuorumServerRequest = 3;
- getAddQuorumServerRequest() - Method in interface alluxio.grpc.JournalQueryRequestOrBuilder
-
optional .alluxio.grpc.meta.AddQuorumServerRequest addQuorumServerRequest = 3;
- getAddQuorumServerRequestBuilder() - Method in class alluxio.grpc.JournalQueryRequest.Builder
-
optional .alluxio.grpc.meta.AddQuorumServerRequest addQuorumServerRequest = 3;
- getAddQuorumServerRequestOrBuilder() - Method in class alluxio.grpc.JournalQueryRequest.Builder
-
optional .alluxio.grpc.meta.AddQuorumServerRequest addQuorumServerRequest = 3;
- getAddQuorumServerRequestOrBuilder() - Method in class alluxio.grpc.JournalQueryRequest
-
optional .alluxio.grpc.meta.AddQuorumServerRequest addQuorumServerRequest = 3;
- getAddQuorumServerRequestOrBuilder() - Method in interface alluxio.grpc.JournalQueryRequestOrBuilder
-
optional .alluxio.grpc.meta.AddQuorumServerRequest addQuorumServerRequest = 3;
- getAddress() - Method in class alluxio.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;
- getAddTablePartitions() - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
-
optional .alluxio.proto.journal.AddTablePartitionsEntry add_table_partitions = 51;
- getAddTablePartitions() - Method in class alluxio.proto.journal.Journal.JournalEntry
-
optional .alluxio.proto.journal.AddTablePartitionsEntry add_table_partitions = 51;
- getAddTablePartitions() - Method in interface alluxio.proto.journal.Journal.JournalEntryOrBuilder
-
optional .alluxio.proto.journal.AddTablePartitionsEntry add_table_partitions = 51;
- getAddTablePartitionsBuilder() - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
-
optional .alluxio.proto.journal.AddTablePartitionsEntry add_table_partitions = 51;
- getAddTablePartitionsOrBuilder() - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
-
optional .alluxio.proto.journal.AddTablePartitionsEntry add_table_partitions = 51;
- getAddTablePartitionsOrBuilder() - Method in class alluxio.proto.journal.Journal.JournalEntry
-
optional .alluxio.proto.journal.AddTablePartitionsEntry add_table_partitions = 51;
- getAddTablePartitionsOrBuilder() - Method in interface alluxio.proto.journal.Journal.JournalEntryOrBuilder
-
optional .alluxio.proto.journal.AddTablePartitionsEntry add_table_partitions = 51;
- 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;
- getAdvice() - Method in class alluxio.cli.ValidationTaskResult
-
- getAffectedPaths(int) - Method in class alluxio.grpc.JobInfo.Builder
-
repeated string affectedPaths = 14;
- getAffectedPaths(int) - Method in class alluxio.grpc.JobInfo
-
repeated string affectedPaths = 14;
- getAffectedPaths(int) - Method in interface alluxio.grpc.JobInfoOrBuilder
-
repeated string affectedPaths = 14;
- getAffectedPaths() - Method in interface alluxio.job.wire.JobInfo
-
- getAffectedPaths() - Method in class alluxio.job.wire.PlanInfo
-
- getAffectedPathsBytes(int) - Method in class alluxio.grpc.JobInfo.Builder
-
repeated string affectedPaths = 14;
- getAffectedPathsBytes(int) - Method in class alluxio.grpc.JobInfo
-
repeated string affectedPaths = 14;
- getAffectedPathsBytes(int) - Method in interface alluxio.grpc.JobInfoOrBuilder
-
repeated string affectedPaths = 14;
- getAffectedPathsCount() - Method in class alluxio.grpc.JobInfo.Builder
-
repeated string affectedPaths = 14;
- getAffectedPathsCount() - Method in class alluxio.grpc.JobInfo
-
repeated string affectedPaths = 14;
- getAffectedPathsCount() - Method in interface alluxio.grpc.JobInfoOrBuilder
-
repeated string affectedPaths = 14;
- getAffectedPathsList() - Method in class alluxio.grpc.JobInfo.Builder
-
repeated string affectedPaths = 14;
- getAffectedPathsList() - Method in class alluxio.grpc.JobInfo
-
repeated string affectedPaths = 14;
- getAffectedPathsList() - Method in interface alluxio.grpc.JobInfoOrBuilder
-
repeated string affectedPaths = 14;
- getAlias(int) - Method in class alluxio.AbstractStorageTierAssoc
-
- getAlias(int) - Method in interface alluxio.StorageTierAssoc
-
- getAliases() - Method in class alluxio.conf.PropertyKey
-
- getAll() - Method in class alluxio.grpc.table.AllOrNoneSet.Builder
-
optional bool all = 1;
- getAll() - Method in class alluxio.grpc.table.AllOrNoneSet
-
optional bool all = 1;
- getAll() - Method in interface alluxio.grpc.table.AllOrNoneSetOrBuilder
-
optional bool all = 1;
- getAllDatabases() - Method in class alluxio.client.table.RetryHandlingTableMasterClient
-
- getAllDatabases() - Method in interface alluxio.client.table.TableMasterClient
-
Get a list of all database names.
- getAllDatabases(GetAllDatabasesPRequest) - 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
-
.alluxio.grpc.table.AllOrNoneSet all_or_none = 3;
- getAllOrNone() - Method in class alluxio.grpc.table.Domain
-
.alluxio.grpc.table.AllOrNoneSet all_or_none = 3;
- getAllOrNone() - Method in interface alluxio.grpc.table.DomainOrBuilder
-
.alluxio.grpc.table.AllOrNoneSet all_or_none = 3;
- getAllOrNoneBuilder() - Method in class alluxio.grpc.table.Domain.Builder
-
.alluxio.grpc.table.AllOrNoneSet all_or_none = 3;
- getAllOrNoneOrBuilder() - Method in class alluxio.grpc.table.Domain.Builder
-
.alluxio.grpc.table.AllOrNoneSet all_or_none = 3;
- getAllOrNoneOrBuilder() - Method in class alluxio.grpc.table.Domain
-
.alluxio.grpc.table.AllOrNoneSet all_or_none = 3;
- getAllOrNoneOrBuilder() - Method in interface alluxio.grpc.table.DomainOrBuilder
-
.alluxio.grpc.table.AllOrNoneSet all_or_none = 3;
- 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.FuseMountOptions
-
- getAlluxioSchema() - Method in class alluxio.job.plan.transform.format.csv.CsvSchema
-
- getAlluxioSchema() - Method in class alluxio.job.plan.transform.format.orc.OrcSchema
-
- 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
-
- 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
-
- getArgs() - Method in class alluxio.stress.job.StressBenchConfig
-
- getArrayHeaderSize() - Method in interface alluxio.util.ObjectSizeCalculator.MemoryLayoutSpecification
-
Returns the fixed overhead of an array of any type or length in this JVM.
- getAscendingIterator() - Method in class alluxio.worker.block.annotator.SortedBlockSet
-
- getAsync() - Method in class alluxio.grpc.CacheRequest.Builder
-
optional bool async = 6;
- getAsync() - Method in class alluxio.grpc.CacheRequest
-
optional bool async = 6;
- getAsync() - Method in interface alluxio.grpc.CacheRequestOrBuilder
-
optional bool async = 6;
- getAsyncCacheMethod() - Static method in class alluxio.grpc.BlockWorkerGrpc
-
- getAsyncMode() - Method in class alluxio.concurrent.jsr.ForkJoinPool
-
Returns true
if this pool uses local first-in-first-out scheduling mode for forked
tasks that are never joined.
- getAsyncPersistOptions() - Method in class alluxio.grpc.CompleteFilePOptions.Builder
-
optional .alluxio.grpc.file.ScheduleAsyncPersistencePOptions asyncPersistOptions = 2;
- getAsyncPersistOptions() - Method in class alluxio.grpc.CompleteFilePOptions
-
optional .alluxio.grpc.file.ScheduleAsyncPersistencePOptions asyncPersistOptions = 2;
- getAsyncPersistOptions() - Method in interface alluxio.grpc.CompleteFilePOptionsOrBuilder
-
optional .alluxio.grpc.file.ScheduleAsyncPersistencePOptions asyncPersistOptions = 2;
- getAsyncPersistOptionsBuilder() - Method in class alluxio.grpc.CompleteFilePOptions.Builder
-
optional .alluxio.grpc.file.ScheduleAsyncPersistencePOptions asyncPersistOptions = 2;
- getAsyncPersistOptionsOrBuilder() - Method in class alluxio.grpc.CompleteFilePOptions.Builder
-
optional .alluxio.grpc.file.ScheduleAsyncPersistencePOptions asyncPersistOptions = 2;
- getAsyncPersistOptionsOrBuilder() - Method in class alluxio.grpc.CompleteFilePOptions
-
optional .alluxio.grpc.file.ScheduleAsyncPersistencePOptions asyncPersistOptions = 2;
- getAsyncPersistOptionsOrBuilder() - Method in interface alluxio.grpc.CompleteFilePOptionsOrBuilder
-
optional .alluxio.grpc.file.ScheduleAsyncPersistencePOptions asyncPersistOptions = 2;
- getAsyncPersistRequest() - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
-
optional .alluxio.proto.journal.AsyncPersistRequestEntry async_persist_request = 16;
- getAsyncPersistRequest() - Method in class alluxio.proto.journal.Journal.JournalEntry
-
optional .alluxio.proto.journal.AsyncPersistRequestEntry async_persist_request = 16;
- getAsyncPersistRequest() - Method in interface alluxio.proto.journal.Journal.JournalEntryOrBuilder
-
optional .alluxio.proto.journal.AsyncPersistRequestEntry async_persist_request = 16;
- getAsyncPersistRequestBuilder() - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
-
optional .alluxio.proto.journal.AsyncPersistRequestEntry async_persist_request = 16;
- getAsyncPersistRequestOrBuilder() - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
-
optional .alluxio.proto.journal.AsyncPersistRequestEntry async_persist_request = 16;
- getAsyncPersistRequestOrBuilder() - Method in class alluxio.proto.journal.Journal.JournalEntry
-
optional .alluxio.proto.journal.AsyncPersistRequestEntry async_persist_request = 16;
- getAsyncPersistRequestOrBuilder() - Method in interface alluxio.proto.journal.Journal.JournalEntryOrBuilder
-
optional .alluxio.proto.journal.AsyncPersistRequestEntry async_persist_request = 16;
- 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.
- getattr(String, FileStat) - Method in class alluxio.fuse.AlluxioJniFuseFileSystem
-
- getattr(String, FileStat) - Method in class alluxio.fuse.StackFS
-
- getattr(String, FileStat) - Method in interface alluxio.jnifuse.FuseFileSystem
-
- getattrCallback(String, ByteBuffer) - Method in class alluxio.jnifuse.AbstractFuseFileSystem
-
- 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() - Method in class alluxio.wire.JournalDiskInfo
-
- getAvailableBytes(BlockStoreLocation) - Method in class alluxio.worker.block.BlockMetadataEvictorView
-
- 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.DefaultStorageDir
-
- getAvailableBytes() - Method in class alluxio.worker.block.meta.DefaultStorageTier
-
- getAvailableBytes() - Method in interface 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 interface alluxio.worker.block.meta.StorageTier
-
- getAvgColLen() - Method in class alluxio.grpc.table.BinaryColumnStatsData.Builder
-
optional double avg_col_len = 2;
- getAvgColLen() - Method in class alluxio.grpc.table.BinaryColumnStatsData
-
optional double avg_col_len = 2;
- getAvgColLen() - Method in interface alluxio.grpc.table.BinaryColumnStatsDataOrBuilder
-
optional double avg_col_len = 2;
- getAvgColLen() - Method in class alluxio.grpc.table.StringColumnStatsData.Builder
-
optional double avg_col_len = 2;
- getAvgColLen() - Method in class alluxio.grpc.table.StringColumnStatsData
-
optional double avg_col_len = 2;
- getAvgColLen() - Method in interface alluxio.grpc.table.StringColumnStatsDataOrBuilder
-
optional double avg_col_len = 2;
- 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;
- getBaseName(String) - Static method in class alluxio.metrics.Metric
-
Gets the simple name without the tags.
- getBaseParameters() - Method in class alluxio.stress.client.ClientIOTaskResult
-
- getBaseParameters() - Method in class alluxio.stress.fuse.FuseIOTaskResult
-
- getBaseParameters() - Method in class alluxio.stress.jobservice.JobServiceBenchTaskResult
-
- getBaseParameters() - Method in class alluxio.stress.master.MasterBenchTaskResult
-
- getBaseParameters() - Method in class alluxio.stress.rpc.RpcTaskResult
-
- getBaseParameters() - Method in class alluxio.stress.rpc.RpcTaskSummary
-
- getBaseParameters() - Method in class alluxio.stress.worker.IOTaskResult
-
- getBaseParameters() - Method in class alluxio.stress.worker.IOTaskSummary
-
- getBaseParameters() - Method in class alluxio.stress.worker.WorkerBenchTaskResult
-
- 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
-
- getBenchDescription() - Method in class alluxio.stress.cli.Benchmark
-
Get the description of the bench.
- getBenchDescription() - Method in class alluxio.stress.cli.client.StressClientIOBench
-
- getBenchDescription() - Method in class alluxio.stress.cli.fuse.FuseIOBench
-
- getBenchDescription() - Method in class alluxio.stress.cli.GetPinnedFileIdsBench
-
- getBenchDescription() - Method in class alluxio.stress.cli.RegisterWorkerBench
-
- getBenchDescription() - Method in class alluxio.stress.cli.StressJobServiceBench
-
- getBenchDescription() - Method in class alluxio.stress.cli.StressMasterBench
-
- getBenchDescription() - Method in class alluxio.stress.cli.UfsIOBench
-
- getBenchDescription() - Method in class alluxio.stress.cli.worker.StressWorkerBench
-
- getBenchDescription() - Method in class alluxio.stress.cli.WorkerHeartbeatBench
-
- getBinaryStats() - Method in class alluxio.grpc.table.ColumnStatisticsData.Builder
-
.alluxio.grpc.table.BinaryColumnStatsData binary_stats = 5;
- getBinaryStats() - Method in class alluxio.grpc.table.ColumnStatisticsData
-
.alluxio.grpc.table.BinaryColumnStatsData binary_stats = 5;
- getBinaryStats() - Method in interface alluxio.grpc.table.ColumnStatisticsDataOrBuilder
-
.alluxio.grpc.table.BinaryColumnStatsData binary_stats = 5;
- getBinaryStatsBuilder() - Method in class alluxio.grpc.table.ColumnStatisticsData.Builder
-
.alluxio.grpc.table.BinaryColumnStatsData binary_stats = 5;
- getBinaryStatsOrBuilder() - Method in class alluxio.grpc.table.ColumnStatisticsData.Builder
-
.alluxio.grpc.table.BinaryColumnStatsData binary_stats = 5;
- getBinaryStatsOrBuilder() - Method in class alluxio.grpc.table.ColumnStatisticsData
-
.alluxio.grpc.table.BinaryColumnStatsData binary_stats = 5;
- getBinaryStatsOrBuilder() - Method in interface alluxio.grpc.table.ColumnStatisticsDataOrBuilder
-
.alluxio.grpc.table.BinaryColumnStatsData binary_stats = 5;
- getBindAddress(NetworkAddressUtils.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
-
- 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
-
- getBits() - Method in class alluxio.grpc.CheckAccessPOptions.Builder
-
optional .alluxio.grpc.Bits bits = 1;
- getBits() - Method in class alluxio.grpc.CheckAccessPOptions
-
optional .alluxio.grpc.Bits bits = 1;
- getBits() - Method in interface alluxio.grpc.CheckAccessPOptionsOrBuilder
-
optional .alluxio.grpc.Bits bits = 1;
- 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;
- getBlockCount() - Method in class alluxio.master.block.meta.MasterWorkerInfo
-
Return the block count of this worker.
- 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.CacheRequest.Builder
-
optional int64 block_id = 1;
- getBlockId() - Method in class alluxio.grpc.CacheRequest
-
optional int64 block_id = 1;
- getBlockId() - Method in interface alluxio.grpc.CacheRequestOrBuilder
-
optional int64 block_id = 1;
- getBlockId() - Method in class alluxio.grpc.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.proto.journal.Block.BlockInfoEntry.Builder
-
optional int64 block_id = 1;
- getBlockId() - Method in class alluxio.proto.journal.Block.BlockInfoEntry
-
optional int64 block_id = 1;
- getBlockId() - Method in interface alluxio.proto.journal.Block.BlockInfoEntryOrBuilder
-
optional int64 block_id = 1;
- getBlockId() - Method in class alluxio.proto.journal.Block.DeleteBlockEntry.Builder
-
optional int64 block_id = 1;
- getBlockId() - Method in class alluxio.proto.journal.Block.DeleteBlockEntry
-
optional int64 block_id = 1;
- getBlockId() - Method in interface alluxio.proto.journal.Block.DeleteBlockEntryOrBuilder
-
optional int64 block_id = 1;
- getBlockId() - Method in class alluxio.wire.BlockInfo
-
- getBlockId() - Method in interface alluxio.worker.block.meta.BlockMeta
-
- getBlockId() - Method in class alluxio.worker.block.meta.DefaultBlockMeta
-
- getBlockId() - Method in class alluxio.worker.block.meta.DefaultTempBlockMeta
-
- getBlockId() - Method in interface alluxio.worker.block.meta.TempBlockMeta
-
- 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.DefaultStorageDir
-
- getBlockIds() - Method in interface alluxio.worker.block.meta.StorageDir
-
Returns the list of block ids in this dir.
- getBlockIdsCount() - Method in class alluxio.grpc.FileInfo.Builder
-
repeated int64 blockIds = 13;
- getBlockIdsCount() - Method in class alluxio.grpc.FileInfo
-
repeated int64 blockIds = 13;
- getBlockIdsCount() - Method in interface alluxio.grpc.FileInfoOrBuilder
-
repeated int64 blockIds = 13;
- getBlockIdsCount() - Method in class alluxio.grpc.PersistFile.Builder
-
repeated int64 blockIds = 2;
- getBlockIdsCount() - Method in class alluxio.grpc.PersistFile
-
repeated int64 blockIds = 2;
- getBlockIdsCount() - Method in interface alluxio.grpc.PersistFileOrBuilder
-
repeated int64 blockIds = 2;
- getBlockIdsCount() - Method in class alluxio.proto.journal.File.CompleteFileEntry.Builder
-
repeated int64 block_ids = 1;
- getBlockIdsCount() - Method in class alluxio.proto.journal.File.CompleteFileEntry
-
repeated int64 block_ids = 1;
- getBlockIdsCount() - Method in interface alluxio.proto.journal.File.CompleteFileEntryOrBuilder
-
repeated int64 block_ids = 1;
- getBlockIdsList() - Method in class alluxio.grpc.FileInfo.Builder
-
repeated int64 blockIds = 13;
- getBlockIdsList() - Method in class alluxio.grpc.FileInfo
-
repeated int64 blockIds = 13;
- getBlockIdsList() - Method in interface alluxio.grpc.FileInfoOrBuilder
-
repeated int64 blockIds = 13;
- getBlockIdsList() - Method in class alluxio.grpc.PersistFile.Builder
-
repeated int64 blockIds = 2;
- getBlockIdsList() - Method in class alluxio.grpc.PersistFile
-
repeated int64 blockIds = 2;
- getBlockIdsList() - Method in interface alluxio.grpc.PersistFileOrBuilder
-
repeated int64 blockIds = 2;
- getBlockIdsList() - Method in class alluxio.proto.journal.File.CompleteFileEntry.Builder
-
repeated int64 block_ids = 1;
- getBlockIdsList() - Method in class alluxio.proto.journal.File.CompleteFileEntry
-
repeated int64 block_ids = 1;
- getBlockIdsList() - Method in interface alluxio.proto.journal.File.CompleteFileEntryOrBuilder
-
repeated int64 block_ids = 1;
- getBlockInfo(long) - Method in interface alluxio.client.block.BlockMasterClient
-
- getBlockInfo() - Method in class alluxio.client.block.policy.options.GetWorkerOptions
-
- getBlockInfo(long) - Method in class alluxio.client.block.RetryHandlingBlockMasterClient
-
- getBlockInfo(long) - Method in class alluxio.client.file.options.InStreamOptions
-
- getBlockInfo(long) - Method in class alluxio.client.file.URIStatus
-
- getBlockInfo(GetBlockInfoPRequest) - 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(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.BlockMetadataManager
-
- getBlockIterator() - Method in class alluxio.worker.block.evictor.AbstractEvictor
-
Deprecated.
Returns an iterator for evictor cache blocks.
- getBlockIterator() - Method in class alluxio.worker.block.evictor.LRUEvictor
-
Deprecated.
- getBlockLength() - Method in class alluxio.util.webui.UIFileBlockInfo
-
Gets block length.
- getBlockList() - Method in interface alluxio.worker.block.BlockStoreMeta
-
Note: This method is only available when users initialize
the blockStoreMeta with full block meta requirement.
- getBlockList() - Method in class alluxio.worker.block.DefaultBlockStoreMeta
-
- getBlockListByStorageLocation() - Method in interface alluxio.worker.block.BlockStoreMeta
-
Note: This method is only available when users initialize
the blockStoreMeta with full block meta requirement.
- getBlockListByStorageLocation() - Method in class alluxio.worker.block.DefaultBlockStoreMeta
-
- getBlockLocation() - Method in interface alluxio.worker.block.meta.BlockMeta
-
- getBlockLocation() - Method in class alluxio.worker.block.meta.DefaultBlockMeta
-
- getBlockLocation() - Method in class alluxio.worker.block.meta.DefaultTempBlockMeta
-
- getBlockLocation() - Method in interface alluxio.worker.block.meta.TempBlockMeta
-
- 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
-
- getBlockLocations(AlluxioURI) - Method in class alluxio.client.file.FileSystemCache.InstanceCachingFileSystem
-
- 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
-
- 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.DefaultStorageDir
-
- getBlockMeta(long) - Method in interface alluxio.worker.block.meta.StorageDir
-
Gets the
BlockMeta
from this storage dir by its block id.
- getBlockMeta(long, long, long) - Method in 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, String) - 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.DefaultStorageDir
-
- getBlocks() - Method in interface 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 interface alluxio.worker.block.meta.BlockMeta
-
- getBlockSize() - Method in class alluxio.worker.block.meta.DefaultBlockMeta
-
- getBlockSize() - Method in class alluxio.worker.block.meta.DefaultTempBlockMeta
-
- getBlockSize() - Method in interface 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.abfs.AbfsUnderFileSystem
-
- getBlockSizeByte(String) - Method in class alluxio.underfs.adl.AdlUnderFileSystem
-
- getBlockSizeByte(String) - Method in class alluxio.underfs.cephfs.CephFSUnderFileSystem
-
- getBlockSizeByte(String) - Method in class alluxio.underfs.hdfs.HdfsUnderFileSystem
-
- getBlockSizeByte(String) - Method in class alluxio.underfs.local.LocalUnderFileSystem
-
- getBlockSizeByte(String) - Method in class alluxio.underfs.ObjectUnderFileSystem
-
Gets the block size in bytes.
- getBlockSizeByte(String) - Method in interface alluxio.underfs.UnderFileSystem
-
- 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.
- 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
-
- 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
-
- getBoolArg(CommandLine, Option, boolean) - Static method in class alluxio.cli.fs.FileSystemShellUtils
-
Gets the value of an option from the command line.
- getBoolean(PropertyKey) - Method in interface alluxio.conf.AlluxioConfiguration
-
Gets the boolean representation of the value for the given key.
- getBoolean(PropertyKey) - 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.
- getBoolean(T) - Method in class alluxio.table.common.BaseConfiguration
-
Return the boolean value of this property.
- getBooleanStats() - Method in class alluxio.grpc.table.ColumnStatisticsData.Builder
-
.alluxio.grpc.table.BooleanColumnStatsData boolean_stats = 1;
- getBooleanStats() - Method in class alluxio.grpc.table.ColumnStatisticsData
-
.alluxio.grpc.table.BooleanColumnStatsData boolean_stats = 1;
- getBooleanStats() - Method in interface alluxio.grpc.table.ColumnStatisticsDataOrBuilder
-
.alluxio.grpc.table.BooleanColumnStatsData boolean_stats = 1;
- getBooleanStatsBuilder() - Method in class alluxio.grpc.table.ColumnStatisticsData.Builder
-
.alluxio.grpc.table.BooleanColumnStatsData boolean_stats = 1;
- getBooleanStatsOrBuilder() - Method in class alluxio.grpc.table.ColumnStatisticsData.Builder
-
.alluxio.grpc.table.BooleanColumnStatsData boolean_stats = 1;
- getBooleanStatsOrBuilder() - Method in class alluxio.grpc.table.ColumnStatisticsData
-
.alluxio.grpc.table.BooleanColumnStatsData boolean_stats = 1;
- getBooleanStatsOrBuilder() - Method in interface alluxio.grpc.table.ColumnStatisticsDataOrBuilder
-
.alluxio.grpc.table.BooleanColumnStatsData boolean_stats = 1;
- getBooleanType() - Method in class alluxio.grpc.table.Value.Builder
-
bool boolean_type = 4;
- getBooleanType() - Method in class alluxio.grpc.table.Value
-
bool boolean_type = 4;
- getBooleanType() - Method in interface alluxio.grpc.table.ValueOrBuilder
-
bool boolean_type = 4;
- getBucket() - Method in class alluxio.proxy.s3.CompleteMultipartUploadResult
-
- getBucket() - Method in class alluxio.proxy.s3.InitiateMultipartUploadResult
-
- getBucket() - Method in class alluxio.proxy.s3.ListPartsResult
-
- getBucket(String, String, String, String, String, String, int) - 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;
- getBuckets() - Method in class alluxio.proxy.s3.ListAllMyBucketsResult
-
- getBuffer() - Method in class alluxio.grpc.DataMessage
-
- getBuffer() - Method in class alluxio.jnifuse.struct.FileStat
-
- getBufferFromStream(InputStream) - Static method in class alluxio.grpc.GrpcSerializationUtils
-
Gets a buffer directly from a gRPC input stream.
- 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
-
- getBypassedTables() - Method in class alluxio.master.table.DbConfig.BypassEntry
-
- getBypassEntry() - Method in class alluxio.master.table.DbConfig
-
- getBypassTableEntries() - Method in class alluxio.master.table.DbConfig.BypassEntry
-
- 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
-
- getCacheable() - Method in class alluxio.grpc.FileInfo.Builder
-
optional bool cacheable = 11;
- getCacheable() - Method in class alluxio.grpc.FileInfo
-
optional bool cacheable = 11;
- getCacheable() - Method in interface alluxio.grpc.FileInfoOrBuilder
-
optional bool cacheable = 11;
- getCacheable() - Method in class alluxio.proto.journal.File.InodeFileEntry.Builder
-
optional bool cacheable = 11;
- getCacheable() - Method in class alluxio.proto.journal.File.InodeFileEntry
-
optional bool cacheable = 11;
- getCacheable() - Method in interface alluxio.proto.journal.File.InodeFileEntryOrBuilder
-
optional bool cacheable = 11;
- getCacheable() - Method in class alluxio.proto.journal.File.UpdateInodeFileEntry.Builder
-
optional bool cacheable = 5;
- getCacheable() - Method in class alluxio.proto.journal.File.UpdateInodeFileEntry
-
optional bool cacheable = 5;
- getCacheable() - Method in interface alluxio.proto.journal.File.UpdateInodeFileEntryOrBuilder
-
optional bool cacheable = 5;
- getCacheContext() - Method in class alluxio.client.file.URIStatus
-
- 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.
- getCacheIdentifier() - Method in class alluxio.client.file.CacheContext
-
Returns an string as a hint from computation to indicate the file.
- getCacheMap() - Method in class alluxio.master.metastore.caching.Cache
-
- getCacheMethod() - Static method in class alluxio.grpc.BlockWorkerGrpc
-
- getCacheMiss() - Method in class alluxio.wire.MasterWebUIMetrics
-
Gets cache miss.
- getCacheQuota() - Method in class alluxio.client.file.CacheContext
-
- getCacheScope() - Method in class alluxio.client.file.CacheContext
-
- getCacheSize() - Method in 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.client.file.cache.TimeBoundPageStore
-
- 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;
- getCancelledTrackers() - Method in class alluxio.master.file.contexts.OperationContext
-
- getCancelMethod() - Static method in class alluxio.grpc.JobMasterClientServiceGrpc
-
- getCancelState() - Method in class alluxio.master.file.PersistJob
-
- getCancelTaskCommand() - Method in class alluxio.grpc.JobCommand.Builder
-
optional .alluxio.grpc.job.CancelTaskCommand cancelTaskCommand = 2;
- getCancelTaskCommand() - Method in class alluxio.grpc.JobCommand
-
optional .alluxio.grpc.job.CancelTaskCommand cancelTaskCommand = 2;
- getCancelTaskCommand() - Method in interface alluxio.grpc.JobCommandOrBuilder
-
optional .alluxio.grpc.job.CancelTaskCommand cancelTaskCommand = 2;
- getCancelTaskCommandBuilder() - Method in class alluxio.grpc.JobCommand.Builder
-
optional .alluxio.grpc.job.CancelTaskCommand cancelTaskCommand = 2;
- getCancelTaskCommandOrBuilder() - Method in class alluxio.grpc.JobCommand.Builder
-
optional .alluxio.grpc.job.CancelTaskCommand cancelTaskCommand = 2;
- getCancelTaskCommandOrBuilder() - Method in class alluxio.grpc.JobCommand
-
optional .alluxio.grpc.job.CancelTaskCommand cancelTaskCommand = 2;
- getCancelTaskCommandOrBuilder() - Method in interface alluxio.grpc.JobCommandOrBuilder
-
optional .alluxio.grpc.job.CancelTaskCommand cancelTaskCommand = 2;
- getCandidates(int) - Method in class alluxio.grpc.table.EquatableValueSet.Builder
-
repeated .alluxio.grpc.table.Value candidates = 1;
- getCandidates(int) - Method in class alluxio.grpc.table.EquatableValueSet
-
repeated .alluxio.grpc.table.Value candidates = 1;
- getCandidates(int) - Method in interface alluxio.grpc.table.EquatableValueSetOrBuilder
-
repeated .alluxio.grpc.table.Value candidates = 1;
- getCandidatesBuilder(int) - Method in class alluxio.grpc.table.EquatableValueSet.Builder
-
repeated .alluxio.grpc.table.Value candidates = 1;
- getCandidatesBuilderList() - Method in class alluxio.grpc.table.EquatableValueSet.Builder
-
repeated .alluxio.grpc.table.Value candidates = 1;
- getCandidatesCount() - Method in class alluxio.grpc.table.EquatableValueSet.Builder
-
repeated .alluxio.grpc.table.Value candidates = 1;
- getCandidatesCount() - Method in class alluxio.grpc.table.EquatableValueSet
-
repeated .alluxio.grpc.table.Value candidates = 1;
- getCandidatesCount() - Method in interface alluxio.grpc.table.EquatableValueSetOrBuilder
-
repeated .alluxio.grpc.table.Value candidates = 1;
- getCandidatesList() - Method in class alluxio.grpc.table.EquatableValueSet.Builder
-
repeated .alluxio.grpc.table.Value candidates = 1;
- getCandidatesList() - Method in class alluxio.grpc.table.EquatableValueSet
-
repeated .alluxio.grpc.table.Value candidates = 1;
- getCandidatesList() - Method in interface alluxio.grpc.table.EquatableValueSetOrBuilder
-
repeated .alluxio.grpc.table.Value candidates = 1;
- getCandidatesOrBuilder(int) - Method in class alluxio.grpc.table.EquatableValueSet.Builder
-
repeated .alluxio.grpc.table.Value candidates = 1;
- getCandidatesOrBuilder(int) - Method in class alluxio.grpc.table.EquatableValueSet
-
repeated .alluxio.grpc.table.Value candidates = 1;
- getCandidatesOrBuilder(int) - Method in interface alluxio.grpc.table.EquatableValueSetOrBuilder
-
repeated .alluxio.grpc.table.Value candidates = 1;
- getCandidatesOrBuilderList() - Method in class alluxio.grpc.table.EquatableValueSet.Builder
-
repeated .alluxio.grpc.table.Value candidates = 1;
- getCandidatesOrBuilderList() - Method in class alluxio.grpc.table.EquatableValueSet
-
repeated .alluxio.grpc.table.Value candidates = 1;
- getCandidatesOrBuilderList() - Method in interface alluxio.grpc.table.EquatableValueSetOrBuilder
-
repeated .alluxio.grpc.table.Value candidates = 1;
- 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.util.webui.UIStorageDir
-
Gets capacity bytes.
- getCapacityBytes() - Method in class alluxio.util.webui.UIUsageOnTier
-
Gets capacity bytes.
- getCapacityBytes() - Method in class alluxio.wire.BlockMasterInfo
-
- getCapacityBytes() - Method in class alluxio.wire.WorkerInfo
-
- getCapacityBytes() - Method in class alluxio.wire.WorkerWebUIOverview
-
Gets capacity bytes.
- getCapacityBytes() - Method in interface alluxio.worker.block.BlockStoreMeta
-
- getCapacityBytes() - Method in class alluxio.worker.block.DefaultBlockStoreMeta
-
- getCapacityBytes() - Method in class alluxio.worker.block.meta.DefaultStorageDir
-
- getCapacityBytes() - Method in class alluxio.worker.block.meta.DefaultStorageTier
-
- getCapacityBytes() - Method in interface alluxio.worker.block.meta.StorageDir
-
Gets the total capacity of this
StorageDir
in bytes, which is a constant once this
StorageDir
has been initialized.
- getCapacityBytes() - Method in class alluxio.worker.block.meta.StorageDirView
-
Gets capacity bytes for this dir.
- getCapacityBytes() - Method in interface alluxio.worker.block.meta.StorageTier
-
- GetCapacityBytesCommand - Class in alluxio.cli.fs.command
-
- 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.wire.BlockMasterInfo
-
- getCapacityBytesOnTiers() - Method in class alluxio.wire.WorkerInfo
-
- 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
-
- getCatchupState() - Method in class alluxio.master.journal.ufs.UfsJournal
-
- getCatchupState() - Method in class alluxio.master.journal.ufs.UfsJournalCheckpointThread
-
- getChangedFiles(AlluxioURI) - Method in class alluxio.SyncInfo
-
REturns a set of changed files.
- getChannel() - Method in class alluxio.grpc.GrpcConnection
-
- getChannel() - Method in class alluxio.worker.block.io.BlockReader
-
Returns a readable byte channel of the block.
- getChannel() - Method in class alluxio.worker.block.io.BlockWriter
-
- getChannel() - Method in class alluxio.worker.block.io.DelegatingBlockReader
-
- getChannel() - Method in class alluxio.worker.block.io.LocalFileBlockReader
-
- getChannel() - Method in class alluxio.worker.block.io.LocalFileBlockWriter
-
- 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.
- getCheckAccessMethod() - Static method in class alluxio.grpc.FileSystemMasterClientServiceGrpc
-
- 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
-
- 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
-
- getChildren(AlluxioURI) - Method in class alluxio.underfs.UfsStatusCache
-
- 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.SnapshotData.Builder
-
optional bytes chunk = 3;
- getChunk() - Method in class alluxio.grpc.SnapshotData
-
optional bytes chunk = 3;
- getChunk() - Method in interface alluxio.grpc.SnapshotDataOrBuilder
-
optional bytes chunk = 3;
- getChunk() - Method in class alluxio.grpc.WriteRequest.Builder
-
.alluxio.grpc.block.Chunk chunk = 2;
- getChunk() - Method in class alluxio.grpc.WriteRequest
-
.alluxio.grpc.block.Chunk chunk = 2;
- getChunk() - Method in interface alluxio.grpc.WriteRequestOrBuilder
-
.alluxio.grpc.block.Chunk chunk = 2;
- getChunkBuilder() - Method in class alluxio.grpc.ReadResponse.Builder
-
optional .alluxio.grpc.block.Chunk chunk = 1;
- getChunkBuilder() - Method in class alluxio.grpc.WriteRequest.Builder
-
.alluxio.grpc.block.Chunk chunk = 2;
- getChunkOrBuilder() - Method in class alluxio.grpc.ReadResponse.Builder
-
optional .alluxio.grpc.block.Chunk chunk = 1;
- getChunkOrBuilder() - Method in class alluxio.grpc.ReadResponse
-
optional .alluxio.grpc.block.Chunk chunk = 1;
- getChunkOrBuilder() - Method in interface alluxio.grpc.ReadResponseOrBuilder
-
optional .alluxio.grpc.block.Chunk chunk = 1;
- getChunkOrBuilder() - Method in class alluxio.grpc.WriteRequest.Builder
-
.alluxio.grpc.block.Chunk chunk = 2;
- getChunkOrBuilder() - Method in class alluxio.grpc.WriteRequest
-
.alluxio.grpc.block.Chunk chunk = 2;
- getChunkOrBuilder() - Method in interface alluxio.grpc.WriteRequestOrBuilder
-
.alluxio.grpc.block.Chunk chunk = 2;
- getChunkSize() - Method in class alluxio.grpc.ReadRequest.Builder
-
optional int64 chunk_size = 5;
- getChunkSize() - Method in class alluxio.grpc.ReadRequest
-
optional int64 chunk_size = 5;
- getChunkSize() - Method in interface alluxio.grpc.ReadRequestOrBuilder
-
optional int64 chunk_size = 5;
- getChunkSize() - Method in class alluxio.wire.BlockReadRequest
-
- 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
-
- getClassName() - Method in class alluxio.stress.job.StressBenchConfig
-
- getClassName() - Method in interface alluxio.util.JsonSerializable
-
- 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
-
- getClient(FileSystemContext) - Method in class alluxio.master.AbstractLocalAlluxioCluster
-
- getClient() - Method in class alluxio.master.ClientPool
-
- 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.
- getClient() - Method in class alluxio.table.under.glue.GlueDatabase
-
Get Glue 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
-
- getClientSslContext() - Method in class alluxio.util.network.tls.DefaultSslContextProvider
-
- getClientSslContext() - Method in interface alluxio.util.network.tls.SslContextProvider
-
- getClientUser(AlluxioConfiguration) - Static method in class alluxio.security.authentication.AuthenticatedClientUser
-
- 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;
- getClusterId() - Method in class alluxio.wire.MasterWebUIOverview
-
Gets cluster id.
- getClusterIdBytes() - Method in class alluxio.proto.journal.Meta.ClusterInfoEntry.Builder
-
optional string cluster_id = 1;
- getClusterIdBytes() - Method in class alluxio.proto.journal.Meta.ClusterInfoEntry
-
optional string cluster_id = 1;
- getClusterIdBytes() - Method in interface alluxio.proto.journal.Meta.ClusterInfoEntryOrBuilder
-
optional string cluster_id = 1;
- getClusterInfo() - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
-
optional .alluxio.proto.journal.ClusterInfoEntry cluster_info = 42;
- getClusterInfo() - Method in class alluxio.proto.journal.Journal.JournalEntry
-
optional .alluxio.proto.journal.ClusterInfoEntry cluster_info = 42;
- getClusterInfo() - Method in interface alluxio.proto.journal.Journal.JournalEntryOrBuilder
-
optional .alluxio.proto.journal.ClusterInfoEntry cluster_info = 42;
- getClusterInfoBuilder() - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
-
optional .alluxio.proto.journal.ClusterInfoEntry cluster_info = 42;
- getClusterInfoOrBuilder() - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
-
optional .alluxio.proto.journal.ClusterInfoEntry cluster_info = 42;
- getClusterInfoOrBuilder() - Method in class alluxio.proto.journal.Journal.JournalEntry
-
optional .alluxio.proto.journal.ClusterInfoEntry cluster_info = 42;
- getClusterInfoOrBuilder() - Method in interface alluxio.proto.journal.Journal.JournalEntryOrBuilder
-
optional .alluxio.proto.journal.ClusterInfoEntry cluster_info = 42;
- getClusterLimit() - Method in class alluxio.stress.job.StressBenchConfig
-
- getCmd() - Method in class alluxio.shell.CommandReturn
-
Gets the command run.
- 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.orc.OrcRow
-
- 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
-
- 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
-
.alluxio.grpc.block.WriteRequestCommand command = 1;
- getCommand() - Method in class alluxio.grpc.WriteRequest
-
.alluxio.grpc.block.WriteRequestCommand command = 1;
- getCommand() - Method in interface alluxio.grpc.WriteRequestOrBuilder
-
.alluxio.grpc.block.WriteRequestCommand command = 1;
- getCommand() - Method in class alluxio.shell.ShellCommand
-
Gets the command.
- getCommandBuilder() - Method in class alluxio.grpc.BlockHeartbeatPResponse.Builder
-
optional .alluxio.grpc.Command command = 1;
- getCommandBuilder() - Method in class alluxio.grpc.FileSystemHeartbeatPResponse.Builder
-
optional .alluxio.grpc.file.FileSystemCommand command = 1;
- getCommandBuilder() - Method in class alluxio.grpc.WriteRequest.Builder
-
.alluxio.grpc.block.WriteRequestCommand command = 1;
- getCommandName() - Method in class alluxio.cli.bundler.command.CollectAlluxioInfoCommand
-
- getCommandName() - Method in class alluxio.cli.bundler.command.CollectConfigCommand
-
- getCommandName() - Method in class alluxio.cli.bundler.command.CollectEnvCommand
-
- getCommandName() - Method in class alluxio.cli.bundler.command.CollectJvmInfoCommand
-
- getCommandName() - Method in class alluxio.cli.bundler.command.CollectLogCommand
-
- getCommandName() - Method in class alluxio.cli.bundler.command.CollectMetricsCommand
-
- getCommandName() - Method in interface alluxio.cli.Command
-
Gets the command name as input from the shell.
- getCommandName() - Method in class alluxio.cli.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
-
Deprecated.
- getCommandName() - Method in class alluxio.cli.fs.command.LoadCommand
-
- getCommandName() - Method in class alluxio.cli.fs.command.LoadMetadataCommand
-
- 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.StateLockHoldersCommand
-
- getCommandName() - Method in class alluxio.cli.fsadmin.command.UfsCommand
-
- getCommandName() - Method in class alluxio.cli.fsadmin.command.UpdateConfCommand
-
- getCommandName() - Method in class alluxio.cli.fsadmin.journal.CheckpointCommand
-
- getCommandName() - Method in class alluxio.cli.fsadmin.journal.QuorumCommand
-
- getCommandName() - Method in class alluxio.cli.fsadmin.journal.QuorumElectCommand
-
- getCommandName() - Method in class alluxio.cli.fsadmin.journal.QuorumInfoCommand
-
- getCommandName() - Method in class alluxio.cli.fsadmin.journal.QuorumRemoveCommand
-
- getCommandName() - Method in class alluxio.cli.fsadmin.metrics.ClearCommand
-
- getCommandName() - Method in class alluxio.cli.fsadmin.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
-
.alluxio.grpc.block.WriteRequestCommand command = 1;
- getCommandOrBuilder() - Method in class alluxio.grpc.WriteRequest
-
.alluxio.grpc.block.WriteRequestCommand command = 1;
- getCommandOrBuilder() - Method in interface alluxio.grpc.WriteRequestOrBuilder
-
.alluxio.grpc.block.WriteRequestCommand command = 1;
- getCommands() - Method in class alluxio.cli.AbstractShell
-
- getCommands(int) - Method in class alluxio.grpc.JobHeartbeatPResponse.Builder
-
repeated .alluxio.grpc.job.JobCommand commands = 1;
- getCommands(int) - Method in class alluxio.grpc.JobHeartbeatPResponse
-
repeated .alluxio.grpc.job.JobCommand commands = 1;
- getCommands(int) - Method in interface alluxio.grpc.JobHeartbeatPResponseOrBuilder
-
repeated .alluxio.grpc.job.JobCommand commands = 1;
- getCommandsBuilder(int) - Method in class alluxio.grpc.JobHeartbeatPResponse.Builder
-
repeated .alluxio.grpc.job.JobCommand commands = 1;
- getCommandsBuilderList() - Method in class alluxio.grpc.JobHeartbeatPResponse.Builder
-
repeated .alluxio.grpc.job.JobCommand commands = 1;
- getCommandsCount() - Method in class alluxio.grpc.JobHeartbeatPResponse.Builder
-
repeated .alluxio.grpc.job.JobCommand commands = 1;
- getCommandsCount() - Method in class alluxio.grpc.JobHeartbeatPResponse
-
repeated .alluxio.grpc.job.JobCommand commands = 1;
- getCommandsCount() - Method in interface alluxio.grpc.JobHeartbeatPResponseOrBuilder
-
repeated .alluxio.grpc.job.JobCommand commands = 1;
- getCommandsList() - Method in class alluxio.grpc.JobHeartbeatPResponse.Builder
-
repeated .alluxio.grpc.job.JobCommand commands = 1;
- getCommandsList() - Method in class alluxio.grpc.JobHeartbeatPResponse
-
repeated .alluxio.grpc.job.JobCommand commands = 1;
- getCommandsList() - Method in interface alluxio.grpc.JobHeartbeatPResponseOrBuilder
-
repeated .alluxio.grpc.job.JobCommand commands = 1;
- getCommandsOrBuilder(int) - Method in class alluxio.grpc.JobHeartbeatPResponse.Builder
-
repeated .alluxio.grpc.job.JobCommand commands = 1;
- getCommandsOrBuilder(int) - Method in class alluxio.grpc.JobHeartbeatPResponse
-
repeated .alluxio.grpc.job.JobCommand commands = 1;
- getCommandsOrBuilder(int) - Method in interface alluxio.grpc.JobHeartbeatPResponseOrBuilder
-
repeated .alluxio.grpc.job.JobCommand commands = 1;
- getCommandsOrBuilderList() - Method in class alluxio.grpc.JobHeartbeatPResponse.Builder
-
repeated .alluxio.grpc.job.JobCommand commands = 1;
- getCommandsOrBuilderList() - Method in class alluxio.grpc.JobHeartbeatPResponse
-
repeated .alluxio.grpc.job.JobCommand commands = 1;
- getCommandsOrBuilderList() - Method in interface alluxio.grpc.JobHeartbeatPResponseOrBuilder
-
repeated .alluxio.grpc.job.JobCommand commands = 1;
- getCommandType() - Method in class alluxio.grpc.Command.Builder
-
optional .alluxio.grpc.CommandType commandType = 1;
- getCommandType() - Method in class alluxio.grpc.Command
-
optional .alluxio.grpc.CommandType commandType = 1;
- getCommandType() - Method in interface alluxio.grpc.CommandOrBuilder
-
optional .alluxio.grpc.CommandType commandType = 1;
- getCommandType() - Method in class alluxio.grpc.FileSystemCommand.Builder
-
optional .alluxio.grpc.CommandType commandType = 1;
- getCommandType() - Method in class alluxio.grpc.FileSystemCommand
-
optional .alluxio.grpc.CommandType commandType = 1;
- getCommandType() - Method in interface alluxio.grpc.FileSystemCommandOrBuilder
-
optional .alluxio.grpc.CommandType commandType = 1;
- getCommandType() - Method in class alluxio.wire.FileSystemCommand
-
- getComment() - Method in class alluxio.grpc.table.Database.Builder
-
optional string comment = 7;
- getComment() - Method in class alluxio.grpc.table.Database
-
optional string comment = 7;
- getComment() - Method in interface alluxio.grpc.table.DatabaseOrBuilder
-
optional string comment = 7;
- getComment() - Method in class alluxio.grpc.table.FieldSchema.Builder
-
optional string comment = 4;
- getComment() - Method in class alluxio.grpc.table.FieldSchema
-
optional string comment = 4;
- getComment() - Method in interface alluxio.grpc.table.FieldSchemaOrBuilder
-
optional string comment = 4;
- 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.DefaultTempBlockMeta
-
- getCommitPath() - Method in interface alluxio.worker.block.meta.TempBlockMeta
-
- getCommittedBytes() - Method in class alluxio.worker.block.meta.DefaultStorageDir
-
- getCommittedBytes() - Method in interface 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.CheckAccessPOptions.Builder
-
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 2;
- getCommonOptions() - Method in class alluxio.grpc.CheckAccessPOptions
-
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 2;
- getCommonOptions() - Method in interface alluxio.grpc.CheckAccessPOptionsOrBuilder
-
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 2;
- getCommonOptions() - Method in class alluxio.grpc.CheckConsistencyPOptions.Builder
-
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 1;
- getCommonOptions() - Method in class alluxio.grpc.CheckConsistencyPOptions
-
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 1;
- getCommonOptions() - Method in interface alluxio.grpc.CheckConsistencyPOptionsOrBuilder
-
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 1;
- getCommonOptions() - Method in class alluxio.grpc.CompleteFilePOptions.Builder
-
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 3;
- getCommonOptions() - Method in class alluxio.grpc.CompleteFilePOptions
-
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 3;
- getCommonOptions() - Method in interface alluxio.grpc.CompleteFilePOptionsOrBuilder
-
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 3;
- getCommonOptions() - Method in class alluxio.grpc.CreateDirectoryPOptions.Builder
-
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 5;
- getCommonOptions() - Method in class alluxio.grpc.CreateDirectoryPOptions
-
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 5;
- getCommonOptions() - Method in interface alluxio.grpc.CreateDirectoryPOptionsOrBuilder
-
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 5;
- getCommonOptions() - Method in class alluxio.grpc.CreateFilePOptions.Builder
-
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 9;
- getCommonOptions() - Method in class alluxio.grpc.CreateFilePOptions
-
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 9;
- getCommonOptions() - Method in interface alluxio.grpc.CreateFilePOptionsOrBuilder
-
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 9;
- getCommonOptions() - Method in class alluxio.grpc.DeletePOptions.Builder
-
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 4;
- getCommonOptions() - Method in class alluxio.grpc.DeletePOptions
-
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 4;
- getCommonOptions() - Method in interface alluxio.grpc.DeletePOptionsOrBuilder
-
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 4;
- getCommonOptions() - Method in class alluxio.grpc.ExistsPOptions.Builder
-
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 2;
- getCommonOptions() - Method in class alluxio.grpc.ExistsPOptions
-
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 2;
- getCommonOptions() - Method in interface alluxio.grpc.ExistsPOptionsOrBuilder
-
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 2;
- getCommonOptions() - Method in class alluxio.grpc.FreePOptions.Builder
-
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 3;
- getCommonOptions() - Method in class alluxio.grpc.FreePOptions
-
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 3;
- getCommonOptions() - Method in interface alluxio.grpc.FreePOptionsOrBuilder
-
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 3;
- getCommonOptions() - Method in class alluxio.grpc.GetNewBlockIdForFilePOptions.Builder
-
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 1;
- getCommonOptions() - Method in class alluxio.grpc.GetNewBlockIdForFilePOptions
-
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 1;
- getCommonOptions() - Method in interface alluxio.grpc.GetNewBlockIdForFilePOptionsOrBuilder
-
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 1;
- getCommonOptions() - Method in class alluxio.grpc.GetStatusPOptions.Builder
-
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 2;
- getCommonOptions() - Method in class alluxio.grpc.GetStatusPOptions
-
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 2;
- getCommonOptions() - Method in interface alluxio.grpc.GetStatusPOptionsOrBuilder
-
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 2;
- getCommonOptions() - Method in class alluxio.grpc.ListStatusPOptions.Builder
-
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 3;
- getCommonOptions() - Method in class alluxio.grpc.ListStatusPOptions
-
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 3;
- getCommonOptions() - Method in interface alluxio.grpc.ListStatusPOptionsOrBuilder
-
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 3;
- getCommonOptions() - Method in class alluxio.grpc.LoadMetadataPOptions.Builder
-
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 4;
- getCommonOptions() - Method in class alluxio.grpc.LoadMetadataPOptions
-
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 4;
- getCommonOptions() - Method in interface alluxio.grpc.LoadMetadataPOptionsOrBuilder
-
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 4;
- getCommonOptions() - Method in class alluxio.grpc.MountPOptions.Builder
-
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 4;
- getCommonOptions() - Method in class alluxio.grpc.MountPOptions
-
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 4;
- getCommonOptions() - Method in interface alluxio.grpc.MountPOptionsOrBuilder
-
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 4;
- getCommonOptions() - Method in class alluxio.grpc.OpenFilePOptions.Builder
-
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 3;
- getCommonOptions() - Method in class alluxio.grpc.OpenFilePOptions
-
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 3;
- getCommonOptions() - Method in interface alluxio.grpc.OpenFilePOptionsOrBuilder
-
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 3;
- getCommonOptions() - Method in class alluxio.grpc.RenamePOptions.Builder
-
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 1;
- getCommonOptions() - Method in class alluxio.grpc.RenamePOptions
-
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 1;
- getCommonOptions() - Method in interface alluxio.grpc.RenamePOptionsOrBuilder
-
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 1;
- getCommonOptions() - Method in class alluxio.grpc.ScheduleAsyncPersistencePOptions.Builder
-
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 1;
- getCommonOptions() - Method in class alluxio.grpc.ScheduleAsyncPersistencePOptions
-
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 1;
- getCommonOptions() - Method in interface alluxio.grpc.ScheduleAsyncPersistencePOptionsOrBuilder
-
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 1;
- getCommonOptions() - Method in class alluxio.grpc.SetAclPOptions.Builder
-
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 1;
- getCommonOptions() - Method in class alluxio.grpc.SetAclPOptions
-
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 1;
- getCommonOptions() - Method in interface alluxio.grpc.SetAclPOptionsOrBuilder
-
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 1;
- getCommonOptions() - Method in class alluxio.grpc.SetAttributePOptions.Builder
-
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 9;
- getCommonOptions() - Method in class alluxio.grpc.SetAttributePOptions
-
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 9;
- getCommonOptions() - Method in interface alluxio.grpc.SetAttributePOptionsOrBuilder
-
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 9;
- getCommonOptions() - Method in class alluxio.grpc.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.CheckAccessPOptions.Builder
-
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 2;
- getCommonOptionsBuilder() - Method in class alluxio.grpc.CheckConsistencyPOptions.Builder
-
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 1;
- getCommonOptionsBuilder() - Method in class alluxio.grpc.CompleteFilePOptions.Builder
-
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 3;
- getCommonOptionsBuilder() - Method in class alluxio.grpc.CreateDirectoryPOptions.Builder
-
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 5;
- getCommonOptionsBuilder() - Method in class alluxio.grpc.CreateFilePOptions.Builder
-
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 9;
- getCommonOptionsBuilder() - Method in class alluxio.grpc.DeletePOptions.Builder
-
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 4;
- getCommonOptionsBuilder() - Method in class alluxio.grpc.ExistsPOptions.Builder
-
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 2;
- getCommonOptionsBuilder() - Method in class alluxio.grpc.FreePOptions.Builder
-
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 3;
- getCommonOptionsBuilder() - Method in class alluxio.grpc.GetNewBlockIdForFilePOptions.Builder
-
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 1;
- getCommonOptionsBuilder() - Method in class alluxio.grpc.GetStatusPOptions.Builder
-
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 2;
- getCommonOptionsBuilder() - Method in class alluxio.grpc.ListStatusPOptions.Builder
-
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 3;
- getCommonOptionsBuilder() - Method in class alluxio.grpc.LoadMetadataPOptions.Builder
-
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 4;
- getCommonOptionsBuilder() - Method in class alluxio.grpc.MountPOptions.Builder
-
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 4;
- getCommonOptionsBuilder() - Method in class alluxio.grpc.OpenFilePOptions.Builder
-
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 3;
- getCommonOptionsBuilder() - Method in class alluxio.grpc.RenamePOptions.Builder
-
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 1;
- getCommonOptionsBuilder() - Method in class alluxio.grpc.ScheduleAsyncPersistencePOptions.Builder
-
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 1;
- getCommonOptionsBuilder() - Method in class alluxio.grpc.SetAclPOptions.Builder
-
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 1;
- getCommonOptionsBuilder() - Method in class alluxio.grpc.SetAttributePOptions.Builder
-
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 9;
- getCommonOptionsBuilder() - Method in class alluxio.grpc.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.CheckAccessPOptions.Builder
-
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 2;
- getCommonOptionsOrBuilder() - Method in class alluxio.grpc.CheckAccessPOptions
-
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 2;
- getCommonOptionsOrBuilder() - Method in interface alluxio.grpc.CheckAccessPOptionsOrBuilder
-
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 2;
- getCommonOptionsOrBuilder() - Method in class alluxio.grpc.CheckConsistencyPOptions.Builder
-
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 1;
- getCommonOptionsOrBuilder() - Method in class alluxio.grpc.CheckConsistencyPOptions
-
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 1;
- getCommonOptionsOrBuilder() - Method in interface alluxio.grpc.CheckConsistencyPOptionsOrBuilder
-
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 1;
- getCommonOptionsOrBuilder() - Method in class alluxio.grpc.CompleteFilePOptions.Builder
-
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 3;
- getCommonOptionsOrBuilder() - Method in class alluxio.grpc.CompleteFilePOptions
-
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 3;
- getCommonOptionsOrBuilder() - Method in interface alluxio.grpc.CompleteFilePOptionsOrBuilder
-
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 3;
- getCommonOptionsOrBuilder() - Method in class alluxio.grpc.CreateDirectoryPOptions.Builder
-
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 5;
- getCommonOptionsOrBuilder() - Method in class alluxio.grpc.CreateDirectoryPOptions
-
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 5;
- getCommonOptionsOrBuilder() - Method in interface alluxio.grpc.CreateDirectoryPOptionsOrBuilder
-
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 5;
- getCommonOptionsOrBuilder() - Method in class alluxio.grpc.CreateFilePOptions.Builder
-
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 9;
- getCommonOptionsOrBuilder() - Method in class alluxio.grpc.CreateFilePOptions
-
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 9;
- getCommonOptionsOrBuilder() - Method in interface alluxio.grpc.CreateFilePOptionsOrBuilder
-
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 9;
- getCommonOptionsOrBuilder() - Method in class alluxio.grpc.DeletePOptions.Builder
-
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 4;
- getCommonOptionsOrBuilder() - Method in class alluxio.grpc.DeletePOptions
-
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 4;
- getCommonOptionsOrBuilder() - Method in interface alluxio.grpc.DeletePOptionsOrBuilder
-
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 4;
- getCommonOptionsOrBuilder() - Method in class alluxio.grpc.ExistsPOptions.Builder
-
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 2;
- getCommonOptionsOrBuilder() - Method in class alluxio.grpc.ExistsPOptions
-
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 2;
- getCommonOptionsOrBuilder() - Method in interface alluxio.grpc.ExistsPOptionsOrBuilder
-
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 2;
- getCommonOptionsOrBuilder() - Method in class alluxio.grpc.FreePOptions.Builder
-
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 3;
- getCommonOptionsOrBuilder() - Method in class alluxio.grpc.FreePOptions
-
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 3;
- getCommonOptionsOrBuilder() - Method in interface alluxio.grpc.FreePOptionsOrBuilder
-
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 3;
- getCommonOptionsOrBuilder() - Method in class alluxio.grpc.GetNewBlockIdForFilePOptions.Builder
-
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 1;
- getCommonOptionsOrBuilder() - Method in class alluxio.grpc.GetNewBlockIdForFilePOptions
-
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 1;
- getCommonOptionsOrBuilder() - Method in interface alluxio.grpc.GetNewBlockIdForFilePOptionsOrBuilder
-
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 1;
- getCommonOptionsOrBuilder() - Method in class alluxio.grpc.GetStatusPOptions.Builder
-
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 2;
- getCommonOptionsOrBuilder() - Method in class alluxio.grpc.GetStatusPOptions
-
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 2;
- getCommonOptionsOrBuilder() - Method in interface alluxio.grpc.GetStatusPOptionsOrBuilder
-
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 2;
- getCommonOptionsOrBuilder() - Method in class alluxio.grpc.ListStatusPOptions.Builder
-
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 3;
- getCommonOptionsOrBuilder() - Method in class alluxio.grpc.ListStatusPOptions
-
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 3;
- getCommonOptionsOrBuilder() - Method in interface alluxio.grpc.ListStatusPOptionsOrBuilder
-
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 3;
- getCommonOptionsOrBuilder() - Method in class alluxio.grpc.LoadMetadataPOptions.Builder
-
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 4;
- getCommonOptionsOrBuilder() - Method in class alluxio.grpc.LoadMetadataPOptions
-
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 4;
- getCommonOptionsOrBuilder() - Method in interface alluxio.grpc.LoadMetadataPOptionsOrBuilder
-
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 4;
- getCommonOptionsOrBuilder() - Method in class alluxio.grpc.MountPOptions.Builder
-
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 4;
- getCommonOptionsOrBuilder() - Method in class alluxio.grpc.MountPOptions
-
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 4;
- getCommonOptionsOrBuilder() - Method in interface alluxio.grpc.MountPOptionsOrBuilder
-
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 4;
- getCommonOptionsOrBuilder() - Method in class alluxio.grpc.OpenFilePOptions.Builder
-
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 3;
- getCommonOptionsOrBuilder() - Method in class alluxio.grpc.OpenFilePOptions
-
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 3;
- getCommonOptionsOrBuilder() - Method in interface alluxio.grpc.OpenFilePOptionsOrBuilder
-
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 3;
- getCommonOptionsOrBuilder() - Method in class alluxio.grpc.RenamePOptions.Builder
-
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 1;
- getCommonOptionsOrBuilder() - Method in class alluxio.grpc.RenamePOptions
-
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 1;
- getCommonOptionsOrBuilder() - Method in interface alluxio.grpc.RenamePOptionsOrBuilder
-
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 1;
- getCommonOptionsOrBuilder() - Method in class alluxio.grpc.ScheduleAsyncPersistencePOptions.Builder
-
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 1;
- getCommonOptionsOrBuilder() - Method in class alluxio.grpc.ScheduleAsyncPersistencePOptions
-
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 1;
- getCommonOptionsOrBuilder() - Method in interface alluxio.grpc.ScheduleAsyncPersistencePOptionsOrBuilder
-
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 1;
- getCommonOptionsOrBuilder() - Method in class alluxio.grpc.SetAclPOptions.Builder
-
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 1;
- getCommonOptionsOrBuilder() - Method in class alluxio.grpc.SetAclPOptions
-
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 1;
- getCommonOptionsOrBuilder() - Method in interface alluxio.grpc.SetAclPOptionsOrBuilder
-
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 1;
- getCommonOptionsOrBuilder() - Method in class alluxio.grpc.SetAttributePOptions.Builder
-
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 9;
- getCommonOptionsOrBuilder() - Method in class alluxio.grpc.SetAttributePOptions
-
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 9;
- getCommonOptionsOrBuilder() - Method in interface alluxio.grpc.SetAttributePOptionsOrBuilder
-
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 9;
- getCommonOptionsOrBuilder() - Method in class alluxio.grpc.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 class alluxio.proxy.s3.ListBucketResult.CommonPrefixes
-
- getCommonPrefixes() - Method in class alluxio.proxy.s3.ListBucketResult
-
- 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;
- getCompletedCount() - Method in class alluxio.cli.fs.command.AbstractDistributedJobCommand
-
Gets the number of completed jobs.
- getCompletedLocation() - Method in class alluxio.master.journalv0.ufs.UfsJournal
-
- getCompletedLog(long) - Method in class alluxio.master.journalv0.ufs.UfsJournal
-
- getCompleteFile() - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
-
optional .alluxio.proto.journal.CompleteFileEntry complete_file = 5;
- getCompleteFile() - Method in class alluxio.proto.journal.Journal.JournalEntry
-
optional .alluxio.proto.journal.CompleteFileEntry complete_file = 5;
- getCompleteFile() - Method in interface alluxio.proto.journal.Journal.JournalEntryOrBuilder
-
optional .alluxio.proto.journal.CompleteFileEntry complete_file = 5;
- getCompleteFileBuilder() - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
-
optional .alluxio.proto.journal.CompleteFileEntry complete_file = 5;
- getCompleteFileMethod() - Static method in class alluxio.grpc.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.multi.process.Master
-
- getConfAddress() - Method in class alluxio.AbstractClient
-
- getConfAddress() - Method in class alluxio.AbstractJobMasterClient
-
- 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.
- getConfigCheckWarnNum() - Method in class alluxio.wire.MasterWebUIOverview
-
Gets config check warn num.
- 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() - Method in class alluxio.concurrent.ManagedBlockingUfsForwarder
-
- 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(GetConfigurationPOptions) - Method in class alluxio.master.meta.DefaultMetaMaster
-
- getConfiguration(GetConfigurationPOptions) - Method in interface alluxio.master.meta.MetaMaster
-
- getConfiguration(GetConfigurationPOptions, StreamObserver<GetConfigurationPResponse>) - Method in class alluxio.master.meta.MetaMasterConfigurationServiceHandler
-
- getConfiguration() - Method in class alluxio.underfs.BaseUnderFileSystem
-
- getConfiguration() - Method in interface alluxio.underfs.UnderFileSystem
-
Gets the under file system configuration.
- getConfiguration() - Method in class alluxio.underfs.UnderFileSystemWithLogging
-
- getConfiguration(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.
- 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;
- getContainerHost() - Method in class alluxio.grpc.WorkerNetAddress.Builder
-
optional string containerHost = 7;
- getContainerHost() - Method in class alluxio.grpc.WorkerNetAddress
-
optional string containerHost = 7;
- getContainerHost() - Method in interface alluxio.grpc.WorkerNetAddressOrBuilder
-
optional string containerHost = 7;
- getContainerHost() - Method in class alluxio.wire.WorkerNetAddress
-
- getContainerHostBytes() - Method in class alluxio.grpc.WorkerNetAddress.Builder
-
optional string containerHost = 7;
- getContainerHostBytes() - Method in class alluxio.grpc.WorkerNetAddress
-
optional string containerHost = 7;
- getContainerHostBytes() - Method in interface alluxio.grpc.WorkerNetAddressOrBuilder
-
optional string containerHost = 7;
- getContainerId(long) - Static method in class alluxio.master.block.BlockId
-
- getContainerId() - Method in class alluxio.master.file.state.DirectoryId
-
- getContainerId() - Method in interface alluxio.master.file.state.DirectoryId.UnmodifiableDirectoryId
-
- getContainerId() - Method in class alluxio.proto.journal.File.InodeDirectoryIdGeneratorEntry.Builder
-
optional int64 container_id = 1;
- getContainerId() - Method in class alluxio.proto.journal.File.InodeDirectoryIdGeneratorEntry
-
optional int64 container_id = 1;
- getContainerId() - Method in interface alluxio.proto.journal.File.InodeDirectoryIdGeneratorEntryOrBuilder
-
optional int64 container_id = 1;
- getContentHash() - Method in class alluxio.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.jnifuse.AbstractFuseFileSystem
-
- getContext() - Method in interface alluxio.jnifuse.FuseFileSystem
-
- getContext() - Method in class alluxio.master.table.Database
-
- getContext() - Method in class alluxio.master.transport.GrpcMessagingThread
-
- getContext(Class<?>) - Method in class alluxio.web.JacksonProtobufObjectMapperProvider
-
- getCoordinator(long) - Method in class alluxio.master.job.plan.PlanTracker
-
- getCount() - Method in class alluxio.grpc.StatusSummary.Builder
-
optional int64 count = 2;
- getCount() - Method in class alluxio.grpc.StatusSummary
-
optional int64 count = 2;
- getCount() - Method in interface alluxio.grpc.StatusSummaryOrBuilder
-
optional int64 count = 2;
- getCount() - Method in class alluxio.job.wire.StatusSummary
-
Returns the count of the number of jobs associated with
Status
.
- getCounter() - Method in class alluxio.worker.grpc.BlockReadRequestContext
-
- getCounter() - Method in class alluxio.worker.grpc.WriteRequestContext
-
- getCounters() - Method in class alluxio.util.BucketCounter
-
- 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.
- getCreationDate() - Method in class alluxio.proxy.s3.ListAllMyBucketsResult.Bucket
-
- getCreationTime() - Method in class alluxio.util.webui.UIFileInfo
-
Gets creation time.
- getCreationTimeMs() - Method in class alluxio.client.file.URIStatus
-
- getCreationTimeMs() - Method in class alluxio.grpc.FileInfo.Builder
-
optional int64 creationTimeMs = 7;
- getCreationTimeMs() - Method in class alluxio.grpc.FileInfo
-
optional int64 creationTimeMs = 7;
- getCreationTimeMs() - Method in interface alluxio.grpc.FileInfoOrBuilder
-
optional int64 creationTimeMs = 7;
- getCreationTimeMs() - Method in class alluxio.master.file.meta.Inode
-
- getCreationTimeMs() - Method in interface alluxio.master.file.meta.InodeView
-
- getCreationTimeMs() - Method in class alluxio.master.file.meta.MutableInode
-
- getCreationTimeMs() - Method in class alluxio.proto.journal.File.InodeDirectoryEntry.Builder
-
optional int64 creation_time_ms = 6;
- getCreationTimeMs() - Method in class alluxio.proto.journal.File.InodeDirectoryEntry
-
optional int64 creation_time_ms = 6;
- getCreationTimeMs() - Method in interface alluxio.proto.journal.File.InodeDirectoryEntryOrBuilder
-
optional int64 creation_time_ms = 6;
- getCreationTimeMs() - Method in class alluxio.proto.journal.File.InodeFileEntry.Builder
-
optional int64 creation_time_ms = 6;
- getCreationTimeMs() - Method in class alluxio.proto.journal.File.InodeFileEntry
-
optional int64 creation_time_ms = 6;
- getCreationTimeMs() - Method in interface alluxio.proto.journal.File.InodeFileEntryOrBuilder
-
optional int64 creation_time_ms = 6;
- getCreationTimeMs() - Method in class alluxio.proto.journal.File.UpdateInodeEntry.Builder
-
optional int64 creation_time_ms = 6;
- getCreationTimeMs() - Method in class alluxio.proto.journal.File.UpdateInodeEntry
-
optional int64 creation_time_ms = 6;
- getCreationTimeMs() - Method in interface alluxio.proto.journal.File.UpdateInodeEntryOrBuilder
-
optional int64 creation_time_ms = 6;
- getCreationTimeMs() - Method in class alluxio.proto.meta.InodeMeta.Inode.Builder
-
optional int64 creation_time_ms = 2;
- getCreationTimeMs() - Method in class alluxio.proto.meta.InodeMeta.Inode
-
optional int64 creation_time_ms = 2;
- getCreationTimeMs() - Method in interface alluxio.proto.meta.InodeMeta.InodeOrBuilder
-
optional int64 creation_time_ms = 2;
- getCreationTimeMs() - Method in class alluxio.wire.FileInfo
-
- getCredentials() - Static method in class alluxio.conf.CredentialPropertyKeys
-
return CREDENTIAL set.
- getCurrentBlocks(int) - Method in class alluxio.grpc.RegisterWorkerPRequest.Builder
-
use repeated fields to represent mapping from BlockStoreLocationProto to TierList
- getCurrentBlocks(int) - Method in class alluxio.grpc.RegisterWorkerPRequest
-
use repeated fields to represent mapping from BlockStoreLocationProto to TierList
- getCurrentBlocks(int) - Method in interface alluxio.grpc.RegisterWorkerPRequestOrBuilder
-
use repeated fields to represent mapping from BlockStoreLocationProto to TierList
- getCurrentBlocksBuilder(int) - Method in class alluxio.grpc.RegisterWorkerPRequest.Builder
-
use repeated fields to represent mapping from BlockStoreLocationProto to TierList
- getCurrentBlocksBuilderList() - Method in class alluxio.grpc.RegisterWorkerPRequest.Builder
-
use repeated fields to represent mapping from BlockStoreLocationProto to TierList
- getCurrentBlocksCount() - Method in class alluxio.grpc.RegisterWorkerPRequest.Builder
-
use repeated fields to represent mapping from BlockStoreLocationProto to TierList
- getCurrentBlocksCount() - Method in class alluxio.grpc.RegisterWorkerPRequest
-
use repeated fields to represent mapping from BlockStoreLocationProto to TierList
- getCurrentBlocksCount() - Method in interface alluxio.grpc.RegisterWorkerPRequestOrBuilder
-
use repeated fields to represent mapping from BlockStoreLocationProto to TierList
- getCurrentBlocksList() - Method in class alluxio.grpc.RegisterWorkerPRequest.Builder
-
use repeated fields to represent mapping from BlockStoreLocationProto to TierList
- getCurrentBlocksList() - Method in class alluxio.grpc.RegisterWorkerPRequest
-
use repeated fields to represent mapping from BlockStoreLocationProto to TierList
- getCurrentBlocksList() - Method in interface alluxio.grpc.RegisterWorkerPRequestOrBuilder
-
use repeated fields to represent mapping from BlockStoreLocationProto to TierList
- getCurrentBlocksOnTiers() - Method in class alluxio.grpc.RegisterWorkerPRequest.Builder
-
Deprecated.
- getCurrentBlocksOnTiers() - Method in class alluxio.grpc.RegisterWorkerPRequest
-
Deprecated.
- getCurrentBlocksOnTiers() - Method in interface alluxio.grpc.RegisterWorkerPRequestOrBuilder
-
Deprecated.
- getCurrentBlocksOnTiersCount() - Method in class alluxio.grpc.RegisterWorkerPRequest.Builder
-
- getCurrentBlocksOnTiersCount() - Method in class alluxio.grpc.RegisterWorkerPRequest
-
- getCurrentBlocksOnTiersCount() - Method in interface alluxio.grpc.RegisterWorkerPRequestOrBuilder
-
the map of list of blocks on each tier (deprecated since 2.0, replaced by currentBlocks
- getCurrentBlocksOnTiersMap() - Method in class alluxio.grpc.RegisterWorkerPRequest.Builder
-
the map of list of blocks on each tier (deprecated since 2.0, replaced by currentBlocks
- getCurrentBlocksOnTiersMap() - Method in class alluxio.grpc.RegisterWorkerPRequest
-
the map of list of blocks on each tier (deprecated since 2.0, replaced by currentBlocks
- getCurrentBlocksOnTiersMap() - Method in interface alluxio.grpc.RegisterWorkerPRequestOrBuilder
-
the map of list of blocks on each tier (deprecated since 2.0, replaced by currentBlocks
- getCurrentBlocksOnTiersOrDefault(String, TierList) - Method in class alluxio.grpc.RegisterWorkerPRequest.Builder
-
the map of list of blocks on each tier (deprecated since 2.0, replaced by currentBlocks
- getCurrentBlocksOnTiersOrDefault(String, TierList) - Method in class alluxio.grpc.RegisterWorkerPRequest
-
the map of list of blocks on each tier (deprecated since 2.0, replaced by currentBlocks
- getCurrentBlocksOnTiersOrDefault(String, TierList) - Method in interface alluxio.grpc.RegisterWorkerPRequestOrBuilder
-
the map of list of blocks on each tier (deprecated since 2.0, replaced by currentBlocks
- getCurrentBlocksOnTiersOrThrow(String) - Method in class alluxio.grpc.RegisterWorkerPRequest.Builder
-
the map of list of blocks on each tier (deprecated since 2.0, replaced by currentBlocks
- getCurrentBlocksOnTiersOrThrow(String) - Method in class alluxio.grpc.RegisterWorkerPRequest
-
the map of list of blocks on each tier (deprecated since 2.0, replaced by currentBlocks
- getCurrentBlocksOnTiersOrThrow(String) - Method in interface alluxio.grpc.RegisterWorkerPRequestOrBuilder
-
the map of list of blocks on each tier (deprecated since 2.0, replaced by currentBlocks
- getCurrentBlocksOrBuilder(int) - Method in class alluxio.grpc.RegisterWorkerPRequest.Builder
-
use repeated fields to represent mapping from BlockStoreLocationProto to TierList
- getCurrentBlocksOrBuilder(int) - Method in class alluxio.grpc.RegisterWorkerPRequest
-
use repeated fields to represent mapping from BlockStoreLocationProto to TierList
- getCurrentBlocksOrBuilder(int) - Method in interface alluxio.grpc.RegisterWorkerPRequestOrBuilder
-
use repeated fields to represent mapping from BlockStoreLocationProto to TierList
- getCurrentBlocksOrBuilderList() - Method in class alluxio.grpc.RegisterWorkerPRequest.Builder
-
use repeated fields to represent mapping from BlockStoreLocationProto to TierList
- getCurrentBlocksOrBuilderList() - Method in class alluxio.grpc.RegisterWorkerPRequest
-
use repeated fields to represent mapping from BlockStoreLocationProto to TierList
- getCurrentBlocksOrBuilderList() - Method in interface alluxio.grpc.RegisterWorkerPRequestOrBuilder
-
use repeated fields to represent mapping from BlockStoreLocationProto to TierList
- getCurrentDirectory() - Method in class alluxio.wire.MasterWebUIBrowse
-
Gets current directory.
- getCurrentGroup() - Method in class alluxio.master.journal.raft.RaftJournalSystem
-
- getCurrentLog(UfsJournal) - Static method in class alluxio.master.journal.ufs.UfsJournalSnapshot
-
Gets the current log (the incomplete log) that is being written to.
- getCurrentLog() - Method in class alluxio.master.journalv0.ufs.UfsJournal
-
- getCurrentMs() - Static method in class alluxio.util.CommonUtils
-
- getCurrentPath() - Method in class alluxio.wire.MasterWebUIBrowse
-
Gets current path.
- getCurrentPath() - Method in class alluxio.wire.MasterWebUILogs
-
Gets current path.
- getCurrentPath() - Method in class alluxio.wire.WorkerWebUILogs
-
Gets current path.
- getCurrentSequenceNumbers() - Method in interface alluxio.master.journal.JournalSystem
-
Used to get the current state from a leader journal system.
- getCurrentSequenceNumbers() - Method in class alluxio.master.journal.noop.NoopJournalSystem
-
- getCurrentSequenceNumbers() - Method in class alluxio.master.journal.raft.RaftJournalSystem
-
- getCurrentSequenceNumbers() - Method in class alluxio.master.journal.ufs.UfsJournalSystem
-
- getCurrentStatus() - Method in class alluxio.master.backup.BackupTracker
-
- getCurrentThreadIdentifier() - Static method in class alluxio.util.ThreadUtils
-
- getCustomProvider() - Method in class alluxio.security.authentication.plain.CustomAuthenticationProvider
-
- getData() - Method in class alluxio.grpc.Chunk.Builder
-
optional bytes data = 1;
- getData() - Method in class alluxio.grpc.Chunk
-
optional bytes data = 1;
- getData() - Method in interface alluxio.grpc.ChunkOrBuilder
-
optional bytes data = 1;
- getData(int) - Method in class alluxio.grpc.Command.Builder
-
repeated int64 data = 2;
- getData(int) - Method in class alluxio.grpc.Command
-
repeated int64 data = 2;
- getData(int) - Method in interface alluxio.grpc.CommandOrBuilder
-
repeated int64 data = 2;
- getData() - Method in class alluxio.grpc.DownloadSnapshotPResponse.Builder
-
optional .alluxio.grpc.meta.SnapshotData data = 1;
- getData() - Method in class alluxio.grpc.DownloadSnapshotPResponse
-
optional .alluxio.grpc.meta.SnapshotData data = 1;
- getData() - Method in interface alluxio.grpc.DownloadSnapshotPResponseOrBuilder
-
optional .alluxio.grpc.meta.SnapshotData data = 1;
- getData() - Method in class alluxio.grpc.table.ColumnStatisticsInfo.Builder
-
optional .alluxio.grpc.table.ColumnStatisticsData data = 3;
- getData() - Method in class alluxio.grpc.table.ColumnStatisticsInfo
-
optional .alluxio.grpc.table.ColumnStatisticsData data = 3;
- getData() - Method in interface alluxio.grpc.table.ColumnStatisticsInfoOrBuilder
-
optional .alluxio.grpc.table.ColumnStatisticsData data = 3;
- getData() - Method in class alluxio.grpc.UploadSnapshotPRequest.Builder
-
optional .alluxio.grpc.meta.SnapshotData data = 1;
- getData() - Method in class alluxio.grpc.UploadSnapshotPRequest
-
optional .alluxio.grpc.meta.SnapshotData data = 1;
- getData() - Method in interface alluxio.grpc.UploadSnapshotPRequestOrBuilder
-
optional .alluxio.grpc.meta.SnapshotData data = 1;
- getData() - Method in interface alluxio.table.common.Layout
-
- getData() - Method in class alluxio.table.common.layout.HiveLayout
-
- getDatabase() - Method in class alluxio.client.hive.HiveCacheContext
-
- getDatabase(String) - Method in class alluxio.client.table.RetryHandlingTableMasterClient
-
- getDatabase(String) - Method in interface alluxio.client.table.TableMasterClient
-
Get database metadata.
- getDatabase(int) - Method in class alluxio.grpc.table.GetAllDatabasesPResponse.Builder
-
repeated string database = 1;
- getDatabase(int) - Method in class alluxio.grpc.table.GetAllDatabasesPResponse
-
repeated string database = 1;
- getDatabase(int) - Method in interface alluxio.grpc.table.GetAllDatabasesPResponseOrBuilder
-
repeated string database = 1;
- getDatabase() - Method in class alluxio.grpc.table.GetAllTablesPRequest.Builder
-
optional string database = 1;
- getDatabase() - Method in class alluxio.grpc.table.GetAllTablesPRequest
-
optional string database = 1;
- getDatabase() - Method in interface alluxio.grpc.table.GetAllTablesPRequestOrBuilder
-
optional string database = 1;
- getDatabase(GetDatabasePRequest) - 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.glue.GlueDatabase
-
- 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
-
- getDataBindHost() - Method in class alluxio.worker.AlluxioWorkerProcess
-
- getDataBindHost() - Method in interface alluxio.worker.WorkerProcess
-
- getDataBuilder() - Method in class alluxio.grpc.DownloadSnapshotPResponse.Builder
-
optional .alluxio.grpc.meta.SnapshotData data = 1;
- getDataBuilder() - Method in class alluxio.grpc.table.ColumnStatisticsInfo.Builder
-
optional .alluxio.grpc.table.ColumnStatisticsData data = 3;
- getDataBuilder() - Method in class alluxio.grpc.UploadSnapshotPRequest.Builder
-
optional .alluxio.grpc.meta.SnapshotData data = 1;
- 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.DownloadSnapshotPResponse.Builder
-
optional .alluxio.grpc.meta.SnapshotData data = 1;
- getDataOrBuilder() - Method in class alluxio.grpc.DownloadSnapshotPResponse
-
optional .alluxio.grpc.meta.SnapshotData data = 1;
- getDataOrBuilder() - Method in interface alluxio.grpc.DownloadSnapshotPResponseOrBuilder
-
optional .alluxio.grpc.meta.SnapshotData data = 1;
- getDataOrBuilder() - Method in class alluxio.grpc.table.ColumnStatisticsInfo.Builder
-
optional .alluxio.grpc.table.ColumnStatisticsData data = 3;
- getDataOrBuilder() - Method in class alluxio.grpc.table.ColumnStatisticsInfo
-
optional .alluxio.grpc.table.ColumnStatisticsData data = 3;
- getDataOrBuilder() - Method in interface alluxio.grpc.table.ColumnStatisticsInfoOrBuilder
-
optional .alluxio.grpc.table.ColumnStatisticsData data = 3;
- getDataOrBuilder() - Method in class alluxio.grpc.UploadSnapshotPRequest.Builder
-
optional .alluxio.grpc.meta.SnapshotData data = 1;
- getDataOrBuilder() - Method in class alluxio.grpc.UploadSnapshotPRequest
-
optional .alluxio.grpc.meta.SnapshotData data = 1;
- getDataOrBuilder() - Method in interface alluxio.grpc.UploadSnapshotPRequestOrBuilder
-
optional .alluxio.grpc.meta.SnapshotData data = 1;
- 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.
- getDataReaderFactory() - Method in class alluxio.client.block.stream.BlockInStream
-
- getDataSourceAndType(BlockInfo, URIStatus, BlockLocationPolicy, Map<WorkerNetAddress, Long>) - Method in class alluxio.client.block.AlluxioBlockStore
-
Gets the data source and type of data source of a block.
- getDateStats() - Method in class alluxio.grpc.table.ColumnStatisticsData.Builder
-
.alluxio.grpc.table.DateColumnStatsData date_stats = 7;
- getDateStats() - Method in class alluxio.grpc.table.ColumnStatisticsData
-
.alluxio.grpc.table.DateColumnStatsData date_stats = 7;
- getDateStats() - Method in interface alluxio.grpc.table.ColumnStatisticsDataOrBuilder
-
.alluxio.grpc.table.DateColumnStatsData date_stats = 7;
- getDateStatsBuilder() - Method in class alluxio.grpc.table.ColumnStatisticsData.Builder
-
.alluxio.grpc.table.DateColumnStatsData date_stats = 7;
- getDateStatsOrBuilder() - Method in class alluxio.grpc.table.ColumnStatisticsData.Builder
-
.alluxio.grpc.table.DateColumnStatsData date_stats = 7;
- getDateStatsOrBuilder() - Method in class alluxio.grpc.table.ColumnStatisticsData
-
.alluxio.grpc.table.DateColumnStatsData date_stats = 7;
- getDateStatsOrBuilder() - Method in interface alluxio.grpc.table.ColumnStatisticsDataOrBuilder
-
.alluxio.grpc.table.DateColumnStatsData date_stats = 7;
- 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.AddTablePartitionsEntry.Builder
-
optional string db_name = 1;
- getDbName() - Method in class alluxio.proto.journal.Table.AddTablePartitionsEntry
-
optional string db_name = 1;
- getDbName() - Method in interface alluxio.proto.journal.Table.AddTablePartitionsEntryOrBuilder
-
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.AddTablePartitionsEntry.Builder
-
optional string db_name = 1;
- getDbNameBytes() - Method in class alluxio.proto.journal.Table.AddTablePartitionsEntry
-
optional string db_name = 1;
- getDbNameBytes() - Method in interface alluxio.proto.journal.Table.AddTablePartitionsEntryOrBuilder
-
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.MasterWebUIMountTable
-
Gets debug.
- getDebug() - Method in class alluxio.wire.MasterWebUIOverview
-
Gets debug.
- getDebug() - Method in class alluxio.wire.MasterWebUIWorkers
-
Gets debug.
- getDebug() - Method in class alluxio.wire.WorkerWebUIInit
-
Gets debug.
- getDebug() - Method in class alluxio.wire.WorkerWebUILogs
-
Gets debug.
- getDecimalStats() - Method in class alluxio.grpc.table.ColumnStatisticsData.Builder
-
.alluxio.grpc.table.DecimalColumnStatsData decimal_stats = 6;
- getDecimalStats() - Method in class alluxio.grpc.table.ColumnStatisticsData
-
.alluxio.grpc.table.DecimalColumnStatsData decimal_stats = 6;
- getDecimalStats() - Method in interface alluxio.grpc.table.ColumnStatisticsDataOrBuilder
-
.alluxio.grpc.table.DecimalColumnStatsData decimal_stats = 6;
- getDecimalStatsBuilder() - Method in class alluxio.grpc.table.ColumnStatisticsData.Builder
-
.alluxio.grpc.table.DecimalColumnStatsData decimal_stats = 6;
- getDecimalStatsOrBuilder() - Method in class alluxio.grpc.table.ColumnStatisticsData.Builder
-
.alluxio.grpc.table.DecimalColumnStatsData decimal_stats = 6;
- getDecimalStatsOrBuilder() - Method in class alluxio.grpc.table.ColumnStatisticsData
-
.alluxio.grpc.table.DecimalColumnStatsData decimal_stats = 6;
- getDecimalStatsOrBuilder() - Method in interface alluxio.grpc.table.ColumnStatisticsDataOrBuilder
-
.alluxio.grpc.table.DecimalColumnStatsData decimal_stats = 6;
- 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.AddQuorumServerRequest
-
- getDefaultInstance() - Static method in class alluxio.grpc.AsyncCacheRequest
-
- getDefaultInstance() - Static method in class alluxio.grpc.AsyncCacheResponse
-
- getDefaultInstance() - Static method in class alluxio.grpc.BackupPOptions
-
- getDefaultInstance() - Static method in class alluxio.grpc.BackupPRequest
-
- getDefaultInstance() - Static method in class alluxio.grpc.BackupPStatus
-
- getDefaultInstance() - Static method in class alluxio.grpc.BackupStatusPRequest
-
- getDefaultInstance() - Static method in class alluxio.grpc.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.CacheRequest
-
- getDefaultInstance() - Static method in class alluxio.grpc.CacheResponse
-
- getDefaultInstance() - Static method in class alluxio.grpc.CancelPOptions
-
- getDefaultInstance() - Static method in class alluxio.grpc.CancelPRequest
-
- getDefaultInstance() - Static method in class alluxio.grpc.CancelPResponse
-
- getDefaultInstance() - Static method in class alluxio.grpc.CancelTaskCommand
-
- getDefaultInstance() - Static method in class alluxio.grpc.CheckAccessPOptions
-
- getDefaultInstance() - Static method in class alluxio.grpc.CheckAccessPRequest
-
- getDefaultInstance() - Static method in class alluxio.grpc.CheckAccessPResponse
-
- getDefaultInstance() - Static method in class alluxio.grpc.CheckConsistencyPOptions
-
- getDefaultInstance() - Static method in class alluxio.grpc.CheckConsistencyPRequest
-
- getDefaultInstance() - Static method in class alluxio.grpc.CheckConsistencyPResponse
-
- getDefaultInstance() - Static method in class alluxio.grpc.CheckpointPOptions
-
- getDefaultInstance() - Static method in class alluxio.grpc.CheckpointPResponse
-
- getDefaultInstance() - Static method in class alluxio.grpc.CheckRequest
-
- getDefaultInstance() - Static method in class alluxio.grpc.CheckResponse
-
- getDefaultInstance() - Static method in class alluxio.grpc.Chunk
-
- getDefaultInstance() - Static method in class alluxio.grpc.ClearMetricsPRequest
-
- getDefaultInstance() - Static method in class alluxio.grpc.ClearMetricsPResponse
-
- getDefaultInstance() - Static method in class alluxio.grpc.ClearMetricsRequest
-
- getDefaultInstance() - Static method in class alluxio.grpc.ClearMetricsResponse
-
- getDefaultInstance() - Static method in class alluxio.grpc.ClientMetrics
-
- getDefaultInstance() - Static method in class alluxio.grpc.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.DownloadSnapshotPRequest
-
- getDefaultInstance() - Static method in class alluxio.grpc.DownloadSnapshotPResponse
-
- 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.GetJobStatusDetailedPOptions
-
- getDefaultInstance() - Static method in class alluxio.grpc.GetJobStatusDetailedPRequest
-
- getDefaultInstance() - Static method in class alluxio.grpc.GetJobStatusDetailedPResponse
-
- getDefaultInstance() - Static method in class alluxio.grpc.GetJobStatusPOptions
-
- getDefaultInstance() - Static method in class alluxio.grpc.GetJobStatusPRequest
-
- getDefaultInstance() - Static method in class alluxio.grpc.GetJobStatusPResponse
-
- getDefaultInstance() - Static method in class alluxio.grpc.GetMasterIdPOptions
-
- getDefaultInstance() - Static method in class alluxio.grpc.GetMasterIdPRequest
-
- getDefaultInstance() - Static method in class alluxio.grpc.GetMasterIdPResponse
-
- getDefaultInstance() - Static method in class alluxio.grpc.GetMasterInfoPOptions
-
- getDefaultInstance() - Static method in class alluxio.grpc.GetMasterInfoPResponse
-
- getDefaultInstance() - Static method in class alluxio.grpc.GetMetricsPOptions
-
- getDefaultInstance() - Static method in class alluxio.grpc.GetMetricsPResponse
-
- getDefaultInstance() - Static method in class alluxio.grpc.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.GetSnapshotInfoRequest
-
- getDefaultInstance() - Static method in class alluxio.grpc.GetSnapshotInfoResponse
-
- getDefaultInstance() - Static method in class alluxio.grpc.GetSnapshotRequest
-
- getDefaultInstance() - Static method in class alluxio.grpc.GetStateLockHoldersPOptions
-
- getDefaultInstance() - Static method in class alluxio.grpc.GetStateLockHoldersPRequest
-
- getDefaultInstance() - Static method in class alluxio.grpc.GetStateLockHoldersPResponse
-
- getDefaultInstance() - Static method in class alluxio.grpc.GetStatusPOptions
-
- getDefaultInstance() - Static method in class alluxio.grpc.GetStatusPRequest
-
- getDefaultInstance() - Static method in class alluxio.grpc.GetStatusPResponse
-
- getDefaultInstance() - Static method in class alluxio.grpc.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.JournalQueryRequest
-
- getDefaultInstance() - Static method in class alluxio.grpc.JournalQueryResponse
-
- 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.ResetPrioritiesPOptions
-
- getDefaultInstance() - Static method in class alluxio.grpc.ResetPrioritiesPRequest
-
- getDefaultInstance() - Static method in class alluxio.grpc.ResetPrioritiesPResponse
-
- 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.SnapshotData
-
- getDefaultInstance() - Static method in class alluxio.grpc.SnapshotMetadata
-
- 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.TransferLeadershipPOptions
-
- getDefaultInstance() - Static method in class alluxio.grpc.TransferLeadershipPRequest
-
- getDefaultInstance() - Static method in class alluxio.grpc.TransferLeadershipPResponse
-
- getDefaultInstance() - Static method in class alluxio.grpc.TransportMessage
-
- getDefaultInstance() - Static method in class alluxio.grpc.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.UpdateConfigurationPRequest
-
- getDefaultInstance() - Static method in class alluxio.grpc.UpdateConfigurationPResponse
-
- getDefaultInstance() - Static method in class alluxio.grpc.UpdateMountPRequest
-
- getDefaultInstance() - Static method in class alluxio.grpc.UpdateMountPResponse
-
- getDefaultInstance() - Static method in class alluxio.grpc.UpdateUfsModePOptions
-
- getDefaultInstance() - Static method in class alluxio.grpc.UpdateUfsModePRequest
-
- getDefaultInstance() - Static method in class alluxio.grpc.UpdateUfsModePResponse
-
- getDefaultInstance() - Static method in class alluxio.grpc.UploadSnapshotPRequest
-
- getDefaultInstance() - Static method in class alluxio.grpc.UploadSnapshotPResponse
-
- 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.AddTablePartitionsEntry
-
- 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.AddQuorumServerRequest.Builder
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.AddQuorumServerRequest
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.AsyncCacheRequest.Builder
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.AsyncCacheRequest
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.AsyncCacheResponse.Builder
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.AsyncCacheResponse
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.BackupPOptions.Builder
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.BackupPOptions
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.BackupPRequest.Builder
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.BackupPRequest
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.BackupPStatus.Builder
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.BackupPStatus
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.BackupStatusPRequest.Builder
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.BackupStatusPRequest
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.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.CacheRequest.Builder
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.CacheRequest
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.CacheResponse.Builder
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.CacheResponse
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.CancelPOptions.Builder
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.CancelPOptions
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.CancelPRequest.Builder
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.CancelPRequest
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.CancelPResponse.Builder
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.CancelPResponse
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.CancelTaskCommand.Builder
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.CancelTaskCommand
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.CheckAccessPOptions.Builder
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.CheckAccessPOptions
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.CheckAccessPRequest.Builder
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.CheckAccessPRequest
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.CheckAccessPResponse.Builder
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.CheckAccessPResponse
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.CheckConsistencyPOptions.Builder
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.CheckConsistencyPOptions
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.CheckConsistencyPRequest.Builder
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.CheckConsistencyPRequest
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.CheckConsistencyPResponse.Builder
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.CheckConsistencyPResponse
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.CheckpointPOptions.Builder
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.CheckpointPOptions
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.CheckpointPResponse.Builder
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.CheckpointPResponse
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.CheckRequest.Builder
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.CheckRequest
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.CheckResponse.Builder
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.CheckResponse
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.Chunk.Builder
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.Chunk
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.ClearMetricsPRequest.Builder
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.ClearMetricsPRequest
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.ClearMetricsPResponse.Builder
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.ClearMetricsPResponse
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.ClearMetricsRequest.Builder
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.ClearMetricsRequest
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.ClearMetricsResponse.Builder
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.ClearMetricsResponse
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.ClientMetrics.Builder
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.ClientMetrics
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.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.DownloadSnapshotPRequest.Builder
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.DownloadSnapshotPRequest
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.DownloadSnapshotPResponse.Builder
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.DownloadSnapshotPResponse
-
- 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.GetJobStatusDetailedPOptions.Builder
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.GetJobStatusDetailedPOptions
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.GetJobStatusDetailedPRequest.Builder
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.GetJobStatusDetailedPRequest
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.GetJobStatusDetailedPResponse.Builder
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.GetJobStatusDetailedPResponse
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.GetJobStatusPOptions.Builder
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.GetJobStatusPOptions
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.GetJobStatusPRequest.Builder
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.GetJobStatusPRequest
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.GetJobStatusPResponse.Builder
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.GetJobStatusPResponse
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.GetMasterIdPOptions.Builder
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.GetMasterIdPOptions
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.GetMasterIdPRequest.Builder
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.GetMasterIdPRequest
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.GetMasterIdPResponse.Builder
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.GetMasterIdPResponse
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.GetMasterInfoPOptions.Builder
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.GetMasterInfoPOptions
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.GetMasterInfoPResponse.Builder
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.GetMasterInfoPResponse
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.GetMetricsPOptions.Builder
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.GetMetricsPOptions
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.GetMetricsPResponse.Builder
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.GetMetricsPResponse
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.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.GetSnapshotInfoRequest.Builder
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.GetSnapshotInfoRequest
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.GetSnapshotInfoResponse.Builder
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.GetSnapshotInfoResponse
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.GetSnapshotRequest.Builder
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.GetSnapshotRequest
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.GetStateLockHoldersPOptions.Builder
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.GetStateLockHoldersPOptions
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.GetStateLockHoldersPRequest.Builder
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.GetStateLockHoldersPRequest
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.GetStateLockHoldersPResponse.Builder
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.GetStateLockHoldersPResponse
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.GetStatusPOptions.Builder
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.GetStatusPOptions
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.GetStatusPRequest.Builder
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.GetStatusPRequest
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.GetStatusPResponse.Builder
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.GetStatusPResponse
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.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.JournalQueryRequest.Builder
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.JournalQueryRequest
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.JournalQueryResponse.Builder
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.JournalQueryResponse
-
- 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.ResetPrioritiesPOptions.Builder
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.ResetPrioritiesPOptions
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.ResetPrioritiesPRequest.Builder
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.ResetPrioritiesPRequest
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.ResetPrioritiesPResponse.Builder
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.ResetPrioritiesPResponse
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.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.SnapshotData.Builder
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.SnapshotData
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.SnapshotMetadata.Builder
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.SnapshotMetadata
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.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.TransferLeadershipPOptions.Builder
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.TransferLeadershipPOptions
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.TransferLeadershipPRequest.Builder
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.TransferLeadershipPRequest
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.TransferLeadershipPResponse.Builder
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.TransferLeadershipPResponse
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.TransportMessage.Builder
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.TransportMessage
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.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.UpdateConfigurationPRequest.Builder
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.UpdateConfigurationPRequest
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.UpdateConfigurationPResponse.Builder
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.UpdateConfigurationPResponse
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.UpdateMountPRequest.Builder
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.UpdateMountPRequest
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.UpdateMountPResponse.Builder
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.UpdateMountPResponse
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.UpdateUfsModePOptions.Builder
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.UpdateUfsModePOptions
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.UpdateUfsModePRequest.Builder
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.UpdateUfsModePRequest
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.UpdateUfsModePResponse.Builder
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.UpdateUfsModePResponse
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.UploadSnapshotPRequest.Builder
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.UploadSnapshotPRequest
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.UploadSnapshotPResponse.Builder
-
- getDefaultInstanceForType() - Method in class alluxio.grpc.UploadSnapshotPResponse
-
- 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.AddTablePartitionsEntry.Builder
-
- getDefaultInstanceForType() - Method in class alluxio.proto.journal.Table.AddTablePartitionsEntry
-
- 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
-
- getDefaultValue() - Method in class alluxio.table.under.glue.Property
-
- getDefaultValue() - Method in class alluxio.table.under.hive.Property
-
- 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
-
- getDelegate() - Method in class alluxio.worker.block.io.DelegatingBlockReader
-
- 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;
- getDelimiter() - Method in class alluxio.proxy.s3.ListBucketOptions
-
- getDelimiter() - Method in class alluxio.proxy.s3.ListBucketResult
-
- getDependencies() - Method in class alluxio.master.AbstractMaster
-
- getDependencies() - Method in class alluxio.master.block.DefaultBlockMaster
-
- getDependencies() - Method in class alluxio.master.file.DefaultFileSystemMaster
-
- getDependencies() - Method in class alluxio.master.meta.DefaultMetaMaster
-
- getDependencies() - Method in class alluxio.master.NoopMaster
-
- getDependencies() - Method in 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
.
- getDesc() - Method in class alluxio.cli.ValidationTaskResult
-
- getDescendants(LockedInodePath) - Method in class alluxio.master.file.meta.InodeTree
-
- getDescendingIterator() - Method in class alluxio.worker.block.annotator.SortedBlockSet
-
- 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
-
Deprecated.
- getDescription() - Method in class alluxio.cli.fs.command.LoadCommand
-
- getDescription() - Method in class alluxio.cli.fs.command.LoadMetadataCommand
-
- 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.StateLockHoldersCommand
-
- getDescription() - Method in class alluxio.cli.fsadmin.command.UfsCommand
-
- getDescription() - Method in class alluxio.cli.fsadmin.command.UpdateConfCommand
-
- getDescription() - Method in class alluxio.cli.fsadmin.journal.CheckpointCommand
-
- getDescription() - Method in class alluxio.cli.fsadmin.journal.QuorumCommand
-
- getDescription() - Method in class alluxio.cli.fsadmin.journal.QuorumElectCommand
-
- getDescription() - Method in class alluxio.cli.fsadmin.journal.QuorumInfoCommand
-
- getDescription() - Method in class alluxio.cli.fsadmin.journal.QuorumRemoveCommand
-
- getDescription() - Method in class alluxio.cli.fsadmin.metrics.ClearCommand
-
- getDescription() - Method in class alluxio.cli.fsadmin.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.cli.ValidateEnv
-
Gets the task descriptions.
- getDescription() - Method in class alluxio.conf.PropertyKey
-
- getDescription() - Method in class alluxio.DefaultSupplier
-
- getDescription() - Method in class alluxio.grpc.JobInfo.Builder
-
optional string description = 13;
- getDescription() - Method in class alluxio.grpc.JobInfo
-
optional string description = 13;
- getDescription() - Method in interface alluxio.grpc.JobInfoOrBuilder
-
optional string description = 13;
- getDescription() - Method in class alluxio.grpc.table.Database.Builder
-
optional string description = 2;
- getDescription() - Method in class alluxio.grpc.table.Database
-
optional string description = 2;
- getDescription() - Method in interface alluxio.grpc.table.DatabaseOrBuilder
-
optional string description = 2;
- getDescription() - Method in interface alluxio.job.wire.JobInfo
-
- getDescription() - Method in class alluxio.job.wire.PlanInfo
-
- getDescription() - Method in class alluxio.job.wire.TaskInfo
-
- getDescription() - Method in class alluxio.job.wire.WorkflowInfo
-
- getDescription() - Method in class alluxio.metrics.MetricKey
-
- getDescription() - Method in class alluxio.proxy.s3.S3ErrorCode
-
- getDescription(List<String>) - Method in class alluxio.stress.Parameters
-
Returns a string representation of the parameters, using only the specified fields.
- getDescription() - Method in class alluxio.table.common.BaseProperty
-
- getDescription() - Method in class alluxio.table.under.glue.Property
-
- getDescription() - Method in class alluxio.table.under.hive.Property
-
- 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.AddQuorumServerRequest.Builder
-
- getDescriptor() - Static method in class alluxio.grpc.AddQuorumServerRequest
-
- getDescriptor() - Static method in class alluxio.grpc.AsyncCacheRequest.Builder
-
- getDescriptor() - Static method in class alluxio.grpc.AsyncCacheRequest
-
- getDescriptor() - Static method in class alluxio.grpc.AsyncCacheResponse.Builder
-
- getDescriptor() - Static method in class alluxio.grpc.AsyncCacheResponse
-
- getDescriptor() - Static method in class alluxio.grpc.AuthenticationServerProto
-
- getDescriptor() - Static method in class alluxio.grpc.BackupPOptions.Builder
-
- getDescriptor() - Static method in class alluxio.grpc.BackupPOptions
-
- getDescriptor() - Static method in class alluxio.grpc.BackupPRequest.Builder
-
- getDescriptor() - Static method in class alluxio.grpc.BackupPRequest
-
- getDescriptor() - Static method in class alluxio.grpc.BackupPStatus.Builder
-
- getDescriptor() - Static method in class alluxio.grpc.BackupPStatus
-
- getDescriptor() - Static method in enum alluxio.grpc.BackupState
-
- getDescriptor() - Static method in class alluxio.grpc.BackupStatusPRequest.Builder
-
- getDescriptor() - Static method in class alluxio.grpc.BackupStatusPRequest
-
- getDescriptor() - Static method in enum alluxio.grpc.Bits
-
- getDescriptor() - Static method in class alluxio.grpc.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.CacheRequest.Builder
-
- getDescriptor() - Static method in class alluxio.grpc.CacheRequest
-
- getDescriptor() - Static method in class alluxio.grpc.CacheResponse.Builder
-
- getDescriptor() - Static method in class alluxio.grpc.CacheResponse
-
- getDescriptor() - Static method in class alluxio.grpc.CancelPOptions.Builder
-
- getDescriptor() - Static method in class alluxio.grpc.CancelPOptions
-
- getDescriptor() - Static method in class alluxio.grpc.CancelPRequest.Builder
-
- getDescriptor() - Static method in class alluxio.grpc.CancelPRequest
-
- getDescriptor() - Static method in class alluxio.grpc.CancelPResponse.Builder
-
- getDescriptor() - Static method in class alluxio.grpc.CancelPResponse
-
- getDescriptor() - Static method in class alluxio.grpc.CancelTaskCommand.Builder
-
- getDescriptor() - Static method in class alluxio.grpc.CancelTaskCommand
-
- getDescriptor() - Static method in enum alluxio.grpc.ChannelAuthenticationScheme
-
- getDescriptor() - Static method in class alluxio.grpc.CheckAccessPOptions.Builder
-
- getDescriptor() - Static method in class alluxio.grpc.CheckAccessPOptions
-
- getDescriptor() - Static method in class alluxio.grpc.CheckAccessPRequest.Builder
-
- getDescriptor() - Static method in class alluxio.grpc.CheckAccessPRequest
-
- getDescriptor() - Static method in class alluxio.grpc.CheckAccessPResponse.Builder
-
- getDescriptor() - Static method in class alluxio.grpc.CheckAccessPResponse
-
- getDescriptor() - Static method in class alluxio.grpc.CheckConsistencyPOptions.Builder
-
- getDescriptor() - Static method in class alluxio.grpc.CheckConsistencyPOptions
-
- getDescriptor() - Static method in class alluxio.grpc.CheckConsistencyPRequest.Builder
-
- getDescriptor() - Static method in class alluxio.grpc.CheckConsistencyPRequest
-
- getDescriptor() - Static method in class alluxio.grpc.CheckConsistencyPResponse.Builder
-
- getDescriptor() - Static method in class alluxio.grpc.CheckConsistencyPResponse
-
- getDescriptor() - Static method in class alluxio.grpc.CheckpointPOptions.Builder
-
- getDescriptor() - Static method in class alluxio.grpc.CheckpointPOptions
-
- getDescriptor() - Static method in class alluxio.grpc.CheckpointPResponse.Builder
-
- getDescriptor() - Static method in class alluxio.grpc.CheckpointPResponse
-
- getDescriptor() - Static method in class alluxio.grpc.CheckRequest.Builder
-
- getDescriptor() - Static method in class alluxio.grpc.CheckRequest
-
- getDescriptor() - Static method in class alluxio.grpc.CheckResponse.Builder
-
- getDescriptor() - Static method in class alluxio.grpc.CheckResponse
-
- getDescriptor() - Static method in class alluxio.grpc.Chunk.Builder
-
- getDescriptor() - Static method in class alluxio.grpc.Chunk
-
- getDescriptor() - Static method in class alluxio.grpc.ClearMetricsPRequest.Builder
-
- getDescriptor() - Static method in class alluxio.grpc.ClearMetricsPRequest
-
- getDescriptor() - Static method in class alluxio.grpc.ClearMetricsPResponse.Builder
-
- getDescriptor() - Static method in class alluxio.grpc.ClearMetricsPResponse
-
- getDescriptor() - Static method in class alluxio.grpc.ClearMetricsRequest.Builder
-
- getDescriptor() - Static method in class alluxio.grpc.ClearMetricsRequest
-
- getDescriptor() - Static method in class alluxio.grpc.ClearMetricsResponse.Builder
-
- getDescriptor() - Static method in class alluxio.grpc.ClearMetricsResponse
-
- getDescriptor() - Static method in class alluxio.grpc.ClientMetrics.Builder
-
- getDescriptor() - Static method in class alluxio.grpc.ClientMetrics
-
- getDescriptor() - Static method in class alluxio.grpc.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.DownloadSnapshotPRequest.Builder
-
- getDescriptor() - Static method in class alluxio.grpc.DownloadSnapshotPRequest
-
- getDescriptor() - Static method in class alluxio.grpc.DownloadSnapshotPResponse.Builder
-
- getDescriptor() - Static method in class alluxio.grpc.DownloadSnapshotPResponse
-
- 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.GetJobStatusDetailedPOptions.Builder
-
- getDescriptor() - Static method in class alluxio.grpc.GetJobStatusDetailedPOptions
-
- getDescriptor() - Static method in class alluxio.grpc.GetJobStatusDetailedPRequest.Builder
-
- getDescriptor() - Static method in class alluxio.grpc.GetJobStatusDetailedPRequest
-
- getDescriptor() - Static method in class alluxio.grpc.GetJobStatusDetailedPResponse.Builder
-
- getDescriptor() - Static method in class alluxio.grpc.GetJobStatusDetailedPResponse
-
- getDescriptor() - Static method in class alluxio.grpc.GetJobStatusPOptions.Builder
-
- getDescriptor() - Static method in class alluxio.grpc.GetJobStatusPOptions
-
- getDescriptor() - Static method in class alluxio.grpc.GetJobStatusPRequest.Builder
-
- getDescriptor() - Static method in class alluxio.grpc.GetJobStatusPRequest
-
- getDescriptor() - Static method in class alluxio.grpc.GetJobStatusPResponse.Builder
-
- getDescriptor() - Static method in class alluxio.grpc.GetJobStatusPResponse
-
- getDescriptor() - Static method in class alluxio.grpc.GetMasterIdPOptions.Builder
-
- getDescriptor() - Static method in class alluxio.grpc.GetMasterIdPOptions
-
- getDescriptor() - Static method in class alluxio.grpc.GetMasterIdPRequest.Builder
-
- getDescriptor() - Static method in class alluxio.grpc.GetMasterIdPRequest
-
- getDescriptor() - Static method in class alluxio.grpc.GetMasterIdPResponse.Builder
-
- getDescriptor() - Static method in class alluxio.grpc.GetMasterIdPResponse
-
- getDescriptor() - Static method in class alluxio.grpc.GetMasterInfoPOptions.Builder
-
- getDescriptor() - Static method in class alluxio.grpc.GetMasterInfoPOptions
-
- getDescriptor() - Static method in class alluxio.grpc.GetMasterInfoPResponse.Builder
-
- getDescriptor() - Static method in class alluxio.grpc.GetMasterInfoPResponse
-
- getDescriptor() - Static method in class alluxio.grpc.GetMetricsPOptions.Builder
-
- getDescriptor() - Static method in class alluxio.grpc.GetMetricsPOptions
-
- getDescriptor() - Static method in class alluxio.grpc.GetMetricsPResponse.Builder
-
- getDescriptor() - Static method in class alluxio.grpc.GetMetricsPResponse
-
- getDescriptor() - Static method in class alluxio.grpc.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.GetSnapshotInfoRequest.Builder
-
- getDescriptor() - Static method in class alluxio.grpc.GetSnapshotInfoRequest
-
- getDescriptor() - Static method in class alluxio.grpc.GetSnapshotInfoResponse.Builder
-
- getDescriptor() - Static method in class alluxio.grpc.GetSnapshotInfoResponse
-
- getDescriptor() - Static method in class alluxio.grpc.GetSnapshotRequest.Builder
-
- getDescriptor() - Static method in class alluxio.grpc.GetSnapshotRequest
-
- getDescriptor() - Static method in class alluxio.grpc.GetStateLockHoldersPOptions.Builder
-
- getDescriptor() - Static method in class alluxio.grpc.GetStateLockHoldersPOptions
-
- getDescriptor() - Static method in class alluxio.grpc.GetStateLockHoldersPRequest.Builder
-
- getDescriptor() - Static method in class alluxio.grpc.GetStateLockHoldersPRequest
-
- getDescriptor() - Static method in class alluxio.grpc.GetStateLockHoldersPResponse.Builder
-
- getDescriptor() - Static method in class alluxio.grpc.GetStateLockHoldersPResponse
-
- getDescriptor() - Static method in class alluxio.grpc.GetStatusPOptions.Builder
-
- getDescriptor() - Static method in class alluxio.grpc.GetStatusPOptions
-
- getDescriptor() - Static method in class alluxio.grpc.GetStatusPRequest.Builder
-
- getDescriptor() - Static method in class alluxio.grpc.GetStatusPRequest
-
- getDescriptor() - Static method in class alluxio.grpc.GetStatusPResponse.Builder
-
- getDescriptor() - Static method in class alluxio.grpc.GetStatusPResponse
-
- getDescriptor() - Static method in class alluxio.grpc.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.JournalQueryRequest.Builder
-
- getDescriptor() - Static method in class alluxio.grpc.JournalQueryRequest
-
- getDescriptor() - Static method in class alluxio.grpc.JournalQueryResponse.Builder
-
- getDescriptor() - Static method in class alluxio.grpc.JournalQueryResponse
-
- 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 class alluxio.grpc.RaftJournalProto
-
- getDescriptor() - Static method in enum alluxio.grpc.ReadPType
-
- getDescriptor() - Static method in class alluxio.grpc.ReadRequest.Builder
-
- getDescriptor() - Static method in class alluxio.grpc.ReadRequest
-
- getDescriptor() - Static method in class alluxio.grpc.ReadResponse.Builder
-
- getDescriptor() - Static method in class alluxio.grpc.ReadResponse
-
- getDescriptor() - Static method in class alluxio.grpc.RegisterCommand.Builder
-
- getDescriptor() - Static method in class alluxio.grpc.RegisterCommand
-
- getDescriptor() - Static method in class alluxio.grpc.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.ResetPrioritiesPOptions.Builder
-
- getDescriptor() - Static method in class alluxio.grpc.ResetPrioritiesPOptions
-
- getDescriptor() - Static method in class alluxio.grpc.ResetPrioritiesPRequest.Builder
-
- getDescriptor() - Static method in class alluxio.grpc.ResetPrioritiesPRequest
-
- getDescriptor() - Static method in class alluxio.grpc.ResetPrioritiesPResponse.Builder
-
- getDescriptor() - Static method in class alluxio.grpc.ResetPrioritiesPResponse
-
- getDescriptor() - Static method in class alluxio.grpc.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.SnapshotData.Builder
-
- getDescriptor() - Static method in class alluxio.grpc.SnapshotData
-
- getDescriptor() - Static method in class alluxio.grpc.SnapshotMetadata.Builder
-
- getDescriptor() - Static method in class alluxio.grpc.SnapshotMetadata
-
- getDescriptor() - Static method in 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.TransferLeadershipPOptions.Builder
-
- getDescriptor() - Static method in class alluxio.grpc.TransferLeadershipPOptions
-
- getDescriptor() - Static method in class alluxio.grpc.TransferLeadershipPRequest.Builder
-
- getDescriptor() - Static method in class alluxio.grpc.TransferLeadershipPRequest
-
- getDescriptor() - Static method in class alluxio.grpc.TransferLeadershipPResponse.Builder
-
- getDescriptor() - Static method in class alluxio.grpc.TransferLeadershipPResponse
-
- getDescriptor() - Static method in class alluxio.grpc.TransportMessage.Builder
-
- getDescriptor() - Static method in class alluxio.grpc.TransportMessage
-
- getDescriptor() - Static method in 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.UpdateConfigurationPRequest.Builder
-
- getDescriptor() - Static method in class alluxio.grpc.UpdateConfigurationPRequest
-
- getDescriptor() - Static method in class alluxio.grpc.UpdateConfigurationPResponse.Builder
-
- getDescriptor() - Static method in class alluxio.grpc.UpdateConfigurationPResponse
-
- getDescriptor() - Static method in class alluxio.grpc.UpdateMountPRequest.Builder
-
- getDescriptor() - Static method in class alluxio.grpc.UpdateMountPRequest
-
- getDescriptor() - Static method in class alluxio.grpc.UpdateMountPResponse.Builder
-
- getDescriptor() - Static method in class alluxio.grpc.UpdateMountPResponse
-
- getDescriptor() - Static method in class alluxio.grpc.UpdateUfsModePOptions.Builder
-
- getDescriptor() - Static method in class alluxio.grpc.UpdateUfsModePOptions
-
- getDescriptor() - Static method in class alluxio.grpc.UpdateUfsModePRequest.Builder
-
- getDescriptor() - Static method in class alluxio.grpc.UpdateUfsModePRequest
-
- getDescriptor() - Static method in class alluxio.grpc.UpdateUfsModePResponse.Builder
-
- getDescriptor() - Static method in class alluxio.grpc.UpdateUfsModePResponse
-
- getDescriptor() - Static method in class alluxio.grpc.UploadSnapshotPRequest.Builder
-
- getDescriptor() - Static method in class alluxio.grpc.UploadSnapshotPRequest
-
- getDescriptor() - Static method in class alluxio.grpc.UploadSnapshotPResponse.Builder
-
- getDescriptor() - Static method in class alluxio.grpc.UploadSnapshotPResponse
-
- 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.AddTablePartitionsEntry.Builder
-
- getDescriptor() - Static method in class alluxio.proto.journal.Table.AddTablePartitionsEntry
-
- 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.AddQuorumServerRequest.Builder
-
- getDescriptorForType() - Method in class alluxio.grpc.AsyncCacheRequest.Builder
-
- getDescriptorForType() - Method in class alluxio.grpc.AsyncCacheResponse.Builder
-
- getDescriptorForType() - Method in class alluxio.grpc.BackupPOptions.Builder
-
- getDescriptorForType() - Method in class alluxio.grpc.BackupPRequest.Builder
-
- getDescriptorForType() - Method in class alluxio.grpc.BackupPStatus.Builder
-
- getDescriptorForType() - Method in enum alluxio.grpc.BackupState
-
- getDescriptorForType() - Method in class alluxio.grpc.BackupStatusPRequest.Builder
-
- getDescriptorForType() - Method in enum alluxio.grpc.Bits
-
- getDescriptorForType() - Method in class alluxio.grpc.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.CacheRequest.Builder
-
- getDescriptorForType() - Method in class alluxio.grpc.CacheResponse.Builder
-
- getDescriptorForType() - Method in class alluxio.grpc.CancelPOptions.Builder
-
- getDescriptorForType() - Method in class alluxio.grpc.CancelPRequest.Builder
-
- getDescriptorForType() - Method in class alluxio.grpc.CancelPResponse.Builder
-
- getDescriptorForType() - Method in class alluxio.grpc.CancelTaskCommand.Builder
-
- getDescriptorForType() - Method in enum alluxio.grpc.ChannelAuthenticationScheme
-
- getDescriptorForType() - Method in class alluxio.grpc.CheckAccessPOptions.Builder
-
- getDescriptorForType() - Method in class alluxio.grpc.CheckAccessPRequest.Builder
-
- getDescriptorForType() - Method in class alluxio.grpc.CheckAccessPResponse.Builder
-
- getDescriptorForType() - Method in class alluxio.grpc.CheckConsistencyPOptions.Builder
-
- getDescriptorForType() - Method in class alluxio.grpc.CheckConsistencyPRequest.Builder
-
- getDescriptorForType() - Method in class alluxio.grpc.CheckConsistencyPResponse.Builder
-
- getDescriptorForType() - Method in class alluxio.grpc.CheckpointPOptions.Builder
-
- getDescriptorForType() - Method in class alluxio.grpc.CheckpointPResponse.Builder
-
- getDescriptorForType() - Method in class alluxio.grpc.CheckRequest.Builder
-
- getDescriptorForType() - Method in class alluxio.grpc.CheckResponse.Builder
-
- getDescriptorForType() - Method in class alluxio.grpc.Chunk.Builder
-
- getDescriptorForType() - Method in class alluxio.grpc.ClearMetricsPRequest.Builder
-
- getDescriptorForType() - Method in class alluxio.grpc.ClearMetricsPResponse.Builder
-
- getDescriptorForType() - Method in class alluxio.grpc.ClearMetricsRequest.Builder
-
- getDescriptorForType() - Method in class alluxio.grpc.ClearMetricsResponse.Builder
-
- getDescriptorForType() - Method in class alluxio.grpc.ClientMetrics.Builder
-
- getDescriptorForType() - Method in class alluxio.grpc.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.DownloadSnapshotPRequest.Builder
-
- getDescriptorForType() - Method in class alluxio.grpc.DownloadSnapshotPResponse.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.GetJobStatusDetailedPOptions.Builder
-
- getDescriptorForType() - Method in class alluxio.grpc.GetJobStatusDetailedPRequest.Builder
-
- getDescriptorForType() - Method in class alluxio.grpc.GetJobStatusDetailedPResponse.Builder
-
- getDescriptorForType() - Method in class alluxio.grpc.GetJobStatusPOptions.Builder
-
- getDescriptorForType() - Method in class alluxio.grpc.GetJobStatusPRequest.Builder
-
- getDescriptorForType() - Method in class alluxio.grpc.GetJobStatusPResponse.Builder
-
- getDescriptorForType() - Method in class alluxio.grpc.GetMasterIdPOptions.Builder
-
- getDescriptorForType() - Method in class alluxio.grpc.GetMasterIdPRequest.Builder
-
- getDescriptorForType() - Method in class alluxio.grpc.GetMasterIdPResponse.Builder
-
- getDescriptorForType() - Method in class alluxio.grpc.GetMasterInfoPOptions.Builder
-
- getDescriptorForType() - Method in class alluxio.grpc.GetMasterInfoPResponse.Builder
-
- getDescriptorForType() - Method in class alluxio.grpc.GetMetricsPOptions.Builder
-
- getDescriptorForType() - Method in class alluxio.grpc.GetMetricsPResponse.Builder
-
- getDescriptorForType() - Method in class alluxio.grpc.GetMoun