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

A

abort() - Method in class alluxio.security.login.AlluxioLoginModule
Aborts the authentication (second phase).
abort() - Method in class alluxio.security.login.AppLoginModule
Aborts the authentication (second phase).
abortBlock(long, long) - Method in interface alluxio.worker.block.BlockStore
Aborts a temporary block.
abortBlock(long, long) - Method in interface alluxio.worker.block.BlockWorker
Aborts the temporary block created by the session.
abortBlock(long, long) - Method in class alluxio.worker.block.DefaultBlockWorker
 
abortBlock(long, long) - Method in class alluxio.worker.block.TieredBlockStore
 
ABORTED_VALUE - Static variable in enum alluxio.proto.status.Status.PStatus
ABORTED = 10;
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
 
abortTask(TaskAttemptContext) - Method in class alluxio.hadoop.mapreduce.KeyValueOutputCommitter

Deletes the completed key-value stores under the task's temporary output directory, and then calls FileOutputCommitter.abortTask(TaskAttemptContext).

abortTempBlockMeta(TempBlockMeta) - Method in class alluxio.worker.block.BlockMetadataManager
Aborts a temp block.
AbstractBlockMeta - Class in alluxio.worker.block.meta
A base class of the metadata of blocks in Alluxio managed storage.
AbstractBlockMeta(long, StorageDir) - Constructor for class alluxio.worker.block.meta.AbstractBlockMeta
Creates a new instance of AbstractBlockMeta.
AbstractBlockStoreEventListener - Class in alluxio.worker.block
A block store event listener base class implementing the BlockStoreEventListener interface with empty methods bodies.
AbstractBlockStoreEventListener() - Constructor for class alluxio.worker.block.AbstractBlockStoreEventListener
 
AbstractClient - Class in alluxio
The base class for clients.
AbstractClient(Subject, InetSocketAddress) - Constructor for class alluxio.AbstractClient
Creates a new client base.
AbstractClient(Subject, InetSocketAddress, Supplier<RetryPolicy>) - Constructor for class alluxio.AbstractClient
Creates a new client base.
AbstractClient.RpcCallable<V> - Interface in alluxio
The RPC to be executed in AbstractClient.retryRPC(RpcCallable).
AbstractEvictor - Class in alluxio.worker.block.evictor
Provides the basic implementation for every evictor.
AbstractEvictor(BlockMetadataManagerView, Allocator) - Constructor for class alluxio.worker.block.evictor.AbstractEvictor
Creates a new instance of AbstractEvictor.
AbstractFileSystemCommand - Class in alluxio.cli.fs.command
The base class for all the FileSystem Command classes.
AbstractFileSystemCommand(FileSystem) - 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
 
AbstractJournalSystem - Class in alluxio.master.journal
Base implementation for journal systems.
AbstractJournalSystem() - Constructor for class alluxio.master.journal.AbstractJournalSystem
 
AbstractLineageClient - Class in alluxio.client.lineage
Alluxio Lineage client.
AbstractLineageClient(LineageContext) - Constructor for class alluxio.client.lineage.AbstractLineageClient
Constructs a new instance with a LineageContext.
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(MasterClientConfig) - Constructor for class alluxio.AbstractMasterClient
Creates a new master client base.
AbstractMasterClient(MasterClientConfig, InetSocketAddress, Supplier<RetryPolicy>) - Constructor for class alluxio.AbstractMasterClient
Creates a new master client base.
AbstractOutStream - Class in alluxio.client
An abstraction of the output stream API in Alluxio to write data to a file or a block.
AbstractOutStream() - Constructor for class alluxio.client.AbstractOutStream
 
AbstractPrimarySelector - Class in alluxio.master
Base class for implementing primary selectors.
AbstractPrimarySelector() - Constructor for class alluxio.master.AbstractPrimarySelector
 
AbstractShell - Class in alluxio.cli
Abstract class for handling command line inputs.
AbstractShell(Map<String, String[]>) - Constructor for class alluxio.cli.AbstractShell
Creates a new instance of AbstractShell.
AbstractUfsManager - Class in alluxio.underfs
Basic implementation of UfsManager.
AbstractUfsManager.Key - Class in alluxio.underfs
The key of the UFS cache.
AbstractValidationTask - Class in alluxio.cli.validation
Abstract class for validation environment.
AbstractValidationTask() - Constructor for class alluxio.cli.validation.AbstractValidationTask
 
AbstractWorker - Class in alluxio.worker
This is the base class for all workers, and contains common functionality.
AbstractWorker(ExecutorService) - Constructor for class alluxio.worker.AbstractWorker
 
acceptImpl() - Method in class alluxio.network.thrift.SocketTrackingTServerSocket
 
acceptMessage(Object) - Method in class alluxio.network.netty.NettyRPC.RPCHandler
 
acceptMessage(Object) - Method in class alluxio.worker.netty.BlockWriteHandler
 
acceptMessage(Object) - Method in class alluxio.worker.netty.UfsFileWriteHandler
 
ACCESS_BLOCK_SESSION_ID - Static variable in class alluxio.Sessions
 
accessBlock(long, AccessBlockTOptions, AsyncMethodCallback) - Method in class alluxio.thrift.BlockWorkerClientService.AsyncClient
 
accessBlock(long, AccessBlockTOptions, AsyncMethodCallback) - Method in interface alluxio.thrift.BlockWorkerClientService.AsyncIface
 
accessBlock() - Constructor for class alluxio.thrift.BlockWorkerClientService.AsyncProcessor.accessBlock
 
accessBlock(long, AccessBlockTOptions) - Method in class alluxio.thrift.BlockWorkerClientService.Client
 
accessBlock(long, AccessBlockTOptions) - Method in interface alluxio.thrift.BlockWorkerClientService.Iface
Accesses a block given the block id.
accessBlock() - Constructor for class alluxio.thrift.BlockWorkerClientService.Processor.accessBlock
 
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, AccessBlockTOptions) - Method in class alluxio.worker.block.BlockWorkerClientServiceHandler
 
accessBlock(long, long) - Method in class alluxio.worker.block.DefaultBlockWorker
 
accessBlock(long, long) - Method in class alluxio.worker.block.TieredBlockStore
 
accessBlock_args() - Constructor for class alluxio.thrift.BlockWorkerClientService.accessBlock_args
 
accessBlock_args(long, AccessBlockTOptions) - Constructor for class alluxio.thrift.BlockWorkerClientService.accessBlock_args
 
accessBlock_args(BlockWorkerClientService.accessBlock_args) - Constructor for class alluxio.thrift.BlockWorkerClientService.accessBlock_args
Performs a deep copy on other.
accessBlock_call(long, AccessBlockTOptions, AsyncMethodCallback, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class alluxio.thrift.BlockWorkerClientService.AsyncClient.accessBlock_call
 
accessBlock_result() - Constructor for class alluxio.thrift.BlockWorkerClientService.accessBlock_result
 
accessBlock_result(AccessBlockTResponse, AlluxioTException) - Constructor for class alluxio.thrift.BlockWorkerClientService.accessBlock_result
 
accessBlock_result(BlockWorkerClientService.accessBlock_result) - Constructor for class alluxio.thrift.BlockWorkerClientService.accessBlock_result
Performs a deep copy on other.
AccessBlockTOptions - Class in alluxio.thrift
 
AccessBlockTOptions() - Constructor for class alluxio.thrift.AccessBlockTOptions
 
AccessBlockTOptions(AccessBlockTOptions) - Constructor for class alluxio.thrift.AccessBlockTOptions
Performs a deep copy on other.
AccessBlockTOptions._Fields - Enum in alluxio.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
AccessBlockTResponse - Class in alluxio.thrift
 
AccessBlockTResponse() - Constructor for class alluxio.thrift.AccessBlockTResponse
 
AccessBlockTResponse(AccessBlockTResponse) - Constructor for class alluxio.thrift.AccessBlockTResponse
Performs a deep copy on other.
AccessBlockTResponse._Fields - Enum in alluxio.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
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.
acquire() - Method in class alluxio.resource.DynamicResourcePool
Acquire a resource of type {code T} from the pool.
acquire(long, TimeUnit) - Method in class alluxio.resource.DynamicResourcePool
Acquires a resource of type {code T} from the pool.
acquire() - Method in interface alluxio.resource.Pool
Acquires a resource from the pool.
acquire(long, TimeUnit) - Method in interface alluxio.resource.Pool
Acquires a resource from the pool.
acquire() - Method in class alluxio.resource.ResourcePool
Acquires an object of type T from the pool.
acquire(long, TimeUnit) - Method in class alluxio.resource.ResourcePool
Acquires an object of type {code T} from the pool.
acquire(UnderFileSystem, String, long, OpenOptions) - Method in class alluxio.worker.block.UfsInputStreamManager
Acquires an input stream.
acquire(UnderFileSystem, String, long, OpenOptions, boolean) - Method in class alluxio.worker.block.UfsInputStreamManager
Acquires an input stream.
acquireAccess(long, long, Protocol.OpenUfsBlockOptions) - Method in class alluxio.worker.block.UnderFileSystemBlockStore
Acquires access for a UFS block given a UnderFileSystemBlockMeta and the limit on the maximum concurrency on the block.
acquireBlockMasterClientResource() - Method in class alluxio.client.file.FileSystemContext
Acquires a block master client resource from the block master client pool.
acquireMasterClient() - Method in class alluxio.client.file.FileSystemContext
Acquires a file system master client from the file system master client pool.
acquireMasterClient() - Method in enum alluxio.client.lineage.LineageContext
Acquires a lineage master client from the lineage master client pool.
acquireMasterClientResource() - Method in class alluxio.client.file.FileSystemContext
Acquires a file system master client from the file system master client pool.
acquireNettyChannel(WorkerNetAddress) - Method in class alluxio.client.file.FileSystemContext
Acquires a netty channel from the channel pools.
acquireUfsResource() - Method in class alluxio.master.file.meta.MountTable.Resolution
 
acquireUfsResource() - Method in class alluxio.underfs.UfsManager.UfsClient
 
add(T) - Method in class alluxio.collections.ConcurrentHashSet
 
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(AlluxioURI, AlluxioURI, long, MountOptions) - Method in class alluxio.master.file.meta.MountTable
Mounts the given UFS path at the given Alluxio path.
add(Class<W>, T) - Method in class alluxio.Registry
 
add(String) - Method in class alluxio.underfs.ObjectUnderFileSystem.DeleteBuffer
Add a new object to be deleted.
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
 
addAggregator(SingleValueAggregator) - Method in class alluxio.master.metrics.DefaultMetricsMaster
 
addAggregator(MultiValueMetricsAggregator) - Method in class alluxio.master.metrics.DefaultMetricsMaster
 
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;
addAllInputFiles(Iterable<? extends Long>) - Method in class alluxio.proto.journal.Lineage.LineageEntry.Builder
repeated int64 input_files = 2;
addAllOutputFileIds(Iterable<? extends Long>) - Method in class alluxio.proto.journal.Lineage.LineageEntry.Builder
repeated int64 output_file_ids = 3;
addAllProperties(Iterable<? extends File.StringPairEntry>) - Method in class alluxio.proto.journal.File.AddMountPointEntry.Builder
repeated .alluxio.proto.journal.StringPairEntry properties = 4;
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.web.UIFileInfo
Adds a block to the file information.
addBlockIds(long) - Method in class alluxio.proto.journal.File.CompleteFileEntry.Builder
repeated int64 block_ids = 1;
addBlockMeta(BlockMeta) - Method in class alluxio.worker.block.meta.StorageDir
Adds the metadata of a new block into this storage dir.
addBlocks(long) - Method in class alluxio.proto.journal.File.InodeFileEntry.Builder
repeated int64 blocks = 12;
addChild(DirectedAcyclicGraphNode<T>) - Method in class alluxio.collections.DirectedAcyclicGraphNode
Adds a child node to the node.
addChild(Inode<?>) - Method in class alluxio.master.file.meta.InodeDirectory
Adds the given inode to the set of children.
addHandler(AbstractHandler) - Method in class alluxio.web.WebServer
Adds a handler.
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.
addInode(Inode<?>) - Method in class alluxio.master.file.meta.TtlBucket
Adds a inode to the bucket.
addInodeDirectoryFromJournal(File.InodeDirectoryEntry) - Method in class alluxio.master.file.meta.InodeTree
Adds the directory represented by the entry parameter into the inode tree.
addInodeFileFromJournal(File.InodeFileEntry) - Method in class alluxio.master.file.meta.InodeTree
Adds the file represented by the entry parameter into the inode tree.
addInputFiles(long) - Method in class alluxio.proto.journal.Lineage.LineageEntry.Builder
repeated int64 input_files = 2;
addLineageFromJournal(Lineage.LineageEntry) - Method in class alluxio.master.lineage.meta.LineageStore
Constructs the lineage store from the journal.
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.
addOutputFileIds(long) - Method in class alluxio.proto.journal.Lineage.LineageEntry.Builder
repeated int64 output_file_ids = 3;
addParent(DirectedAcyclicGraphNode<T>) - Method in class alluxio.collections.DirectedAcyclicGraphNode
Adds a parent node to the node.
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.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
 
addReference() - Method in class alluxio.worker.block.ClientRWLock
Increments the reference count.
Address - Class in alluxio.wire
The address of a node.
Address() - Constructor for class alluxio.wire.Address
Creates a new instance of Address.
Address(String, int) - Constructor for class alluxio.wire.Address
Creates a new instance of Address.
Address(MasterNetAddress) - Constructor for class alluxio.wire.Address
Creates a new instance of Address from thrift representation.
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.
addTag(String, String) - Method in class alluxio.metrics.Metric
Adds a new tag.
addTempBlockMeta(TempBlockMeta) - Method in class alluxio.worker.block.BlockMetadataManager
Adds a temp block.
addTempBlockMeta(TempBlockMeta) - Method in class alluxio.worker.block.meta.StorageDir
Adds the metadata of a new block into this storage dir.
addTimer(ScheduledTimer) - Static method in class alluxio.heartbeat.HeartbeatScheduler
 
addToAddresses(String) - Method in class alluxio.thrift.GetWorkerReportTOptions
 
addToBlockIds(long) - Method in class alluxio.thrift.FileInfo
 
addToBlockIds(long) - Method in class alluxio.thrift.PersistFile
 
addToChildren(long) - Method in class alluxio.thrift.LineageInfo
 
addToConfigList(ConfigProperty) - Method in class alluxio.thrift.GetConfigurationTResponse
 
addToConfigList(ConfigProperty) - Method in class alluxio.thrift.RegisterMasterTOptions
 
addToConfigList(ConfigProperty) - Method in class alluxio.thrift.RegisterWorkerTOptions
 
addToData(long) - Method in class alluxio.thrift.Command
 
addToFieldRange(WorkerInfoField) - Method in class alluxio.thrift.GetWorkerReportTOptions
 
addToFileBlockInfos(FileBlockInfo) - Method in class alluxio.thrift.FileInfo
 
addToFileInfoList(FileInfo) - Method in class alluxio.thrift.ListStatusTResponse
 
addToFilter(BlockMasterInfoField) - Method in class alluxio.thrift.GetBlockMasterInfoTOptions
 
addToFilter(MasterInfoField) - Method in class alluxio.thrift.GetMasterInfoTOptions
 
addToInconsistentPaths(String) - Method in class alluxio.thrift.CheckConsistencyTResponse
 
addToInputFiles(String) - Method in class alluxio.thrift.LineageInfo
 
addToInputFiles(String) - Method in class alluxio.thrift.LineageMasterClientService.createLineage_args
 
addToKeys(ByteBuffer) - Method in class alluxio.thrift.GetNextKeysTResponse
 
addToLineageInfoList(LineageInfo) - Method in class alluxio.thrift.GetLineageInfoListTResponse
 
addToLocations(BlockLocation) - Method in class alluxio.thrift.BlockInfo
 
addToMasterAddresses(MasterNetAddress) - Method in class alluxio.thrift.MasterInfo
 
addToMetrics(Metric) - Method in class alluxio.thrift.BlockHeartbeatTOptions
 
addToMetrics(long) - Method in class alluxio.thrift.BlockWorkerClientService.sessionBlockHeartbeat_args
 
addToMetrics(long) - Method in class alluxio.thrift.FileSystemWorkerClientService.sessionFileSystemHeartbeat_args
 
addToMetrics(Metric) - Method in class alluxio.thrift.MetricsHeartbeatTOptions
 
addToOutputFiles(String) - Method in class alluxio.thrift.LineageInfo
 
addToOutputFiles(String) - Method in class alluxio.thrift.LineageMasterClientService.createLineage_args
 
addToParents(long) - Method in class alluxio.thrift.LineageInfo
 
addToPartitionInfo(PartitionInfo) - Method in class alluxio.thrift.GetPartitionInfoTResponse
 
addToPersistedFileFingerprints(String) - Method in class alluxio.thrift.FileSystemHeartbeatTOptions
 
addToPersistedFiles(long) - Method in class alluxio.thrift.FileSystemMasterWorkerService.fileSystemHeartbeat_args
 
addToPersistFiles(PersistFile) - Method in class alluxio.thrift.PersistCommandOptions
 
addToPinnedFileIds(long) - Method in class alluxio.thrift.GetPinnedFileIdsTResponse
 
addToRemovedBlockIds(long) - Method in class alluxio.thrift.BlockMasterWorkerService.blockHeartbeat_args
 
addToStorageTiers(String) - Method in class alluxio.thrift.BlockMasterWorkerService.registerWorker_args
 
addToTiers(LocalityTier) - Method in class alluxio.thrift.TieredIdentity
 
addToUfsLocations(WorkerNetAddress) - Method in class alluxio.thrift.FileBlockInfo
 
addToUfsStringLocations(String) - Method in class alluxio.thrift.FileBlockInfo
 
addToWorkerAddresses(MasterNetAddress) - Method in class alluxio.thrift.MasterInfo
 
addToWorkerInfoList(WorkerInfo) - Method in class alluxio.thrift.GetWorkerInfoListTResponse
 
addToZookeeperAddresses(String) - Method in class alluxio.thrift.MasterInfo
 
addValue(double) - Method in class alluxio.metrics.Metric
Add metric value delta to the existing value.
addWorker(long, String) - Method in class alluxio.master.block.meta.MasterBlockInfo
Adds a location of the block.
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.keyvalue.KeyValueMasterClient
 
afterConnect() - Method in class alluxio.client.keyvalue.KeyValueWorkerClient
 
afterConnect() - Method in class alluxio.client.lineage.LineageMasterClient
 
afterConnect() - Method in class alluxio.client.metrics.MetricsMasterClient
 
afterConnect() - Method in class alluxio.client.RetryHandlingMetaMasterClient
 
afterConnect() - Method in class alluxio.master.meta.RetryHandlingMetaMasterMasterClient
 
afterConnect() - Method in class alluxio.worker.block.BlockMasterClient
 
afterConnect() - Method in class alluxio.worker.file.FileSystemMasterClient
 
afterDisconnect() - Method in class alluxio.AbstractClient
This method is called after the connection is disconnected.
AggregateException - Exception in alluxio.exception
Represents a collection of exceptions.
AggregateException(Collection<Exception>) - Constructor for exception alluxio.exception.AggregateException
Creates a new instance of AggregateException.
allClientMetrics() - Static method in class alluxio.metrics.MetricsSystem
 
allMasterMetrics() - Static method in class alluxio.metrics.MetricsSystem
 
allocateBlockWithView(long, long, BlockStoreLocation, BlockMetadataManagerView) - 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, BlockMetadataManagerView) - Method in class alluxio.worker.block.allocator.GreedyAllocator
 
allocateBlockWithView(long, long, BlockStoreLocation, BlockMetadataManagerView) - Method in class alluxio.worker.block.allocator.MaxFreeAllocator
 
allocateBlockWithView(long, long, BlockStoreLocation, BlockMetadataManagerView) - Method in class alluxio.worker.block.allocator.RoundRobinAllocator
 
Allocator - Interface in alluxio.worker.block.allocator
Interface for the allocation policy of Alluxio managed data.
Allocator.Factory - Class in alluxio.worker.block.allocator
Factory for Allocator.
alluxio - package alluxio
 
alluxio.annotation - package alluxio.annotation
 
alluxio.checker - package alluxio.checker
 
alluxio.cli - package alluxio.cli
 
alluxio.cli.extensions - package alluxio.cli.extensions
 
alluxio.cli.extensions.command - package alluxio.cli.extensions.command
 
alluxio.cli.fs - package alluxio.cli.fs
 
alluxio.cli.fs.command - package alluxio.cli.fs.command
 
alluxio.cli.fsadmin - package alluxio.cli.fsadmin
 
alluxio.cli.fsadmin.command - package alluxio.cli.fsadmin.command
 
alluxio.cli.fsadmin.doctor - package alluxio.cli.fsadmin.doctor
 
alluxio.cli.fsadmin.report - package alluxio.cli.fsadmin.report
 
alluxio.cli.validation - package alluxio.cli.validation
 
alluxio.client - package alluxio.client
 
alluxio.client.block - package alluxio.client.block
 
alluxio.client.block.options - package alluxio.client.block.options
 
alluxio.client.block.policy - package alluxio.client.block.policy
 
alluxio.client.block.policy.options - package alluxio.client.block.policy.options
 
alluxio.client.block.stream - package alluxio.client.block.stream
 
alluxio.client.file - package alluxio.client.file
 
alluxio.client.file.options - package alluxio.client.file.options
 
alluxio.client.file.policy - package alluxio.client.file.policy
 
alluxio.client.keyvalue - package alluxio.client.keyvalue
 
alluxio.client.lineage - package alluxio.client.lineage
 
alluxio.client.lineage.options - package alluxio.client.lineage.options
 
alluxio.client.metrics - package alluxio.client.metrics
 
alluxio.clock - package alluxio.clock
 
alluxio.collections - package alluxio.collections
 
alluxio.conf - package alluxio.conf
 
alluxio.examples - package alluxio.examples
 
alluxio.examples.keyvalue - package alluxio.examples.keyvalue
 
alluxio.examples.keyvalue.hadoop - package alluxio.examples.keyvalue.hadoop
 
alluxio.exception - package alluxio.exception
 
alluxio.exception.status - package alluxio.exception.status
 
alluxio.extensions - package alluxio.extensions
 
alluxio.fuse - package alluxio.fuse
 
alluxio.hadoop - package alluxio.hadoop
 
alluxio.hadoop.mapreduce - package alluxio.hadoop.mapreduce
 
alluxio.heartbeat - package alluxio.heartbeat
 
alluxio.job - package alluxio.job
 
alluxio.logserver - package alluxio.logserver
 
alluxio.master - package alluxio.master
 
alluxio.master.audit - package alluxio.master.audit
 
alluxio.master.block - package alluxio.master.block
 
alluxio.master.block.meta - package alluxio.master.block.meta
 
alluxio.master.file - package alluxio.master.file
 
alluxio.master.file.async - package alluxio.master.file.async
 
alluxio.master.file.meta - package alluxio.master.file.meta
 
alluxio.master.file.meta.options - package alluxio.master.file.meta.options
 
alluxio.master.file.options - package alluxio.master.file.options
 
alluxio.master.journal - package alluxio.master.journal
 
alluxio.master.journal.noop - package alluxio.master.journal.noop
 
alluxio.master.journal.options - package alluxio.master.journal.options
 
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.keyvalue - package alluxio.master.keyvalue
 
alluxio.master.lineage - package alluxio.master.lineage
 
alluxio.master.lineage.checkpoint - package alluxio.master.lineage.checkpoint
 
alluxio.master.lineage.meta - package alluxio.master.lineage.meta
 
alluxio.master.lineage.recompute - package alluxio.master.lineage.recompute
 
alluxio.master.meta - package alluxio.master.meta
 
alluxio.master.meta.checkconf - package alluxio.master.meta.checkconf
 
alluxio.master.metrics - package alluxio.master.metrics
 
alluxio.metrics - package alluxio.metrics
 
alluxio.metrics.aggregator - package alluxio.metrics.aggregator
 
alluxio.metrics.sink - package alluxio.metrics.sink
 
alluxio.metrics.source - package alluxio.metrics.source
 
alluxio.multi.process - package alluxio.multi.process
 
alluxio.network - package alluxio.network
 
alluxio.network.netty - package alluxio.network.netty
 
alluxio.network.protocol - package alluxio.network.protocol
 
alluxio.network.protocol.databuffer - package alluxio.network.protocol.databuffer
 
alluxio.network.thrift - package alluxio.network.thrift
 
alluxio.proto.dataserver - package alluxio.proto.dataserver
 
alluxio.proto.journal - package alluxio.proto.journal
 
alluxio.proto.status - package alluxio.proto.status
 
alluxio.proxy - package alluxio.proxy
 
alluxio.proxy.s3 - package alluxio.proxy.s3
 
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.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.thrift - package alluxio.thrift
 
alluxio.time - package alluxio.time
 
alluxio.underfs - package alluxio.underfs
 
alluxio.underfs.cos - package alluxio.underfs.cos
 
alluxio.underfs.gcs - package alluxio.underfs.gcs
 
alluxio.underfs.hdfs - package alluxio.underfs.hdfs
 
alluxio.underfs.local - package alluxio.underfs.local
 
alluxio.underfs.options - package alluxio.underfs.options
 
alluxio.underfs.oss - package alluxio.underfs.oss
 
alluxio.underfs.s3a - package alluxio.underfs.s3a
 
alluxio.underfs.swift - package alluxio.underfs.swift
 
alluxio.underfs.swift.http - package alluxio.underfs.swift.http
 
alluxio.underfs.wasb - package alluxio.underfs.wasb
 
alluxio.util - package alluxio.util
 
alluxio.util.executor - package alluxio.util.executor
 
alluxio.util.interfaces - package alluxio.util.interfaces
 
alluxio.util.io - package alluxio.util.io
 
alluxio.util.logging - package alluxio.util.logging
 
alluxio.util.network - package alluxio.util.network
 
alluxio.util.proto - package alluxio.util.proto
 
alluxio.web - package alluxio.web
 
alluxio.wire - package alluxio.wire
 
alluxio.worker - package alluxio.worker
Worker process and utils for working with the worker remotely.
alluxio.worker.block - package alluxio.worker.block
 
alluxio.worker.block.allocator - package alluxio.worker.block.allocator
 
alluxio.worker.block.evictor - package alluxio.worker.block.evictor
Set of evictors for evicting or moving blocks to other locations.
alluxio.worker.block.io - package alluxio.worker.block.io
 
alluxio.worker.block.meta - package alluxio.worker.block.meta
 
alluxio.worker.file - package alluxio.worker.file
 
alluxio.worker.keyvalue - package alluxio.worker.keyvalue
 
alluxio.worker.netty - package alluxio.worker.netty
 
ALLUXIO_BLOCK_VALUE - Static variable in enum alluxio.proto.dataserver.Protocol.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_JAR - Static variable in class alluxio.RuntimeConstants
The relative path to the Alluxio target jar.
ALLUXIO_JAVADOC_URL - Static variable in class alluxio.RuntimeConstants
The URL of Alluxio javadoc documentation.
ALLUXIO_LOCALITY_SCRIPT - Static variable in class alluxio.Constants
 
ALLUXIO_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_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.
AlluxioConfiguration - Interface in alluxio
Alluxio configuration.
AlluxioException - Exception in alluxio.exception
General AlluxioException used throughout the system.
AlluxioException(AlluxioTException) - Constructor for exception alluxio.exception.AlluxioException
Constructs a AlluxioException with an exception type from a AlluxioTException.
AlluxioException(Throwable) - Constructor for exception alluxio.exception.AlluxioException
Constructs an AlluxioException with the given cause.
AlluxioException(String) - Constructor for exception alluxio.exception.AlluxioException
Constructs an AlluxioException with the given message.
AlluxioException(String, Throwable) - Constructor for exception alluxio.exception.AlluxioException
Constructs an AlluxioException with the given message and cause.
AlluxioFileSystem - Class in alluxio.hadoop
The Alluxio implementation of Hadoop AbstractFileSystem.
AlluxioFrameworkIntegrationTest - Class in alluxio.cli
Integration tests for AlluxioFramework.
AlluxioFuse - Class in alluxio.fuse
Main entry point to Alluxio-FUSE.
AlluxioFuseUtils - Class in alluxio.fuse
Utility methods for Alluxio-FUSE.
AlluxioLineage - Class in alluxio.client.lineage
A LineageClient implementation.
AlluxioLineage(LineageContext) - Constructor for class alluxio.client.lineage.AlluxioLineage
Internal constructor that constructs a new instance with a LineageContext.
AlluxioLog4jSocketNode - Class in alluxio.logserver
Reads LoggingEvent objects from remote logging clients and writes the objects to designated log files.
AlluxioLog4jSocketNode(String, Socket) - Constructor for class alluxio.logserver.AlluxioLog4jSocketNode
Constructor of AlluxioLog4jSocketNode.
AlluxioLoginModule - Class in alluxio.security.login
A login module that search the Kerberos or OS user from Subject, and then convert to an Alluxio user.
AlluxioLoginModule() - Constructor for class alluxio.security.login.AlluxioLoginModule
Constructs a new AlluxioLoginModule.
AlluxioLogServer - Class in alluxio.logserver
Alluxio log server receiving logs pushed from Alluxio servers.
AlluxioLogServerProcess - Class in alluxio.logserver
A centralized log server for Alluxio.
AlluxioLogServerProcess(String) - Constructor for class alluxio.logserver.AlluxioLogServerProcess
Constructs an AlluxioLogServerProcess instance.
AlluxioMaster - Class in alluxio.master
Entry point for the Alluxio master.
AlluxioMasterInfo - Class in alluxio.wire
Alluxio master information.
AlluxioMasterInfo() - Constructor for class alluxio.wire.AlluxioMasterInfo
Creates a new instance of AlluxioMasterInfo.
AlluxioMasterMonitor - Class in alluxio.master
Alluxio master monitor for inquiring the AlluxioMaster service availability.
AlluxioMasterProcess - Class in alluxio.master
This class encapsulates the different master services that are configured to run.
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.proto.journal.File.DeleteFileEntry
 
AlluxioProperties - Class in alluxio.conf
Provides the source of truth of property values and a unified abstraction to put and get properties, hiding the difference of accessing user-specified properties, the default properties (known at construction time) and the extension properties (known at runtime).
AlluxioProperties() - Constructor for class alluxio.conf.AlluxioProperties
Constructs a new instance of Alluxio properties.
AlluxioProperties(AlluxioProperties) - Constructor for class alluxio.conf.AlluxioProperties
 
AlluxioProxy - Class in alluxio.proxy
Entry point for the Alluxio proxy program.
AlluxioProxyInfo - Class in alluxio.wire
Alluxio proxy information.
AlluxioProxyInfo() - Constructor for class alluxio.wire.AlluxioProxyInfo
Creates a new instance of AlluxioProxyInfo.
AlluxioProxyMonitor - Class in alluxio.proxy
Alluxio proxy monitor for inquiring the AlluxioProxy service availability.
AlluxioProxyProcess - Class in alluxio.proxy
This class encapsulates the different worker services that are configured to run.
AlluxioProxyRestServiceHandler - Class in alluxio.proxy
This class is a REST handler for requesting general proxy information.
AlluxioProxyRestServiceHandler(ServletContext) - Constructor for class alluxio.proxy.AlluxioProxyRestServiceHandler
AlluxioReadWorker(int, int, int, ByteBuffer) - 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.
AlluxioService - Class in alluxio.thrift
 
AlluxioService() - Constructor for class alluxio.thrift.AlluxioService
 
AlluxioService.AsyncClient - Class in alluxio.thrift
 
AlluxioService.AsyncClient.Factory - Class in alluxio.thrift
 
AlluxioService.AsyncClient.getServiceVersion_call - Class in alluxio.thrift
 
AlluxioService.AsyncIface - Interface in alluxio.thrift
 
AlluxioService.AsyncProcessor<I extends AlluxioService.AsyncIface> - Class in alluxio.thrift
 
AlluxioService.AsyncProcessor.getServiceVersion<I extends AlluxioService.AsyncIface> - Class in alluxio.thrift
 
AlluxioService.Client - Class in alluxio.thrift
 
AlluxioService.Client.Factory - Class in alluxio.thrift
 
AlluxioService.getServiceVersion_args - Class in alluxio.thrift
 
AlluxioService.getServiceVersion_args._Fields - Enum in alluxio.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
AlluxioService.getServiceVersion_result - Class in alluxio.thrift
 
AlluxioService.getServiceVersion_result._Fields - Enum in alluxio.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
AlluxioService.Iface - Interface in alluxio.thrift
 
AlluxioService.Processor<I extends AlluxioService.Iface> - Class in alluxio.thrift
 
AlluxioService.Processor.getServiceVersion<I extends AlluxioService.Iface> - Class in alluxio.thrift
 
AlluxioStatusException - Exception in alluxio.exception.status
An exception thrown by Alluxio.
AlluxioStatusException(Status, String) - Constructor for exception alluxio.exception.status.AlluxioStatusException
 
AlluxioStatusException(Status, Throwable) - Constructor for exception alluxio.exception.status.AlluxioStatusException
 
AlluxioStatusException(Status, String, Throwable) - Constructor for exception alluxio.exception.status.AlluxioStatusException
 
AlluxioStorageType - Enum in alluxio.client
Specifies the type of data interaction with Alluxio.
AlluxioTException - Exception in alluxio.thrift
 
AlluxioTException() - Constructor for exception alluxio.thrift.AlluxioTException
 
AlluxioTException(String, TStatus) - Constructor for exception alluxio.thrift.AlluxioTException
 
AlluxioTException(AlluxioTException) - Constructor for exception alluxio.thrift.AlluxioTException
Performs a deep copy on other.
AlluxioTException._Fields - Enum in alluxio.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
AlluxioURI - Class in alluxio
This class represents a URI in the Alluxio system.
AlluxioURI(String) - Constructor for class alluxio.AlluxioURI
Constructs an AlluxioURI from a String.
AlluxioURI(String, String, String) - Constructor for class alluxio.AlluxioURI
Constructs an AlluxioURI from components.
AlluxioURI(String, String, String, Map<String, String>) - Constructor for class alluxio.AlluxioURI
Constructs an AlluxioURI from components.
AlluxioURI(AlluxioURI, AlluxioURI) - Constructor for class alluxio.AlluxioURI
Resolves a child AlluxioURI against a parent AlluxioURI.
AlluxioWorker - Class in alluxio.worker
Entry point for the Alluxio worker.
AlluxioWorkerInfo - Class in alluxio.wire
Alluxio worker information.
AlluxioWorkerInfo() - Constructor for class alluxio.wire.AlluxioWorkerInfo
Creates a new instance of AlluxioWorkerInfo.
AlluxioWorkerMonitor - Class in alluxio.worker
Alluxio worker monitor for inquiring AlluxioWorker service availability.
AlluxioWorkerProcess - Class in alluxio.worker
This class encapsulates the different worker services that are configured to run.
AlluxioWorkerRestServiceHandler - Class in alluxio.worker
This class is a REST handler for requesting general worker information.
AlluxioWorkerRestServiceHandler(ServletContext) - Constructor for class alluxio.worker.AlluxioWorkerRestServiceHandler
 
AlluxioWriterWorker(int, int, int, ByteBuffer) - Constructor for class alluxio.examples.Performance.AlluxioWriterWorker
 
allWorkerMetrics() - Static method in class alluxio.metrics.MetricsSystem
 
ALREADY_EXISTS_VALUE - Static variable in enum alluxio.proto.status.Status.PStatus
ALREADY_EXISTS = 6;
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
 
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
 
anyDirInTier(String) - Static method in class alluxio.worker.block.BlockStoreLocation
Convenience method to return the block store location representing any dir in the tier.
anyTier() - Static method in class alluxio.worker.block.BlockStoreLocation
Convenience method to return the block store location representing any dir in any tier.
AppCallbackHandler() - Constructor for class alluxio.security.login.AppLoginModule.AppCallbackHandler
Creates a new instance of AppLoginModule.AppCallbackHandler.
append(AuditContext) - Method in class alluxio.master.audit.AsyncUserAccessAuditLogWriter
Appends an AuditContext.
append(Journal.JournalEntry) - Method in interface alluxio.master.journal.JournalContext
 
append(Journal.JournalEntry) - Method in class alluxio.master.journal.MasterJournalContext
 
append(Journal.JournalEntry) - Method in class alluxio.master.journal.NoopJournalContext
 
append(Journal.JournalEntry) - Method in class alluxio.master.journal.StateChangeJournalContext
 
append(ByteBuffer) - Method in interface alluxio.worker.block.io.BlockWriter
Appends data to the end of a block from an input ByteBuffer.
append(ByteBuf) - Method in interface alluxio.worker.block.io.BlockWriter
Appends buf.readableBytes() bytes to the end of this block writer from the given buf.
append(ByteBuffer) - Method in class alluxio.worker.block.io.LocalFileBlockWriter
 
append(ByteBuf) - Method in class alluxio.worker.block.io.LocalFileBlockWriter
 
appendEntry(Journal.JournalEntry) - Method in class alluxio.master.journal.AsyncJournalWriter
Appends a Journal.JournalEntry for writing to the journal.
appendEntry(Journal.JournalEntry) - Method in class alluxio.master.journalv0.AsyncJournalWriter
Appends a Journal.JournalEntry for writing to the journal.
appendPath(URI, String) - Static method in class alluxio.util.URIUtils
Appends the given path to the given base URI.
appendPathOrDie(URI, String) - Static method in class alluxio.util.URIUtils
Appends the given path to the given base URI.
AppLoginModule - Class in alluxio.security.login
An app login module that creates a user based on the user name provided through application configuration.
AppLoginModule() - Constructor for class alluxio.security.login.AppLoginModule
Constructs a new AppLoginModule.
AppLoginModule.AppCallbackHandler - Class in alluxio.security.login
A callback handler for AppLoginModule.
applyDirectoryUMask() - Method in class alluxio.security.authorization.Mode
Applies the default umask for newly created directories to this mode.
applyFileUMask() - Method in class alluxio.security.authorization.Mode
Applies the default umask for newly created files to this mode.
approximateContentHash(long, long) - Static method in class alluxio.util.UnderFileSystemUtils
Returns an approximate content hash, using the length and modification time.
areDescendantsLoaded() - Method in class alluxio.master.file.meta.InodeDirectory
Before calling this method, the caller should hold at least a READ LOCK on the inode.
argsToString(String, T...) - Static method in class alluxio.util.CommonUtils
Converts varargs of objects to a string.
asAsyncCacheRequest() - Method in class alluxio.util.proto.ProtoMessage
 
asLocalBlockCloseRequest() - Method in class alluxio.util.proto.ProtoMessage
Gets the local block close request or throws runtime exception if mMessage is not of type Protocol.LocalBlockCloseRequest.
asLocalBlockCompleteRequest() - Method in class alluxio.util.proto.ProtoMessage
 
asLocalBlockCreateRequest() - Method in class alluxio.util.proto.ProtoMessage
 
asLocalBlockCreateResponse() - Method in class alluxio.util.proto.ProtoMessage
 
asLocalBlockOpenRequest() - Method in class alluxio.util.proto.ProtoMessage
Gets the local block open request or throws runtime exception if mMessage is not of type Protocol.LocalBlockOpenRequest.
asLocalBlockOpenResponse() - Method in class alluxio.util.proto.ProtoMessage
Gets the local block open response or throws runtime exception if mMessage is not of type Protocol.LocalBlockOpenResponse.
asReadRequest() - Method in class alluxio.util.proto.ProtoMessage
Gets the read request or throws runtime exception if mMessage is not of type Protocol.ReadRequest.
asReadResponse() - Method in class alluxio.util.proto.ProtoMessage
Gets the read response or throws runtime exception if mMessage is not of type Protocol.ReadResponse.
asResponse() - Method in class alluxio.util.proto.ProtoMessage
Gets the response or throws runtime exception if mMessage is not of type Protocol.Response.
assertValidPort(int) - Static method in class alluxio.util.network.NetworkAddressUtils
Checks if the given port is valid.
assertValidPort(InetSocketAddress) - Static method in class alluxio.util.network.NetworkAddressUtils
Checks if the given port in the address is valid.
asWriteRequest() - Method in class alluxio.util.proto.ProtoMessage
Gets the write request or throws runtime exception if mMessage is not of type Protocol.WriteRequest.
ASYNC_CACHE_SESSION_ID - Static variable in class alluxio.Sessions
 
ASYNC_PERSIST_REQUEST_FIELD_NUMBER - Static variable in class alluxio.proto.journal.Journal.JournalEntry
 
AsyncCacheHandler - Class in alluxio.worker.netty
Handler for async cache requests.
AsyncCacheHandler(AsyncCacheRequestManager) - Constructor for class alluxio.worker.netty.AsyncCacheHandler
Constructs a new async cache handler.
AsyncCacheRequestManager - Class in alluxio.worker.block
Handles client requests to asynchronously cache blocks.
AsyncCacheRequestManager(ExecutorService, BlockWorker) - Constructor for class alluxio.worker.block.AsyncCacheRequestManager
 
AsyncClient(TProtocolFactory, TAsyncClientManager, TNonblockingTransport) - Constructor for class alluxio.thrift.AlluxioService.AsyncClient
 
AsyncClient(TProtocolFactory, TAsyncClientManager, TNonblockingTransport) - Constructor for class alluxio.thrift.BlockMasterClientService.AsyncClient
 
AsyncClient(TProtocolFactory, TAsyncClientManager, TNonblockingTransport) - Constructor for class alluxio.thrift.BlockMasterWorkerService.AsyncClient
 
AsyncClient(TProtocolFactory, TAsyncClientManager, TNonblockingTransport) - Constructor for class alluxio.thrift.BlockWorkerClientService.AsyncClient
 
AsyncClient(TProtocolFactory, TAsyncClientManager, TNonblockingTransport) - Constructor for class alluxio.thrift.FileSystemMasterClientService.AsyncClient
 
AsyncClient(TProtocolFactory, TAsyncClientManager, TNonblockingTransport) - Constructor for class alluxio.thrift.FileSystemMasterWorkerService.AsyncClient
 
AsyncClient(TProtocolFactory, TAsyncClientManager, TNonblockingTransport) - Constructor for class alluxio.thrift.FileSystemWorkerClientService.AsyncClient
 
AsyncClient(TProtocolFactory, TAsyncClientManager, TNonblockingTransport) - Constructor for class alluxio.thrift.KeyValueMasterClientService.AsyncClient
 
AsyncClient(TProtocolFactory, TAsyncClientManager, TNonblockingTransport) - Constructor for class alluxio.thrift.KeyValueWorkerClientService.AsyncClient
 
AsyncClient(TProtocolFactory, TAsyncClientManager, TNonblockingTransport) - Constructor for class alluxio.thrift.LineageMasterClientService.AsyncClient
 
AsyncClient(TProtocolFactory, TAsyncClientManager, TNonblockingTransport) - Constructor for class alluxio.thrift.MetaMasterClientService.AsyncClient
 
AsyncClient(TProtocolFactory, TAsyncClientManager, TNonblockingTransport) - Constructor for class alluxio.thrift.MetaMasterMasterService.AsyncClient
 
AsyncClient(TProtocolFactory, TAsyncClientManager, TNonblockingTransport) - Constructor for class alluxio.thrift.MetricsMasterClientService.AsyncClient
 
AsyncJournalWriter - Class in alluxio.master.journal
This enables async journal writing, as well as some batched journal flushing.
AsyncJournalWriter(JournalWriter) - 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
AsyncPersistHandler - Interface in alluxio.master.file.async
The handler that handles the scheduled async persist requests on files, and decides which worker to take the persistence task.
AsyncPersistHandler.Factory - Class in alluxio.master.file.async
Factory for AsyncPersistHandler.
AsyncProcessor(I) - Constructor for class alluxio.thrift.AlluxioService.AsyncProcessor
 
AsyncProcessor(I, Map<String, AsyncProcessFunction<I, ? extends TBase, ?>>) - Constructor for class alluxio.thrift.AlluxioService.AsyncProcessor
 
AsyncProcessor(I) - Constructor for class alluxio.thrift.BlockMasterClientService.AsyncProcessor
 
AsyncProcessor(I, Map<String, AsyncProcessFunction<I, ? extends TBase, ?>>) - Constructor for class alluxio.thrift.BlockMasterClientService.AsyncProcessor
 
AsyncProcessor(I) - Constructor for class alluxio.thrift.BlockMasterWorkerService.AsyncProcessor
 
AsyncProcessor(I, Map<String, AsyncProcessFunction<I, ? extends TBase, ?>>) - Constructor for class alluxio.thrift.BlockMasterWorkerService.AsyncProcessor
 
AsyncProcessor(I) - Constructor for class alluxio.thrift.BlockWorkerClientService.AsyncProcessor
 
AsyncProcessor(I, Map<String, AsyncProcessFunction<I, ? extends TBase, ?>>) - Constructor for class alluxio.thrift.BlockWorkerClientService.AsyncProcessor
 
AsyncProcessor(I) - Constructor for class alluxio.thrift.FileSystemMasterClientService.AsyncProcessor
 
AsyncProcessor(I, Map<String, AsyncProcessFunction<I, ? extends TBase, ?>>) - Constructor for class alluxio.thrift.FileSystemMasterClientService.AsyncProcessor
 
AsyncProcessor(I) - Constructor for class alluxio.thrift.FileSystemMasterWorkerService.AsyncProcessor
 
AsyncProcessor(I, Map<String, AsyncProcessFunction<I, ? extends TBase, ?>>) - Constructor for class alluxio.thrift.FileSystemMasterWorkerService.AsyncProcessor
 
AsyncProcessor(I) - Constructor for class alluxio.thrift.FileSystemWorkerClientService.AsyncProcessor
 
AsyncProcessor(I, Map<String, AsyncProcessFunction<I, ? extends TBase, ?>>) - Constructor for class alluxio.thrift.FileSystemWorkerClientService.AsyncProcessor
 
AsyncProcessor(I) - Constructor for class alluxio.thrift.KeyValueMasterClientService.AsyncProcessor
 
AsyncProcessor(I, Map<String, AsyncProcessFunction<I, ? extends TBase, ?>>) - Constructor for class alluxio.thrift.KeyValueMasterClientService.AsyncProcessor
 
AsyncProcessor(I) - Constructor for class alluxio.thrift.KeyValueWorkerClientService.AsyncProcessor
 
AsyncProcessor(I, Map<String, AsyncProcessFunction<I, ? extends TBase, ?>>) - Constructor for class alluxio.thrift.KeyValueWorkerClientService.AsyncProcessor
 
AsyncProcessor(I) - Constructor for class alluxio.thrift.LineageMasterClientService.AsyncProcessor
 
AsyncProcessor(I, Map<String, AsyncProcessFunction<I, ? extends TBase, ?>>) - Constructor for class alluxio.thrift.LineageMasterClientService.AsyncProcessor
 
AsyncProcessor(I) - Constructor for class alluxio.thrift.MetaMasterClientService.AsyncProcessor
 
AsyncProcessor(I, Map<String, AsyncProcessFunction<I, ? extends TBase, ?>>) - Constructor for class alluxio.thrift.MetaMasterClientService.AsyncProcessor
 
AsyncProcessor(I) - Constructor for class alluxio.thrift.MetaMasterMasterService.AsyncProcessor
 
AsyncProcessor(I, Map<String, AsyncProcessFunction<I, ? extends TBase, ?>>) - Constructor for class alluxio.thrift.MetaMasterMasterService.AsyncProcessor
 
AsyncProcessor(I) - Constructor for class alluxio.thrift.MetricsMasterClientService.AsyncProcessor
 
AsyncProcessor(I, Map<String, AsyncProcessFunction<I, ? extends TBase, ?>>) - Constructor for class alluxio.thrift.MetricsMasterClientService.AsyncProcessor
 
AsyncUfsAbsentPathCache - Class in alluxio.master.file.meta
This is a UfsAbsentPathCache which implements asynchronous addition and removal to the cache, since the processing of the path may be slow.
AsyncUfsAbsentPathCache(MountTable, int) - Constructor for class alluxio.master.file.meta.AsyncUfsAbsentPathCache
Creates a new instance of AsyncUfsAbsentPathCache.
AsyncUserAccessAuditLogWriter - Class in alluxio.master.audit
AsyncUserAccessAuditLogWriter writes user access audit log entries asynchronously.
AsyncUserAccessAuditLogWriter() - Constructor for class alluxio.master.audit.AsyncUserAccessAuditLogWriter
Constructs an AsyncUserAccessAuditLogWriter instance.
AtomicFileOutputStream - Class in alluxio.underfs
A AtomicFileOutputStream writes to a temporary file and renames on close.
AtomicFileOutputStream(String, AtomicFileOutputStreamCallback, CreateOptions) - Constructor for class alluxio.underfs.AtomicFileOutputStream
Constructs a new AtomicFileOutputStream.
AtomicFileOutputStreamCallback - Interface in alluxio.underfs
A AtomicFileOutputStreamCallback is the callback interface used when using a AtomicFileOutputStream.
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(String, String) - Method in interface alluxio.security.authentication.AuthenticationProvider
The authenticate method is called by the PlainSaslServerCallbackHandler in the PlainSaslServer layer to authenticate users for their requests.
authenticate(String, String) - Method in class alluxio.security.authentication.CustomAuthenticationProvider
 
authenticate(String, String) - Method in class alluxio.security.authentication.ImpersonationAuthenticator
 
authenticate(String, String) - Method in class alluxio.security.authentication.SimpleAuthenticationProvider
 
authenticate() - Method in class alluxio.underfs.swift.KeystoneV3AccessProvider
 
AuthenticatedClientUser - Class in alluxio.security.authentication
An instance of this class represents a client user connecting to PlainSaslServer.
AuthenticationProvider - Interface in alluxio.security.authentication
Abstraction for an authentication provider at SASL server for AuthType.SIMPLE and AuthType.CUSTOM.
AuthenticationProvider.Factory - Class in alluxio.security.authentication
AuthType - Enum in alluxio.security.authentication
Different authentication types for Alluxio.
available() - Method in class alluxio.hadoop.HdfsFileInputStream
 
available() - Static method in class alluxio.underfs.UnderFileSystemFactoryRegistry
Returns a read-only view of the available base factories.
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.
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
 

B

backup(String, boolean) - Method in interface alluxio.client.MetaMasterClient
Writes a backup of the journal to the specified directory.
backup(String, boolean) - Method in class alluxio.client.RetryHandlingMetaMasterClient
 
backup(OutputStream, AtomicLong) - Method in class alluxio.master.BackupManager
Writes a backup to the specified stream.
backup(BackupOptions) - Method in class alluxio.master.meta.DefaultMetaMaster
 
backup(BackupOptions) - Method in interface alluxio.master.meta.MetaMaster
Backs up the master.
backup(BackupTOptions) - Method in class alluxio.master.meta.MetaMasterClientServiceHandler
 
backup(BackupTOptions, AsyncMethodCallback) - Method in class alluxio.thrift.MetaMasterClientService.AsyncClient
 
backup(BackupTOptions, AsyncMethodCallback) - Method in interface alluxio.thrift.MetaMasterClientService.AsyncIface
 
backup() - Constructor for class alluxio.thrift.MetaMasterClientService.AsyncProcessor.backup
 
backup(BackupTOptions) - Method in class alluxio.thrift.MetaMasterClientService.Client
 
backup(BackupTOptions) - Method in interface alluxio.thrift.MetaMasterClientService.Iface
Backs up the Alluxio master to the specified URI
backup() - Constructor for class alluxio.thrift.MetaMasterClientService.Processor.backup
 
backup_args() - Constructor for class alluxio.thrift.MetaMasterClientService.backup_args
 
backup_args(BackupTOptions) - Constructor for class alluxio.thrift.MetaMasterClientService.backup_args
 
backup_args(MetaMasterClientService.backup_args) - Constructor for class alluxio.thrift.MetaMasterClientService.backup_args
Performs a deep copy on other.
backup_call(BackupTOptions, AsyncMethodCallback, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class alluxio.thrift.MetaMasterClientService.AsyncClient.backup_call
 
BACKUP_FILE_FORMAT - Static variable in class alluxio.master.BackupManager
The name format of the backup files (E.g., alluxio-backup-2018-12-14-1544749081561.gz).
BACKUP_FILE_PATTERN - Static variable in class alluxio.master.BackupManager
 
BACKUP_RESTORE_SINGLE - Static variable in class alluxio.multi.process.PortCoordination
 
BACKUP_RESTORE_ZK - Static variable in class alluxio.multi.process.PortCoordination
 
backup_result() - Constructor for class alluxio.thrift.MetaMasterClientService.backup_result
 
backup_result(BackupTResponse, AlluxioTException) - Constructor for class alluxio.thrift.MetaMasterClientService.backup_result
 
backup_result(MetaMasterClientService.backup_result) - Constructor for class alluxio.thrift.MetaMasterClientService.backup_result
Performs a deep copy on other.
BackupCommand - Class in alluxio.cli.fsadmin.command
Command for backing up Alluxio master metadata.
BackupCommand(Context) - Constructor for class alluxio.cli.fsadmin.command.BackupCommand
 
BackupManager - Class in alluxio.master
Manages creating and restoring from backups.
BackupManager(MasterRegistry) - Constructor for class alluxio.master.BackupManager
 
BackupOptions - Class in alluxio.wire
Options for backing up the Alluxio master.
BackupOptions(String, boolean) - Constructor for class alluxio.wire.BackupOptions
 
BackupResponse - Class in alluxio.wire
Response for the backup RPC.
BackupResponse(AlluxioURI, String, long) - Constructor for class alluxio.wire.BackupResponse
 
BackupTOptions - Class in alluxio.thrift
 
BackupTOptions() - Constructor for class alluxio.thrift.BackupTOptions
 
BackupTOptions(String, boolean) - Constructor for class alluxio.thrift.BackupTOptions
 
BackupTOptions(BackupTOptions) - Constructor for class alluxio.thrift.BackupTOptions
Performs a deep copy on other.
BackupTOptions._Fields - Enum in alluxio.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
BackupTResponse - Class in alluxio.thrift
 
BackupTResponse() - Constructor for class alluxio.thrift.BackupTResponse
 
BackupTResponse(String, String, long) - Constructor for class alluxio.thrift.BackupTResponse
 
BackupTResponse(BackupTResponse) - Constructor for class alluxio.thrift.BackupTResponse
Performs a deep copy on other.
BackupTResponse._Fields - Enum in alluxio.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
BAD_DIGEST - Static variable in class alluxio.proxy.s3.S3ErrorCode
 
BAD_DIGEST - Static variable in class alluxio.proxy.s3.S3ErrorCode.Name
 
BaseFileSystem - Class in alluxio.client.file
Default implementation of the FileSystem interface.
BaseFileSystem(FileSystemContext) - Constructor for class alluxio.client.file.BaseFileSystem
Constructs a new base file system.
BaseKeyValueSystem - Class in alluxio.client.keyvalue
Default implementation of the KeyValueSystem interface.
BaseKeyValueSystem() - Constructor for class alluxio.client.keyvalue.BaseKeyValueSystem
Constructs a new BaseKeyValueSystem.
BaseUnderFileSystem - Class in alluxio.underfs
A base abstract UnderFileSystem.
BaseUnderFileSystem(AlluxioURI, UnderFileSystemConfiguration) - Constructor for class alluxio.underfs.BaseUnderFileSystem
Constructs an BaseUnderFileSystem.
BasicCheckpoint - Class in alluxio.examples
An example to show to how use Alluxio's API.
BasicCheckpoint(String, int) - Constructor for class alluxio.examples.BasicCheckpoint
 
BasicNonByteBufferOperations - Class in alluxio.examples
Basic example of using the FileSystem for writing to and reading from files.
BasicNonByteBufferOperations(AlluxioURI, ReadType, WriteType, boolean, int) - Constructor for class alluxio.examples.BasicNonByteBufferOperations
 
BasicOperations - Class in alluxio.examples
Example to show the basic operations of Alluxio.
BasicOperations(AlluxioURI, ReadType, WriteType) - Constructor for class alluxio.examples.BasicOperations
 
beforeDisconnect() - Method in class alluxio.AbstractClient
This method is called before the connection is disconnected.
belongsTo(BlockStoreLocation) - Method in class alluxio.worker.block.BlockStoreLocation
Returns whether this location belongs to the specific location.
Block - Class in alluxio.proto.journal
 
Block.BlockContainerIdGeneratorEntry - Class in alluxio.proto.journal
Protobuf type alluxio.proto.journal.BlockContainerIdGeneratorEntry
Block.BlockContainerIdGeneratorEntry.Builder - Class in alluxio.proto.journal
Protobuf type alluxio.proto.journal.BlockContainerIdGeneratorEntry
Block.BlockContainerIdGeneratorEntryOrBuilder - Interface in alluxio.proto.journal
 
Block.BlockInfoEntry - Class in alluxio.proto.journal
Protobuf type alluxio.proto.journal.BlockInfoEntry
Block.BlockInfoEntry.Builder - Class in alluxio.proto.journal
Protobuf type alluxio.proto.journal.BlockInfoEntry
Block.BlockInfoEntryOrBuilder - Interface in alluxio.proto.journal
 
Block.DeleteBlockEntry - Class in alluxio.proto.journal
Protobuf type alluxio.proto.journal.DeleteBlockEntry
Block.DeleteBlockEntry.Builder - Class in alluxio.proto.journal
Protobuf type alluxio.proto.journal.DeleteBlockEntry
Block.DeleteBlockEntryOrBuilder - Interface in alluxio.proto.journal
 
BLOCK_CONTAINER_ID_GENERATOR_FIELD_NUMBER - Static variable in class alluxio.proto.journal.Journal.JournalEntry
 
BLOCK_ID_FIELD_NUMBER - Static variable in class alluxio.proto.dataserver.Protocol.AsyncCacheRequest
 
BLOCK_ID_FIELD_NUMBER - Static variable in class alluxio.proto.dataserver.Protocol.LocalBlockCloseRequest
 
BLOCK_ID_FIELD_NUMBER - Static variable in class alluxio.proto.dataserver.Protocol.LocalBlockCompleteRequest
 
BLOCK_ID_FIELD_NUMBER - Static variable in class alluxio.proto.dataserver.Protocol.LocalBlockCreateRequest
 
BLOCK_ID_FIELD_NUMBER - Static variable in class alluxio.proto.dataserver.Protocol.LocalBlockOpenRequest
 
BLOCK_ID_FIELD_NUMBER - Static variable in class alluxio.proto.dataserver.Protocol.ReadRequest
 
BLOCK_ID_FIELD_NUMBER - Static variable in class alluxio.proto.journal.Block.BlockInfoEntry
 
BLOCK_ID_FIELD_NUMBER - Static variable in class alluxio.proto.journal.Block.DeleteBlockEntry
 
BLOCK_ID_FIELD_NUMBER - Static variable in class alluxio.proto.journal.KeyValue.CompletePartitionEntry
 
BLOCK_IDS_FIELD_NUMBER - Static variable in class alluxio.proto.journal.File.CompleteFileEntry
 
BLOCK_INFO_FIELD_NUMBER - Static variable in class alluxio.proto.journal.Journal.JournalEntry
 
BLOCK_MASTER_CLIENT_SERVICE_NAME - Static variable in class alluxio.Constants
 
BLOCK_MASTER_CLIENT_SERVICE_VERSION - Static variable in class alluxio.Constants
 
BLOCK_MASTER_NAME - Static variable in class alluxio.Constants
 
BLOCK_MASTER_WORKER_SERVICE_NAME - Static variable in class alluxio.Constants
 
BLOCK_MASTER_WORKER_SERVICE_VERSION - Static variable in class alluxio.Constants
 
BLOCK_SIZE_BYTES_FIELD_NUMBER - Static variable in class alluxio.proto.journal.File.InodeFileEntry
 
BLOCK_SIZE_BYTES_FIELD_NUMBER - Static variable in class alluxio.proto.journal.File.ReinitializeFileEntry
 
BLOCK_SIZE_FIELD_NUMBER - Static variable in class alluxio.proto.dataserver.Protocol.OpenUfsBlockOptions
 
BLOCK_WORKER_CLIENT_SERVICE_NAME - Static variable in class alluxio.Constants
 
BLOCK_WORKER_CLIENT_SERVICE_VERSION - Static variable in class alluxio.Constants
 
BLOCK_WORKER_NAME - Static variable in class alluxio.Constants
 
BlockAlreadyExistsException - Exception in alluxio.exception
The exception thrown when a block already exists in Alluxio.
BlockAlreadyExistsException(String) - Constructor for exception alluxio.exception.BlockAlreadyExistsException
Constructs a new exception with the specified detail message.
BlockAlreadyExistsException(String, Throwable) - Constructor for exception alluxio.exception.BlockAlreadyExistsException
Constructs a new exception with the specified detail message and cause.
BlockAlreadyExistsException(ExceptionMessage, Object...) - Constructor for exception alluxio.exception.BlockAlreadyExistsException
Constructs a new exception with the specified exception message and multiple parameters.
BlockAlreadyExistsException(ExceptionMessage, Throwable, Object...) - Constructor for exception alluxio.exception.BlockAlreadyExistsException
Constructs a new exception with the specified exception message, the cause and multiple parameters.
BlockContainerIdGenerator - Class in alluxio.master.block
This class generates unique block container ids.
BlockContainerIdGenerator() - Constructor for class alluxio.master.block.BlockContainerIdGenerator
Creates a new instance of BlockContainerIdGenerator.
BlockDeletionContext - Interface in alluxio.master.file
Interface for a class which gathers block deletion requests, then handles them during close.
BlockDeletionContext.BlockDeletionListener - Interface in alluxio.master.file
Interface for block deletion listeners.
BlockDoesNotExistException - Exception in alluxio.exception
The exception thrown when a block does not exist in Alluxio.
BlockDoesNotExistException(String) - Constructor for exception alluxio.exception.BlockDoesNotExistException
Constructs a new exception with the specified detail message.
BlockDoesNotExistException(String, Throwable) - Constructor for exception alluxio.exception.BlockDoesNotExistException
Constructs a new exception with the specified detail message and cause.
BlockDoesNotExistException(ExceptionMessage, Object...) - Constructor for exception alluxio.exception.BlockDoesNotExistException
Constructs a new exception with the specified exception message and multiple parameters.
BlockDoesNotExistException(ExceptionMessage, Throwable, Object...) - Constructor for exception alluxio.exception.BlockDoesNotExistException
Constructs a new exception with the specified exception message, the cause and multiple parameters.
blockHeartbeat(long, Map<String, Long>, List<Long>, Map<String, List<Long>>, BlockHeartbeatTOptions) - Method in class alluxio.master.block.BlockMasterWorkerServiceHandler
 
blockHeartbeat(long, Map<String, Long>, List<Long>, Map<String, List<Long>>, BlockHeartbeatTOptions, AsyncMethodCallback) - Method in class alluxio.thrift.BlockMasterWorkerService.AsyncClient
 
blockHeartbeat(long, Map<String, Long>, List<Long>, Map<String, List<Long>>, BlockHeartbeatTOptions, AsyncMethodCallback) - Method in interface alluxio.thrift.BlockMasterWorkerService.AsyncIface
 
blockHeartbeat() - Constructor for class alluxio.thrift.BlockMasterWorkerService.AsyncProcessor.blockHeartbeat
 
blockHeartbeat(long, Map<String, Long>, List<Long>, Map<String, List<Long>>, BlockHeartbeatTOptions) - Method in class alluxio.thrift.BlockMasterWorkerService.Client
 
blockHeartbeat(long, Map<String, Long>, List<Long>, Map<String, List<Long>>, BlockHeartbeatTOptions) - Method in interface alluxio.thrift.BlockMasterWorkerService.Iface
Periodic block worker heartbeat returns an optional command for the block worker to execute.
blockHeartbeat() - Constructor for class alluxio.thrift.BlockMasterWorkerService.Processor.blockHeartbeat
 
blockHeartbeat_args() - Constructor for class alluxio.thrift.BlockMasterWorkerService.blockHeartbeat_args
 
blockHeartbeat_args(long, Map<String, Long>, List<Long>, Map<String, List<Long>>, BlockHeartbeatTOptions) - Constructor for class alluxio.thrift.BlockMasterWorkerService.blockHeartbeat_args
 
blockHeartbeat_args(BlockMasterWorkerService.blockHeartbeat_args) - Constructor for class alluxio.thrift.BlockMasterWorkerService.blockHeartbeat_args
Performs a deep copy on other.
blockHeartbeat_call(long, Map<String, Long>, List<Long>, Map<String, List<Long>>, BlockHeartbeatTOptions, AsyncMethodCallback, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class alluxio.thrift.BlockMasterWorkerService.AsyncClient.blockHeartbeat_call
 
blockHeartbeat_result() - Constructor for class alluxio.thrift.BlockMasterWorkerService.blockHeartbeat_result
 
blockHeartbeat_result(BlockHeartbeatTResponse, AlluxioTException) - Constructor for class alluxio.thrift.BlockMasterWorkerService.blockHeartbeat_result
 
blockHeartbeat_result(BlockMasterWorkerService.blockHeartbeat_result) - Constructor for class alluxio.thrift.BlockMasterWorkerService.blockHeartbeat_result
Performs a deep copy on other.
BlockHeartbeatReport - Class in alluxio.worker.block
Container for the delta information in each worker to master heartbeat.
BlockHeartbeatReport(Map<String, List<Long>>, List<Long>) - Constructor for class alluxio.worker.block.BlockHeartbeatReport
Creates a new instance of BlockHeartbeatReport.
BlockHeartbeatReporter - Class in alluxio.worker.block
Represents the delta of the block store within one heartbeat period.
BlockHeartbeatReporter() - Constructor for class alluxio.worker.block.BlockHeartbeatReporter
Creates a new instance of BlockHeartbeatReporter.
BlockHeartbeatTOptions - Class in alluxio.thrift
 
BlockHeartbeatTOptions() - Constructor for class alluxio.thrift.BlockHeartbeatTOptions
 
BlockHeartbeatTOptions(List<Metric>) - Constructor for class alluxio.thrift.BlockHeartbeatTOptions
 
BlockHeartbeatTOptions(BlockHeartbeatTOptions) - Constructor for class alluxio.thrift.BlockHeartbeatTOptions
Performs a deep copy on other.
BlockHeartbeatTOptions._Fields - Enum in alluxio.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
BlockHeartbeatTResponse - Class in alluxio.thrift
 
BlockHeartbeatTResponse() - Constructor for class alluxio.thrift.BlockHeartbeatTResponse
 
BlockHeartbeatTResponse(Command) - Constructor for class alluxio.thrift.BlockHeartbeatTResponse
 
BlockHeartbeatTResponse(BlockHeartbeatTResponse) - Constructor for class alluxio.thrift.BlockHeartbeatTResponse
Performs a deep copy on other.
BlockHeartbeatTResponse._Fields - Enum in alluxio.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
BlockId - Class in alluxio.master.block
This class provides a set of methods related to block IDs.
BlockInfo - Class in alluxio.thrift
 
BlockInfo() - Constructor for class alluxio.thrift.BlockInfo
 
BlockInfo(long, long, List<BlockLocation>) - Constructor for class alluxio.thrift.BlockInfo
 
BlockInfo(BlockInfo) - Constructor for class alluxio.thrift.BlockInfo
Performs a deep copy on other.
BlockInfo - Class in alluxio.wire
The block information.
BlockInfo() - Constructor for class alluxio.wire.BlockInfo
Creates a new instance of BlockInfo.
BlockInfo._Fields - Enum in alluxio.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
BlockInfoException - Exception in alluxio.exception
The exception thrown when something with the block goes wrong, i.e.
BlockInfoException(String) - Constructor for exception alluxio.exception.BlockInfoException
Constructs a new exception with the specified detail message.
BlockInfoException(String, Throwable) - Constructor for exception alluxio.exception.BlockInfoException
Constructs a new exception with the specified detail message and cause.
BlockInfoException(ExceptionMessage, Object...) - Constructor for exception alluxio.exception.BlockInfoException
Constructs a new exception with the specified exception message and multiple parameters.
BlockInfoException(ExceptionMessage, Throwable, Object...) - Constructor for exception alluxio.exception.BlockInfoException
Constructs a new exception with the specified exception message, the cause and multiple parameters.
BlockInStream - Class in alluxio.client.block.stream
Provides an InputStream implementation that is based on PacketReaders to stream data packet by packet.
BlockInStream(PacketReader.Factory, WorkerNetAddress, BlockInStream.BlockInStreamSource, long, long) - Constructor for class alluxio.client.block.stream.BlockInStream
Creates an instance of BlockInStream.
BlockInStream.BlockInStreamSource - Enum in alluxio.client.block.stream
the source tracking where the block is from.
BlockIntegrityChecker - Class in alluxio.master.file
Heartbeat executor for validating inode and block integrity.
BlockIntegrityChecker(FileSystemMaster) - Constructor for class alluxio.master.file.BlockIntegrityChecker
Constructs a block integrity checker based on the given FileSystemMaster.
BlockLocation - Class in alluxio.thrift
 
BlockLocation() - Constructor for class alluxio.thrift.BlockLocation
 
BlockLocation(long, WorkerNetAddress, String) - Constructor for class alluxio.thrift.BlockLocation
 
BlockLocation(BlockLocation) - Constructor for class alluxio.thrift.BlockLocation
Performs a deep copy on other.
BlockLocation - Class in alluxio.wire
The location of a block.
BlockLocation() - Constructor for class alluxio.wire.BlockLocation
Creates a new instance of BlockLocation.
BlockLocation._Fields - Enum in alluxio.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
BlockLocationPolicy - Interface in alluxio.client.block.policy
Interface for determining the Alluxio worker location to serve a block write or UFS block read.
BlockLocationPolicy.Factory - Class in alluxio.client.block.policy
The factory for the BlockLocationPolicy.
BlockLockManager - Class in alluxio.worker.block
Handle all block locks.
BlockLockManager() - Constructor for class alluxio.worker.block.BlockLockManager
Constructs a new BlockLockManager.
BlockLockType - Enum in alluxio.worker.block
A read-write lock to guard one block.
BlockMaster - Interface in alluxio.master.block
Interface of the block master that manages the metadata for all the blocks and block workers in Alluxio.
BlockMasterClient - Interface in alluxio.client.block
A client to use for interacting with a block master.
BlockMasterClient - Class in alluxio.worker.block
A wrapper for the thrift client to interact with the block master, used by alluxio worker.
BlockMasterClient(MasterClientConfig) - Constructor for class alluxio.worker.block.BlockMasterClient
Creates a new instance of BlockMasterClient for the worker.
BlockMasterClient.Factory - Class in alluxio.client.block
Factory for BlockMasterClient.
BlockMasterClientPool - Class in alluxio.client.block
Class for managing block master clients.
BlockMasterClientPool(Subject, MasterInquireClient) - Constructor for class alluxio.client.block.BlockMasterClientPool
Creates a new block master client pool.
BlockMasterClientPool - Class in alluxio.worker.block
Class for managing block master clients.
BlockMasterClientPool() - Constructor for class alluxio.worker.block.BlockMasterClientPool
Creates a new block master client pool.
BlockMasterClientRestServiceHandler - Class in alluxio.master.block
Deprecated.
since version 1.4 and will be removed in version 2.0
BlockMasterClientRestServiceHandler(ServletContext) - Constructor for class alluxio.master.block.BlockMasterClientRestServiceHandler
Deprecated.
BlockMasterClientService - Class in alluxio.thrift
 
BlockMasterClientService() - Constructor for class alluxio.thrift.BlockMasterClientService
 
BlockMasterClientService.AsyncClient - Class in alluxio.thrift
 
BlockMasterClientService.AsyncClient.Factory - Class in alluxio.thrift
 
BlockMasterClientService.AsyncClient.getBlockInfo_call - Class in alluxio.thrift
 
BlockMasterClientService.AsyncClient.getBlockMasterInfo_call - Class in alluxio.thrift
 
BlockMasterClientService.AsyncClient.getCapacityBytes_call - Class in alluxio.thrift
 
BlockMasterClientService.AsyncClient.getUsedBytes_call - Class in alluxio.thrift
 
BlockMasterClientService.AsyncClient.getWorkerInfoList_call - Class in alluxio.thrift
 
BlockMasterClientService.AsyncClient.getWorkerReport_call - Class in alluxio.thrift
 
BlockMasterClientService.AsyncIface - Interface in alluxio.thrift
 
BlockMasterClientService.AsyncProcessor<I extends BlockMasterClientService.AsyncIface> - Class in alluxio.thrift
 
BlockMasterClientService.AsyncProcessor.getBlockInfo<I extends BlockMasterClientService.AsyncIface> - Class in alluxio.thrift
 
BlockMasterClientService.AsyncProcessor.getBlockMasterInfo<I extends BlockMasterClientService.AsyncIface> - Class in alluxio.thrift
 
BlockMasterClientService.AsyncProcessor.getCapacityBytes<I extends BlockMasterClientService.AsyncIface> - Class in alluxio.thrift
 
BlockMasterClientService.AsyncProcessor.getUsedBytes<I extends BlockMasterClientService.AsyncIface> - Class in alluxio.thrift
 
BlockMasterClientService.AsyncProcessor.getWorkerInfoList<I extends BlockMasterClientService.AsyncIface> - Class in alluxio.thrift
 
BlockMasterClientService.AsyncProcessor.getWorkerReport<I extends BlockMasterClientService.AsyncIface> - Class in alluxio.thrift
 
BlockMasterClientService.Client - Class in alluxio.thrift
 
BlockMasterClientService.Client.Factory - Class in alluxio.thrift
 
BlockMasterClientService.getBlockInfo_args - Class in alluxio.thrift
 
BlockMasterClientService.getBlockInfo_args._Fields - Enum in alluxio.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
BlockMasterClientService.getBlockInfo_result - Class in alluxio.thrift
 
BlockMasterClientService.getBlockInfo_result._Fields - Enum in alluxio.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
BlockMasterClientService.getBlockMasterInfo_args - Class in alluxio.thrift
 
BlockMasterClientService.getBlockMasterInfo_args._Fields - Enum in alluxio.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
BlockMasterClientService.getBlockMasterInfo_result - Class in alluxio.thrift
 
BlockMasterClientService.getBlockMasterInfo_result._Fields - Enum in alluxio.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
BlockMasterClientService.getCapacityBytes_args - Class in alluxio.thrift
 
BlockMasterClientService.getCapacityBytes_args._Fields - Enum in alluxio.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
BlockMasterClientService.getCapacityBytes_result - Class in alluxio.thrift
 
BlockMasterClientService.getCapacityBytes_result._Fields - Enum in alluxio.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
BlockMasterClientService.getUsedBytes_args - Class in alluxio.thrift
 
BlockMasterClientService.getUsedBytes_args._Fields - Enum in alluxio.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
BlockMasterClientService.getUsedBytes_result - Class in alluxio.thrift
 
BlockMasterClientService.getUsedBytes_result._Fields - Enum in alluxio.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
BlockMasterClientService.getWorkerInfoList_args - Class in alluxio.thrift
 
BlockMasterClientService.getWorkerInfoList_args._Fields - Enum in alluxio.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
BlockMasterClientService.getWorkerInfoList_result - Class in alluxio.thrift
 
BlockMasterClientService.getWorkerInfoList_result._Fields - Enum in alluxio.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
BlockMasterClientService.getWorkerReport_args - Class in alluxio.thrift
 
BlockMasterClientService.getWorkerReport_args._Fields - Enum in alluxio.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
BlockMasterClientService.getWorkerReport_result - Class in alluxio.thrift
 
BlockMasterClientService.getWorkerReport_result._Fields - Enum in alluxio.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
BlockMasterClientService.Iface - Interface in alluxio.thrift
This interface contains block master service endpoints for Alluxio clients.
BlockMasterClientService.Processor<I extends BlockMasterClientService.Iface> - Class in alluxio.thrift
 
BlockMasterClientService.Processor.getBlockInfo<I extends BlockMasterClientService.Iface> - Class in alluxio.thrift
 
BlockMasterClientService.Processor.getBlockMasterInfo<I extends BlockMasterClientService.Iface> - Class in alluxio.thrift
 
BlockMasterClientService.Processor.getCapacityBytes<I extends BlockMasterClientService.Iface> - Class in alluxio.thrift
 
BlockMasterClientService.Processor.getUsedBytes<I extends BlockMasterClientService.Iface> - Class in alluxio.thrift
 
BlockMasterClientService.Processor.getWorkerInfoList<I extends BlockMasterClientService.Iface> - Class in alluxio.thrift
 
BlockMasterClientService.Processor.getWorkerReport<I extends BlockMasterClientService.Iface> - Class in alluxio.thrift
 
BlockMasterClientServiceHandler - Class in alluxio.master.block
This class is a Thrift handler for block master RPCs invoked by an Alluxio client.
BlockMasterFactory - Class in alluxio.master.block
Factory to create a BlockMaster instance.
BlockMasterFactory() - Constructor for class alluxio.master.block.BlockMasterFactory
Constructs a new BlockMasterFactory.
BlockMasterInfo - Class in alluxio.thrift
 
BlockMasterInfo() - Constructor for class alluxio.thrift.BlockMasterInfo
 
BlockMasterInfo(long, Map<String, Long>, long, int, int, long, Map<String, Long>) - Constructor for class alluxio.thrift.BlockMasterInfo
 
BlockMasterInfo(BlockMasterInfo) - Constructor for class alluxio.thrift.BlockMasterInfo
Performs a deep copy on other.
BlockMasterInfo - Class in alluxio.wire
The Alluxio block master information.
BlockMasterInfo() - Constructor for class alluxio.wire.BlockMasterInfo
Creates a new instance of BlockMasterInfo.
BlockMasterInfo._Fields - Enum in alluxio.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
BlockMasterInfo.BlockMasterInfoField - Enum in alluxio.wire
Enum representing the fields of the block master info.
BlockMasterInfoField - Enum in alluxio.thrift
 
BlockMasterSync - Class in alluxio.worker.block
Task that carries out the necessary block worker to master communications, including register and heartbeat.
BlockMasterWorkerService - Class in alluxio.thrift
 
BlockMasterWorkerService() - Constructor for class alluxio.thrift.BlockMasterWorkerService
 
BlockMasterWorkerService.AsyncClient - Class in alluxio.thrift
 
BlockMasterWorkerService.AsyncClient.blockHeartbeat_call - Class in alluxio.thrift
 
BlockMasterWorkerService.AsyncClient.commitBlock_call - Class in alluxio.thrift
 
BlockMasterWorkerService.AsyncClient.Factory - Class in alluxio.thrift
 
BlockMasterWorkerService.AsyncClient.getWorkerId_call - Class in alluxio.thrift
 
BlockMasterWorkerService.AsyncClient.registerWorker_call - Class in alluxio.thrift
 
BlockMasterWorkerService.AsyncIface - Interface in alluxio.thrift
 
BlockMasterWorkerService.AsyncProcessor<I extends BlockMasterWorkerService.AsyncIface> - Class in alluxio.thrift
 
BlockMasterWorkerService.AsyncProcessor.blockHeartbeat<I extends BlockMasterWorkerService.AsyncIface> - Class in alluxio.thrift
 
BlockMasterWorkerService.AsyncProcessor.commitBlock<I extends BlockMasterWorkerService.AsyncIface> - Class in alluxio.thrift
 
BlockMasterWorkerService.AsyncProcessor.getWorkerId<I extends BlockMasterWorkerService.AsyncIface> - Class in alluxio.thrift
 
BlockMasterWorkerService.AsyncProcessor.registerWorker<I extends BlockMasterWorkerService.AsyncIface> - Class in alluxio.thrift
 
BlockMasterWorkerService.blockHeartbeat_args - Class in alluxio.thrift
 
BlockMasterWorkerService.blockHeartbeat_args._Fields - Enum in alluxio.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
BlockMasterWorkerService.blockHeartbeat_result - Class in alluxio.thrift
 
BlockMasterWorkerService.blockHeartbeat_result._Fields - Enum in alluxio.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
BlockMasterWorkerService.Client - Class in alluxio.thrift
 
BlockMasterWorkerService.Client.Factory - Class in alluxio.thrift
 
BlockMasterWorkerService.commitBlock_args - Class in alluxio.thrift
 
BlockMasterWorkerService.commitBlock_args._Fields - Enum in alluxio.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
BlockMasterWorkerService.commitBlock_result - Class in alluxio.thrift
 
BlockMasterWorkerService.commitBlock_result._Fields - Enum in alluxio.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
BlockMasterWorkerService.getWorkerId_args - Class in alluxio.thrift
 
BlockMasterWorkerService.getWorkerId_args._Fields - Enum in alluxio.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
BlockMasterWorkerService.getWorkerId_result - Class in alluxio.thrift
 
BlockMasterWorkerService.getWorkerId_result._Fields - Enum in alluxio.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
BlockMasterWorkerService.Iface - Interface in alluxio.thrift
This interface contains block master service endpoints for Alluxio workers.
BlockMasterWorkerService.Processor<I extends BlockMasterWorkerService.Iface> - Class in alluxio.thrift
 
BlockMasterWorkerService.Processor.blockHeartbeat<I extends BlockMasterWorkerService.Iface> - Class in alluxio.thrift
 
BlockMasterWorkerService.Processor.commitBlock<I extends BlockMasterWorkerService.Iface> - Class in alluxio.thrift
 
BlockMasterWorkerService.Processor.getWorkerId<I extends BlockMasterWorkerService.Iface> - Class in alluxio.thrift
 
BlockMasterWorkerService.Processor.registerWorker<I extends BlockMasterWorkerService.Iface> - Class in alluxio.thrift
 
BlockMasterWorkerService.registerWorker_args - Class in alluxio.thrift
 
BlockMasterWorkerService.registerWorker_args._Fields - Enum in alluxio.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
BlockMasterWorkerService.registerWorker_result - Class in alluxio.thrift
 
BlockMasterWorkerService.registerWorker_result._Fields - Enum in alluxio.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
BlockMasterWorkerServiceHandler - Class in alluxio.master.block
This class is a Thrift handler for block master RPCs invoked by an Alluxio worker.
BlockMeta - Class in alluxio.worker.block.meta
Represents the metadata of a block in Alluxio managed storage.
BlockMeta(long, long, StorageDir) - Constructor for class alluxio.worker.block.meta.BlockMeta
Creates a new instance of BlockMeta.
BlockMeta(TempBlockMeta) - Constructor for class alluxio.worker.block.meta.BlockMeta
Creates a new instance of BlockMeta from TempBlockMeta.
BlockMetadataManager - Class in alluxio.worker.block
Manages the metadata of all blocks in managed space.
BlockMetadataManagerView - Class in alluxio.worker.block
This class exposes a narrower view of BlockMetadataManager to Evictors and Allocators, filtering out un-evictable blocks and un-allocatable space internally, so that evictors and allocators can be developed with much simpler logic, without worrying about various constraints, e.g.
BlockMetadataManagerView(BlockMetadataManager, Set<Long>, Set<Long>) - Constructor for class alluxio.worker.block.BlockMetadataManagerView
Creates a new instance of BlockMetadataManagerView.
BlockMetricsReporter - Class in alluxio.worker.block
This class listens on block events and increases the metrics counters.
BlockMetricsReporter() - Constructor for class alluxio.worker.block.BlockMetricsReporter
Creates a new instance of BlockMetricsReporter.
BlockOutStream - Class in alluxio.client.block.stream
Provides an OutputStream implementation that is based on PacketWriter which streams data packet by packet.
BlockOutStream(PacketWriter, long, WorkerNetAddress) - Constructor for class alluxio.client.block.stream.BlockOutStream
Constructs a new BlockOutStream with only one PacketWriter.
BlockPacketWriter(BlockWriteRequestContext, Channel, BlockWorker) - Constructor for class alluxio.worker.netty.BlockWriteHandler.BlockPacketWriter
 
BlockReader - Interface in alluxio.worker.block.io
A reader interface to access the data of a block stored in managed storage.
BlockReadHandler - Class in alluxio.worker.netty
This handler handles block read request.
BlockReadHandler(ExecutorService, BlockWorker, FileTransferType) - Constructor for class alluxio.worker.netty.BlockReadHandler
Creates an instance of AbstractReadHandler.
BlockReadHandler.BlockPacketReader - Class in alluxio.worker.netty
The packet reader to read from a local block worker.
BlockReadRequest - Class in alluxio.worker.netty
The internal representation of a block read request.
BlockReadRequestContext - Class in alluxio.worker.netty
Context of BlockReadRequest.
BlockReadRequestContext(Protocol.ReadRequest) - Constructor for class alluxio.worker.netty.BlockReadRequestContext
 
BLOCKS_CACHED - Static variable in class alluxio.worker.block.DefaultBlockWorker.Metrics
 
BLOCKS_FIELD_NUMBER - Static variable in class alluxio.proto.journal.File.InodeFileEntry
 
BlockStore - Interface in alluxio.worker.block
A blob store interface to represent the local storage managing and serving all the blocks in the local storage.
BlockStoreEventListener - Interface in alluxio.worker.block
A listener interface for receiving metadata mutation events of BlockStore.
BlockStoreLocation - Class in alluxio.worker.block
Where to store a block within a block store.
BlockStoreLocation(String, int) - Constructor for class alluxio.worker.block.BlockStoreLocation
Creates a new instance of BlockStoreLocation.
BlockStoreMeta - Interface in alluxio.worker.block
Interface for the block store meta in Alluxio.
BlockStoreMeta.Factory - Class in alluxio.worker.block
Factory for BlockStoreMeta.
BlockTransferInfo - Class in alluxio.worker.block.evictor
Provides information about the transfer of a block.
BlockTransferInfo(long, BlockStoreLocation, BlockStoreLocation) - Constructor for class alluxio.worker.block.evictor.BlockTransferInfo
Creates a new instance of BlockTransferInfo.
BlockWorker - Interface in alluxio.worker.block
A block worker in the Alluxio system.
BlockWorkerClientService - Class in alluxio.thrift
 
BlockWorkerClientService() - Constructor for class alluxio.thrift.BlockWorkerClientService
 
BlockWorkerClientService.accessBlock_args - Class in alluxio.thrift
 
BlockWorkerClientService.accessBlock_args._Fields - Enum in alluxio.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
BlockWorkerClientService.accessBlock_result - Class in alluxio.thrift
 
BlockWorkerClientService.accessBlock_result._Fields - Enum in alluxio.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
BlockWorkerClientService.AsyncClient - Class in alluxio.thrift
 
BlockWorkerClientService.AsyncClient.accessBlock_call - Class in alluxio.thrift
 
BlockWorkerClientService.AsyncClient.cacheBlock_call - Class in alluxio.thrift
 
BlockWorkerClientService.AsyncClient.cancelBlock_call - Class in alluxio.thrift
 
BlockWorkerClientService.AsyncClient.Factory - Class in alluxio.thrift
 
BlockWorkerClientService.AsyncClient.lockBlock_call - Class in alluxio.thrift
 
BlockWorkerClientService.AsyncClient.promoteBlock_call - Class in alluxio.thrift
 
BlockWorkerClientService.AsyncClient.removeBlock_call - Class in alluxio.thrift
 
BlockWorkerClientService.AsyncClient.requestBlockLocation_call - Class in alluxio.thrift
 
BlockWorkerClientService.AsyncClient.requestSpace_call - Class in alluxio.thrift
 
BlockWorkerClientService.AsyncClient.sessionBlockHeartbeat_call - Class in alluxio.thrift
 
BlockWorkerClientService.AsyncClient.unlockBlock_call - Class in alluxio.thrift
 
BlockWorkerClientService.AsyncIface - Interface in alluxio.thrift
 
BlockWorkerClientService.AsyncProcessor<I extends BlockWorkerClientService.AsyncIface> - Class in alluxio.thrift
 
BlockWorkerClientService.AsyncProcessor.accessBlock<I extends BlockWorkerClientService.AsyncIface> - Class in alluxio.thrift
 
BlockWorkerClientService.AsyncProcessor.cacheBlock<I extends BlockWorkerClientService.AsyncIface> - Class in alluxio.thrift
 
BlockWorkerClientService.AsyncProcessor.cancelBlock<I extends BlockWorkerClientService.AsyncIface> - Class in alluxio.thrift
 
BlockWorkerClientService.AsyncProcessor.lockBlock<I extends BlockWorkerClientService.AsyncIface> - Class in alluxio.thrift
 
BlockWorkerClientService.AsyncProcessor.promoteBlock<I extends BlockWorkerClientService.AsyncIface> - Class in alluxio.thrift
 
BlockWorkerClientService.AsyncProcessor.removeBlock<I extends BlockWorkerClientService.AsyncIface> - Class in alluxio.thrift
 
BlockWorkerClientService.AsyncProcessor.requestBlockLocation<I extends BlockWorkerClientService.AsyncIface> - Class in alluxio.thrift
 
BlockWorkerClientService.AsyncProcessor.requestSpace<I extends BlockWorkerClientService.AsyncIface> - Class in alluxio.thrift
 
BlockWorkerClientService.AsyncProcessor.sessionBlockHeartbeat<I extends BlockWorkerClientService.AsyncIface> - Class in alluxio.thrift
 
BlockWorkerClientService.AsyncProcessor.unlockBlock<I extends BlockWorkerClientService.AsyncIface> - Class in alluxio.thrift
 
BlockWorkerClientService.cacheBlock_args - Class in alluxio.thrift
 
BlockWorkerClientService.cacheBlock_args._Fields - Enum in alluxio.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
BlockWorkerClientService.cacheBlock_result - Class in alluxio.thrift
 
BlockWorkerClientService.cacheBlock_result._Fields - Enum in alluxio.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
BlockWorkerClientService.cancelBlock_args - Class in alluxio.thrift
 
BlockWorkerClientService.cancelBlock_args._Fields - Enum in alluxio.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
BlockWorkerClientService.cancelBlock_result - Class in alluxio.thrift
 
BlockWorkerClientService.cancelBlock_result._Fields - Enum in alluxio.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
BlockWorkerClientService.Client - Class in alluxio.thrift
 
BlockWorkerClientService.Client.Factory - Class in alluxio.thrift
 
BlockWorkerClientService.Iface - Interface in alluxio.thrift
 
BlockWorkerClientService.lockBlock_args - Class in alluxio.thrift
 
BlockWorkerClientService.lockBlock_args._Fields - Enum in alluxio.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
BlockWorkerClientService.lockBlock_result - Class in alluxio.thrift
 
BlockWorkerClientService.lockBlock_result._Fields - Enum in alluxio.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
BlockWorkerClientService.Processor<I extends BlockWorkerClientService.Iface> - Class in alluxio.thrift
 
BlockWorkerClientService.Processor.accessBlock<I extends BlockWorkerClientService.Iface> - Class in alluxio.thrift
 
BlockWorkerClientService.Processor.cacheBlock<I extends BlockWorkerClientService.Iface> - Class in alluxio.thrift
 
BlockWorkerClientService.Processor.cancelBlock<I extends BlockWorkerClientService.Iface> - Class in alluxio.thrift
 
BlockWorkerClientService.Processor.lockBlock<I extends BlockWorkerClientService.Iface> - Class in alluxio.thrift
 
BlockWorkerClientService.Processor.promoteBlock<I extends BlockWorkerClientService.Iface> - Class in alluxio.thrift
 
BlockWorkerClientService.Processor.removeBlock<I extends BlockWorkerClientService.Iface> - Class in alluxio.thrift
 
BlockWorkerClientService.Processor.requestBlockLocation<I extends BlockWorkerClientService.Iface> - Class in alluxio.thrift
 
BlockWorkerClientService.Processor.requestSpace<I extends BlockWorkerClientService.Iface> - Class in alluxio.thrift
 
BlockWorkerClientService.Processor.sessionBlockHeartbeat<I extends BlockWorkerClientService.Iface> - Class in alluxio.thrift
 
BlockWorkerClientService.Processor.unlockBlock<I extends BlockWorkerClientService.Iface> - Class in alluxio.thrift
 
BlockWorkerClientService.promoteBlock_args - Class in alluxio.thrift
 
BlockWorkerClientService.promoteBlock_args._Fields - Enum in alluxio.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
BlockWorkerClientService.promoteBlock_result - Class in alluxio.thrift
 
BlockWorkerClientService.promoteBlock_result._Fields - Enum in alluxio.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
BlockWorkerClientService.removeBlock_args - Class in alluxio.thrift
 
BlockWorkerClientService.removeBlock_args._Fields - Enum in alluxio.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
BlockWorkerClientService.removeBlock_result - Class in alluxio.thrift
 
BlockWorkerClientService.removeBlock_result._Fields - Enum in alluxio.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
BlockWorkerClientService.requestBlockLocation_args - Class in alluxio.thrift
 
BlockWorkerClientService.requestBlockLocation_args._Fields - Enum in alluxio.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
BlockWorkerClientService.requestBlockLocation_result - Class in alluxio.thrift
 
BlockWorkerClientService.requestBlockLocation_result._Fields - Enum in alluxio.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
BlockWorkerClientService.requestSpace_args - Class in alluxio.thrift
 
BlockWorkerClientService.requestSpace_args._Fields - Enum in alluxio.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
BlockWorkerClientService.requestSpace_result - Class in alluxio.thrift
 
BlockWorkerClientService.requestSpace_result._Fields - Enum in alluxio.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
BlockWorkerClientService.sessionBlockHeartbeat_args - Class in alluxio.thrift
 
BlockWorkerClientService.sessionBlockHeartbeat_args._Fields - Enum in alluxio.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
BlockWorkerClientService.sessionBlockHeartbeat_result - Class in alluxio.thrift
 
BlockWorkerClientService.sessionBlockHeartbeat_result._Fields - Enum in alluxio.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
BlockWorkerClientService.unlockBlock_args - Class in alluxio.thrift
 
BlockWorkerClientService.unlockBlock_args._Fields - Enum in alluxio.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
BlockWorkerClientService.unlockBlock_result - Class in alluxio.thrift
 
BlockWorkerClientService.unlockBlock_result._Fields - Enum in alluxio.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
BlockWorkerClientServiceHandler - Class in alluxio.worker.block
This class is a Thrift handler for block worker RPCs invoked by an Alluxio client.
BlockWorkerClientServiceHandler(BlockWorker) - Constructor for class alluxio.worker.block.BlockWorkerClientServiceHandler
Creates a new instance of BlockWorkerClientServiceHandler.
BlockWorkerFactory - Class in alluxio.worker.block
Factory to create a BlockWorker instance.
BlockWorkerFactory() - Constructor for class alluxio.worker.block.BlockWorkerFactory
Constructs a new BlockWorkerFactory.
BlockWorkerInfo - Class in alluxio.client.block
Information of an active block worker.
BlockWorkerInfo(WorkerNetAddress, long, long) - Constructor for class alluxio.client.block.BlockWorkerInfo
Constructs the block worker information.
BlockWriteHandler - Class in alluxio.worker.netty
This handler handles block write request.
BlockWriteHandler.BlockPacketWriter - Class in alluxio.worker.netty
The packet writer that writes to a local block worker.
BlockWriter - Interface in alluxio.worker.block.io
A writer interface to write or update a block stored in managed storage.
BlockWriteRequest - Class in alluxio.worker.netty
The block write request internal representation.
BlockWriteRequestContext - Class in alluxio.worker.netty
The block write request internal representation.
BootstrapClientTransport - Class in alluxio.network.thrift
The client side transport of a BootstrapTransport.
BootstrapClientTransport(TTransport) - Constructor for class alluxio.network.thrift.BootstrapClientTransport
Constructs a client-side transport of bootstrap transport.
BootstrapServerTransport - Class in alluxio.network.thrift
The server side of bootstrap transport.
BootstrapServerTransport(TTransport, TTransportFactory) - Constructor for class alluxio.network.thrift.BootstrapServerTransport
 
BootstrapServerTransport.Factory - Class in alluxio.network.thrift
Factory to create BootstrapServerTransport instance on server side.
BoundedStream - Interface in alluxio.client
This interface should be implemented by all Alluxio streams which are bounded at a certain byte size.
BUCKET_ALREADY_EXISTS - Static variable in class alluxio.proxy.s3.S3ErrorCode
 
BUCKET_ALREADY_EXISTS - Static variable in class alluxio.proxy.s3.S3ErrorCode.Name
 
BUCKET_NOT_EMPTY - Static variable in class alluxio.proxy.s3.S3ErrorCode
 
BUCKET_NOT_EMPTY - Static variable in class alluxio.proxy.s3.S3ErrorCode.Name
 
BUCKET_PARAM - Static variable in class alluxio.proxy.s3.S3RestServiceHandler
 
BUCKET_SEPARATOR - Static variable in class alluxio.proxy.s3.S3RestServiceHandler
Bucket must be a directory directly under a mount point.
bufferForData() - Method in class alluxio.thrift.GetTResponse
 
bufferForKey() - Method in class alluxio.thrift.KeyValueWorkerClientService.get_args
 
bufferForKey() - Method in class alluxio.thrift.KeyValueWorkerClientService.getNextKeys_args
 
bufferForKeyLimit() - Method in class alluxio.thrift.PartitionInfo
 
bufferForKeyStart() - Method in class alluxio.thrift.PartitionInfo
 
BufferUtils - Class in alluxio.util.io
Utilities related to buffers, not only ByteBuffer.
build() - Method in class alluxio.master.journal.JournalSystem.Builder
 
build() - Method in class alluxio.master.MasterHealthCheckClient.Builder
 
build() - Method in class alluxio.multi.process.MultiProcessCluster.Builder
 
build() - Method in class alluxio.PropertyKey.Builder
Creates and registers the property key.
build() - Method in class alluxio.proto.dataserver.Protocol.AsyncCacheRequest.Builder
 
build() - Method in class alluxio.proto.dataserver.Protocol.CreateUfsFileOptions.Builder
 
build() - Method in class alluxio.proto.dataserver.Protocol.Heartbeat.Builder
 
build() - Method in class alluxio.proto.dataserver.Protocol.LocalBlockCloseRequest.Builder
 
build() - Method in class alluxio.proto.dataserver.Protocol.LocalBlockCompleteRequest.Builder
 
build() - Method in class alluxio.proto.dataserver.Protocol.LocalBlockCreateRequest.Builder
 
build() - Method in class alluxio.proto.dataserver.Protocol.LocalBlockCreateResponse.Builder
 
build() - Method in class alluxio.proto.dataserver.Protocol.LocalBlockOpenRequest.Builder
 
build() - Method in class alluxio.proto.dataserver.Protocol.LocalBlockOpenResponse.Builder
 
build() - Method in class alluxio.proto.dataserver.Protocol.OpenUfsBlockOptions.Builder
 
build() - Method in class alluxio.proto.dataserver.Protocol.ReadRequest.Builder
 
build() - Method in class alluxio.proto.dataserver.Protocol.ReadResponse.Builder
 
build() - Method in class alluxio.proto.dataserver.Protocol.Response.Builder
 
build() - Method in class alluxio.proto.dataserver.Protocol.WriteRequest.Builder
 
build() - Method in class alluxio.proto.journal.Block.BlockContainerIdGeneratorEntry.Builder
 
build() - Method in class alluxio.proto.journal.Block.BlockInfoEntry.Builder
 
build() - Method in class alluxio.proto.journal.Block.DeleteBlockEntry.Builder
 
build() - Method in class alluxio.proto.journal.File.AddMountPointEntry.Builder
 
build() - Method in class alluxio.proto.journal.File.AsyncPersistRequestEntry.Builder
 
build() - Method in class alluxio.proto.journal.File.CompleteFileEntry.Builder
 
build() - Method in class alluxio.proto.journal.File.DeleteFileEntry.Builder
 
build() - Method in class alluxio.proto.journal.File.DeleteMountPointEntry.Builder
 
build() - Method in class alluxio.proto.journal.File.InodeDirectoryEntry.Builder
 
build() - Method in class alluxio.proto.journal.File.InodeDirectoryIdGeneratorEntry.Builder
 
build() - Method in class alluxio.proto.journal.File.InodeFileEntry.Builder
 
build() - Method in class alluxio.proto.journal.File.InodeLastModificationTimeEntry.Builder
 
build() - Method in class alluxio.proto.journal.File.PersistDirectoryEntry.Builder
 
build() - Method in class alluxio.proto.journal.File.PersistFileEntry.Builder
 
build() - Method in class alluxio.proto.journal.File.ReinitializeFileEntry.Builder
 
build() - Method in class alluxio.proto.journal.File.RenameEntry.Builder
 
build() - Method in class alluxio.proto.journal.File.SetAttributeEntry.Builder
 
build() - Method in class alluxio.proto.journal.File.StringPairEntry.Builder
 
build() - Method in class alluxio.proto.journal.File.UpdateUfsModeEntry.Builder
 
build() - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
 
build() - Method in class alluxio.proto.journal.KeyValue.CompletePartitionEntry.Builder
 
build() - Method in class alluxio.proto.journal.KeyValue.CompleteStoreEntry.Builder
 
build() - Method in class alluxio.proto.journal.KeyValue.CreateStoreEntry.Builder
 
build() - Method in class alluxio.proto.journal.KeyValue.DeleteStoreEntry.Builder
 
build() - Method in class alluxio.proto.journal.KeyValue.MergeStoreEntry.Builder
 
build() - Method in class alluxio.proto.journal.KeyValue.RenameStoreEntry.Builder
 
build() - Method in class alluxio.proto.journal.Lineage.DeleteLineageEntry.Builder
 
build() - Method in class alluxio.proto.journal.Lineage.LineageEntry.Builder
 
build() - Method in class alluxio.proto.journal.Lineage.LineageIdGeneratorEntry.Builder
 
build() - Method in class alluxio.retry.ExponentialTimeBoundedRetry.Builder
 
build(String, boolean) - Static method in class alluxio.util.ThreadFactoryUtils
Creates a ThreadFactory that spawns off threads.
build() - Method in class alluxio.util.UnixMountInfo.Builder
 
build() - Method in class alluxio.util.UnixMountInfo.Options.Builder
 
Builder() - Constructor for class alluxio.master.journal.JournalSystem.Builder
Creates a new journal system builder.
Builder() - Constructor for class alluxio.master.MasterHealthCheckClient.Builder
Constructs the builder with default values.
Builder(String) - Constructor for class alluxio.PropertyKey.Builder
 
Builder(PropertyKey.Template, Object...) - Constructor for class alluxio.PropertyKey.Builder
 
builder() - Static method in class alluxio.retry.ExponentialTimeBoundedRetry
 
Builder() - Constructor for class alluxio.retry.ExponentialTimeBoundedRetry.Builder
 
Builder() - Constructor for class alluxio.util.UnixMountInfo.Builder
Constructs a new Unix mount info builder.
Builder() - Constructor for class alluxio.util.UnixMountInfo.Options.Builder
Constructs a new unix mount info options builder.
buildPartial() - Method in class alluxio.proto.dataserver.Protocol.AsyncCacheRequest.Builder
 
buildPartial() - Method in class alluxio.proto.dataserver.Protocol.CreateUfsFileOptions.Builder
 
buildPartial() - Method in class alluxio.proto.dataserver.Protocol.Heartbeat.Builder
 
buildPartial() - Method in class alluxio.proto.dataserver.Protocol.LocalBlockCloseRequest.Builder
 
buildPartial() - Method in class alluxio.proto.dataserver.Protocol.LocalBlockCompleteRequest.Builder
 
buildPartial() - Method in class alluxio.proto.dataserver.Protocol.LocalBlockCreateRequest.Builder
 
buildPartial() - Method in class alluxio.proto.dataserver.Protocol.LocalBlockCreateResponse.Builder
 
buildPartial() - Method in class alluxio.proto.dataserver.Protocol.LocalBlockOpenRequest.Builder
 
buildPartial() - Method in class alluxio.proto.dataserver.Protocol.LocalBlockOpenResponse.Builder
 
buildPartial() - Method in class alluxio.proto.dataserver.Protocol.OpenUfsBlockOptions.Builder
 
buildPartial() - Method in class alluxio.proto.dataserver.Protocol.ReadRequest.Builder
 
buildPartial() - Method in class alluxio.proto.dataserver.Protocol.ReadResponse.Builder
 
buildPartial() - Method in class alluxio.proto.dataserver.Protocol.Response.Builder
 
buildPartial() - Method in class alluxio.proto.dataserver.Protocol.WriteRequest.Builder
 
buildPartial() - Method in class alluxio.proto.journal.Block.BlockContainerIdGeneratorEntry.Builder
 
buildPartial() - Method in class alluxio.proto.journal.Block.BlockInfoEntry.Builder
 
buildPartial() - Method in class alluxio.proto.journal.Block.DeleteBlockEntry.Builder
 
buildPartial() - Method in class alluxio.proto.journal.File.AddMountPointEntry.Builder
 
buildPartial() - Method in class alluxio.proto.journal.File.AsyncPersistRequestEntry.Builder
 
buildPartial() - Method in class alluxio.proto.journal.File.CompleteFileEntry.Builder
 
buildPartial() - Method in class alluxio.proto.journal.File.DeleteFileEntry.Builder
 
buildPartial() - Method in class alluxio.proto.journal.File.DeleteMountPointEntry.Builder
 
buildPartial() - Method in class alluxio.proto.journal.File.InodeDirectoryEntry.Builder
 
buildPartial() - Method in class alluxio.proto.journal.File.InodeDirectoryIdGeneratorEntry.Builder
 
buildPartial() - Method in class alluxio.proto.journal.File.InodeFileEntry.Builder
 
buildPartial() - Method in class alluxio.proto.journal.File.InodeLastModificationTimeEntry.Builder
 
buildPartial() - Method in class alluxio.proto.journal.File.PersistDirectoryEntry.Builder
 
buildPartial() - Method in class alluxio.proto.journal.File.PersistFileEntry.Builder
 
buildPartial() - Method in class alluxio.proto.journal.File.ReinitializeFileEntry.Builder
 
buildPartial() - Method in class alluxio.proto.journal.File.RenameEntry.Builder
 
buildPartial() - Method in class alluxio.proto.journal.File.SetAttributeEntry.Builder
 
buildPartial() - Method in class alluxio.proto.journal.File.StringPairEntry.Builder
 
buildPartial() - Method in class alluxio.proto.journal.File.UpdateUfsModeEntry.Builder
 
buildPartial() - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
 
buildPartial() - Method in class alluxio.proto.journal.KeyValue.CompletePartitionEntry.Builder
 
buildPartial() - Method in class alluxio.proto.journal.KeyValue.CompleteStoreEntry.Builder
 
buildPartial() - Method in class alluxio.proto.journal.KeyValue.CreateStoreEntry.Builder
 
buildPartial() - Method in class alluxio.proto.journal.KeyValue.DeleteStoreEntry.Builder
 
buildPartial() - Method in class alluxio.proto.journal.KeyValue.MergeStoreEntry.Builder
 
buildPartial() - Method in class alluxio.proto.journal.KeyValue.RenameStoreEntry.Builder
 
buildPartial() - Method in class alluxio.proto.journal.Lineage.DeleteLineageEntry.Builder
 
buildPartial() - Method in class alluxio.proto.journal.Lineage.LineageEntry.Builder
 
buildPartial() - Method in class alluxio.proto.journal.Lineage.LineageIdGeneratorEntry.Builder
 
buildUnregistered() - Method in class alluxio.PropertyKey.Builder
Creates the property key without registering it with default property list.
byteArrayToHexString(byte[]) - Static method in class alluxio.util.FormatUtils
Parses a byte array into a space separated hex string where each byte is represented in the format 0x%02x.
byteArrayToHexString(byte[], String, String) - Static method in class alluxio.util.FormatUtils
Parses a byte array into a hex string where each byte is represented in the format %02x.
ByteBufferKeyValuePartitionReader - Class in alluxio.client.keyvalue
Reader that implements KeyValuePartitionReader to access a key-value file using random access API.
ByteBufferKeyValuePartitionReader(ByteBuffer) - Constructor for class alluxio.client.keyvalue.ByteBufferKeyValuePartitionReader
byteBufferToString(ByteBuffer) - Static method in class alluxio.util.FormatUtils
Parses a ByteBuffer into a String.
byteCount() - Method in interface alluxio.client.keyvalue.Index
 
byteCount() - Method in class alluxio.client.keyvalue.LinearProbingIndex
 
ByteIOUtils - Class in alluxio.util.io
A collection of utility functions to read/write primitive values from/to a byte array.
BYTES_IN_INTEGER - Static variable in class alluxio.Constants
 
BYTES_READ_ALLUXIO - Static variable in class alluxio.metrics.WorkerMetrics
Total number of bytes read/written from Alluxio storage through this worker.
BYTES_READ_ALLUXIO_THROUGHPUT - Static variable in class alluxio.metrics.WorkerMetrics
 
BYTES_READ_LOCAL - Static variable in class alluxio.metrics.ClientMetrics
Total number of bytes short-circuit read from local storage.
BYTES_READ_LOCAL_THROUGHPUT - Static variable in class alluxio.metrics.ClientMetrics
 
BYTES_READ_UFS - Static variable in class alluxio.metrics.WorkerMetrics
Total number of bytes read/written from UFS through this worker.
BYTES_READ_UFS_ALL - Static variable in class alluxio.metrics.WorkerMetrics
 
BYTES_READ_UFS_THROUGHPUT - Static variable in class alluxio.metrics.WorkerMetrics
 
BYTES_WRITTEN_ALLUXIO - Static variable in class alluxio.metrics.WorkerMetrics
 
BYTES_WRITTEN_ALLUXIO_THROUGHPUT - Static variable in class alluxio.metrics.WorkerMetrics
 
BYTES_WRITTEN_UFS - Static variable in class alluxio.metrics.WorkerMetrics
 
BYTES_WRITTEN_UFS_ALL - Static variable in class alluxio.metrics.WorkerMetrics
 
BYTES_WRITTEN_UFS_THROUGHPUT - Static variable in class alluxio.metrics.WorkerMetrics
 
byteToInt(byte) - Static method in class alluxio.util.io.BufferUtils
Converts a byte to an integer.

C

CACHEABLE_FIELD_NUMBER - Static variable in class alluxio.proto.journal.File.InodeFileEntry
 
cacheBlock(long, long, CacheBlockTOptions, AsyncMethodCallback) - Method in class alluxio.thrift.BlockWorkerClientService.AsyncClient
 
cacheBlock(long, long, CacheBlockTOptions, AsyncMethodCallback) - Method in interface alluxio.thrift.BlockWorkerClientService.AsyncIface
 
cacheBlock() - Constructor for class alluxio.thrift.BlockWorkerClientService.AsyncProcessor.cacheBlock
 
cacheBlock(long, long, CacheBlockTOptions) - Method in class alluxio.thrift.BlockWorkerClientService.Client
 
cacheBlock(long, long, CacheBlockTOptions) - Method in interface alluxio.thrift.BlockWorkerClientService.Iface
Used to cache a block into Alluxio space, worker will move the temporary block file from session folder to data folder, and update the space usage information related.
cacheBlock() - Constructor for class alluxio.thrift.BlockWorkerClientService.Processor.cacheBlock
 
cacheBlock(long, long, CacheBlockTOptions) - Method in class alluxio.worker.block.BlockWorkerClientServiceHandler
 
cacheBlock_args() - Constructor for class alluxio.thrift.BlockWorkerClientService.cacheBlock_args
 
cacheBlock_args(long, long, CacheBlockTOptions) - Constructor for class alluxio.thrift.BlockWorkerClientService.cacheBlock_args
 
cacheBlock_args(BlockWorkerClientService.cacheBlock_args) - Constructor for class alluxio.thrift.BlockWorkerClientService.cacheBlock_args
Performs a deep copy on other.
cacheBlock_call(long, long, CacheBlockTOptions, AsyncMethodCallback, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class alluxio.thrift.BlockWorkerClientService.AsyncClient.cacheBlock_call
 
cacheBlock_result() - Constructor for class alluxio.thrift.BlockWorkerClientService.cacheBlock_result
 
cacheBlock_result(CacheBlockTResponse, AlluxioTException) - Constructor for class alluxio.thrift.BlockWorkerClientService.cacheBlock_result
 
cacheBlock_result(BlockWorkerClientService.cacheBlock_result) - Constructor for class alluxio.thrift.BlockWorkerClientService.cacheBlock_result
Performs a deep copy on other.
CacheBlockTOptions - Class in alluxio.thrift
 
CacheBlockTOptions() - Constructor for class alluxio.thrift.CacheBlockTOptions
 
CacheBlockTOptions(CacheBlockTOptions) - Constructor for class alluxio.thrift.CacheBlockTOptions
Performs a deep copy on other.
CacheBlockTOptions._Fields - Enum in alluxio.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
CacheBlockTResponse - Class in alluxio.thrift
 
CacheBlockTResponse() - Constructor for class alluxio.thrift.CacheBlockTResponse
 
CacheBlockTResponse(CacheBlockTResponse) - Constructor for class alluxio.thrift.CacheBlockTResponse
Performs a deep copy on other.
CacheBlockTResponse._Fields - Enum in alluxio.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
CachedGroupMapping - Class in alluxio.security.group
Class to map user to groups.
CachedGroupMapping(GroupMappingService) - Constructor for class alluxio.security.group.CachedGroupMapping
Constructor with specified GroupMappingService.
call() - Method in interface alluxio.AbstractClient.RpcCallable
The task where RPC happens.
call() - Method in class alluxio.examples.BasicCheckpoint
 
call() - Method in class alluxio.examples.BasicNonByteBufferOperations
 
call() - Method in class alluxio.examples.BasicOperations
 
call() - Method in class alluxio.examples.keyvalue.KeyValueStoreOperations
 
call() - Method in class alluxio.examples.keyvalue.SameKeyValueStoresTest
 
call(NettyRPCContext, ProtoMessage) - Static method in class alluxio.network.netty.NettyRPC
Sends a request and waits for a response.
call(String, S3RestUtils.RestCallable<T>) - Static method in class alluxio.proxy.s3.S3RestUtils
Calls the given S3RestUtils.RestCallable and handles any exceptions thrown.
call() - Method in interface alluxio.proxy.s3.S3RestUtils.RestCallable
The REST endpoint implementation.
call(RestUtils.RestCallable<T>) - Static method in class alluxio.RestUtils
Calls the given RestUtils.RestCallable and handles any exceptions thrown.
call() - Method in interface alluxio.RestUtils.RestCallable
The REST endpoint implementation.
call(RpcUtils.RpcCallable<T>) - Static method in class alluxio.RpcUtils
Calls the given RpcUtils.RpcCallable and handles any exceptions thrown.
call(Logger, RpcUtils.RpcCallable<T>, String, String, Object...) - Static method in class alluxio.RpcUtils
Calls the given RpcUtils.RpcCallable and handles any exceptions thrown.
call(Logger, RpcUtils.RpcCallable<T>, String, boolean, String, Object...) - Static method in class alluxio.RpcUtils
Calls the given RpcUtils.RpcCallable and handles any exceptions thrown.
call(RpcUtils.RpcCallableThrowsIOException<T>) - Static method in class alluxio.RpcUtils
Calls the given RpcUtils.RpcCallableThrowsIOException and handles any exceptions thrown.
call(Logger, RpcUtils.RpcCallableThrowsIOException<T>, String, String, Object...) - Static method in class alluxio.RpcUtils
Calls the given RpcUtils.RpcCallableThrowsIOException and handles any exceptions thrown.
call(Logger, RpcUtils.RpcCallableThrowsIOException<T>, String, boolean, String, Object...) - Static method in class alluxio.RpcUtils
Calls the given RpcUtils.RpcCallableThrowsIOException and handles any exceptions thrown.
call() - Method in interface alluxio.RpcUtils.NettyRpcCallable
The RPC implementation.
call() - Method in interface alluxio.RpcUtils.RpcCallable
The RPC implementation.
call() - Method in interface alluxio.RpcUtils.RpcCallableThrowsIOException
The RPC implementation.
call() - Method in class alluxio.underfs.ObjectUnderFileSystem.DeleteBuffer.DeleteThread
 
call() - Method in interface alluxio.underfs.UnderFileSystemWithLogging.UfsCallable
Executes the call.
cancel() - Method in class alluxio.client.AbstractOutStream
Aborts the output stream.
cancel() - Method in class alluxio.client.block.stream.BlockOutStream
 
cancel() - Method in class alluxio.client.block.stream.LocalFilePacketWriter
 
cancel() - Method in class alluxio.client.block.stream.NettyPacketWriter
 
cancel() - Method in interface alluxio.client.Cancelable
Cancels an operation.
cancel() - Method in class alluxio.client.file.FileOutStream
 
CANCEL_FIELD_NUMBER - Static variable in class alluxio.proto.dataserver.Protocol.LocalBlockCompleteRequest
 
CANCEL_FIELD_NUMBER - Static variable in class alluxio.proto.dataserver.Protocol.ReadRequest
 
CANCEL_FIELD_NUMBER - Static variable in class alluxio.proto.dataserver.Protocol.WriteRequest
 
Cancelable - Interface in alluxio.client
This interface should be implemented by all Alluxio output streams which support aborting the temporary data that has been written.
cancelBlock(long, long, CancelBlockTOptions, AsyncMethodCallback) - Method in class alluxio.thrift.BlockWorkerClientService.AsyncClient
 
cancelBlock(long, long, CancelBlockTOptions, AsyncMethodCallback) - Method in interface alluxio.thrift.BlockWorkerClientService.AsyncIface
 
cancelBlock() - Constructor for class alluxio.thrift.BlockWorkerClientService.AsyncProcessor.cancelBlock
 
cancelBlock(long, long, CancelBlockTOptions) - Method in class alluxio.thrift.BlockWorkerClientService.Client
 
cancelBlock(long, long, CancelBlockTOptions) - Method in interface alluxio.thrift.BlockWorkerClientService.Iface
Used to cancel a block which is being written.
cancelBlock() - Constructor for class alluxio.thrift.BlockWorkerClientService.Processor.cancelBlock
 
cancelBlock(long, long, CancelBlockTOptions) - Method in class alluxio.worker.block.BlockWorkerClientServiceHandler
 
cancelBlock_args() - Constructor for class alluxio.thrift.BlockWorkerClientService.cancelBlock_args
 
cancelBlock_args(long, long, CancelBlockTOptions) - Constructor for class alluxio.thrift.BlockWorkerClientService.cancelBlock_args
 
cancelBlock_args(BlockWorkerClientService.cancelBlock_args) - Constructor for class alluxio.thrift.BlockWorkerClientService.cancelBlock_args
Performs a deep copy on other.
cancelBlock_call(long, long, CancelBlockTOptions, AsyncMethodCallback, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class alluxio.thrift.BlockWorkerClientService.AsyncClient.cancelBlock_call
 
cancelBlock_result() - Constructor for class alluxio.thrift.BlockWorkerClientService.cancelBlock_result
 
cancelBlock_result(CancelBlockTResponse, AlluxioTException) - Constructor for class alluxio.thrift.BlockWorkerClientService.cancelBlock_result
 
cancelBlock_result(BlockWorkerClientService.cancelBlock_result) - Constructor for class alluxio.thrift.BlockWorkerClientService.cancelBlock_result
Performs a deep copy on other.
CancelBlockTOptions - Class in alluxio.thrift
 
CancelBlockTOptions() - Constructor for class alluxio.thrift.CancelBlockTOptions
 
CancelBlockTOptions(CancelBlockTOptions) - Constructor for class alluxio.thrift.CancelBlockTOptions
Performs a deep copy on other.
CancelBlockTOptions._Fields - Enum in alluxio.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
CancelBlockTResponse - Class in alluxio.thrift
 
CancelBlockTResponse() - Constructor for class alluxio.thrift.CancelBlockTResponse
 
CancelBlockTResponse(CancelBlockTResponse) - Constructor for class alluxio.thrift.CancelBlockTResponse
Performs a deep copy on other.
CancelBlockTResponse._Fields - Enum in alluxio.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
CANCELED_VALUE - Static variable in enum alluxio.proto.status.Status.PStatus
CANCELED = 1;
CanceledException - Exception in alluxio.exception.status
Exception indicating that an operation was cancelled (typically by the caller).
CanceledException(String) - Constructor for exception alluxio.exception.status.CanceledException
 
CanceledException(Throwable) - Constructor for exception alluxio.exception.status.CanceledException
 
CanceledException(String, Throwable) - Constructor for exception alluxio.exception.status.CanceledException
 
cancelRequest(BlockWriteRequestContext) - Method in class alluxio.worker.netty.BlockWriteHandler.BlockPacketWriter
 
cancelRequest(UfsFileWriteRequestContext) - Method in class alluxio.worker.netty.UfsFileWriteHandler.UfsFilePacketWriter
 
cancelUfsFile(long, long, CancelUfsFileTOptions, AsyncMethodCallback) - Method in class alluxio.thrift.FileSystemWorkerClientService.AsyncClient
 
cancelUfsFile(long, long, CancelUfsFileTOptions, AsyncMethodCallback) - Method in interface alluxio.thrift.FileSystemWorkerClientService.AsyncIface
 
cancelUfsFile() - Constructor for class alluxio.thrift.FileSystemWorkerClientService.AsyncProcessor.cancelUfsFile
 
cancelUfsFile(long, long, CancelUfsFileTOptions) - Method in class alluxio.thrift.FileSystemWorkerClientService.Client
 
cancelUfsFile(long, long, CancelUfsFileTOptions) - Method in interface alluxio.thrift.FileSystemWorkerClientService.Iface
Cancels a file which has not been completed in the under file system.
cancelUfsFile() - Constructor for class alluxio.thrift.FileSystemWorkerClientService.Processor.cancelUfsFile
 
cancelUfsFile(long, long, CancelUfsFileTOptions) - Method in class alluxio.worker.file.FileSystemWorkerClientServiceHandler
 
cancelUfsFile_args() - Constructor for class alluxio.thrift.FileSystemWorkerClientService.cancelUfsFile_args
 
cancelUfsFile_args(long, long, CancelUfsFileTOptions) - Constructor for class alluxio.thrift.FileSystemWorkerClientService.cancelUfsFile_args
 
cancelUfsFile_args(FileSystemWorkerClientService.cancelUfsFile_args) - Constructor for class alluxio.thrift.FileSystemWorkerClientService.cancelUfsFile_args
Performs a deep copy on other.
cancelUfsFile_call(long, long, CancelUfsFileTOptions, AsyncMethodCallback, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class alluxio.thrift.FileSystemWorkerClientService.AsyncClient.cancelUfsFile_call
 
cancelUfsFile_result() - Constructor for class alluxio.thrift.FileSystemWorkerClientService.cancelUfsFile_result
 
cancelUfsFile_result(CancelUfsFileTResponse, AlluxioTException) - Constructor for class alluxio.thrift.FileSystemWorkerClientService.cancelUfsFile_result
 
cancelUfsFile_result(FileSystemWorkerClientService.cancelUfsFile_result) - Constructor for class alluxio.thrift.FileSystemWorkerClientService.cancelUfsFile_result
Performs a deep copy on other.
CancelUfsFileOptions - Class in alluxio.client.file.options
Options for canceling a UFS file.
CancelUfsFileTOptions - Class in alluxio.thrift
 
CancelUfsFileTOptions() - Constructor for class alluxio.thrift.CancelUfsFileTOptions
 
CancelUfsFileTOptions(CancelUfsFileTOptions) - Constructor for class alluxio.thrift.CancelUfsFileTOptions
Performs a deep copy on other.
CancelUfsFileTOptions._Fields - Enum in alluxio.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
CancelUfsFileTResponse - Class in alluxio.thrift
 
CancelUfsFileTResponse() - Constructor for class alluxio.thrift.CancelUfsFileTResponse
 
CancelUfsFileTResponse(CancelUfsFileTResponse) - Constructor for class alluxio.thrift.CancelUfsFileTResponse
Performs a deep copy on other.
CancelUfsFileTResponse._Fields - Enum in alluxio.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
canPut(byte[], byte[]) - Method in interface alluxio.client.keyvalue.KeyValuePartitionWriter
Returns whether this writer will be full after inserting the given key-value pair.
Capacity - Class in alluxio.wire
Class that represents the available, free, and total capacity.
Capacity() - Constructor for class alluxio.wire.Capacity
Creates a new instance of Capacity.
CAPACITY_FREE - Static variable in class alluxio.master.block.DefaultBlockMaster.Metrics
 
CAPACITY_FREE - Static variable in class alluxio.worker.block.DefaultBlockWorker.Metrics
 
CAPACITY_TOTAL - Static variable in class alluxio.master.block.DefaultBlockMaster.Metrics
 
CAPACITY_TOTAL - Static variable in class alluxio.worker.block.DefaultBlockWorker.Metrics
 
CAPACITY_USED - Static variable in class alluxio.master.block.DefaultBlockMaster.Metrics
 
CAPACITY_USED - Static variable in class alluxio.worker.block.DefaultBlockWorker.Metrics
 
CapacityCommand - Class in alluxio.cli.fsadmin.report
Prints Alluxio capacity information.
CapacityCommand(BlockMasterClient, PrintStream) - Constructor for class alluxio.cli.fsadmin.report.CapacityCommand
Creates a new instance of CapacityCommand.
CASCADE_FIELD_NUMBER - Static variable in class alluxio.proto.journal.Lineage.DeleteLineageEntry
 
cascadingEvict(long, BlockStoreLocation, EvictionPlan, Evictor.Mode) - Method in class alluxio.worker.block.evictor.AbstractEvictor
A recursive implementation of cascading eviction.
castToIOException(Throwable) - Static method in class alluxio.util.CommonUtils
Casts a Throwable to an IOException.
CatCommand - Class in alluxio.cli.fs.command
Prints the file's contents to the console.
CatCommand(FileSystem) - Constructor for class alluxio.cli.fs.command.CatCommand
 
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.
channelRead(ChannelHandlerContext, Object) - Method in class alluxio.network.netty.NettyRPC.RPCHandler
 
channelRead(ChannelHandlerContext, Object) - Method in class alluxio.worker.netty.AsyncCacheHandler
 
channelRead(ChannelHandlerContext, Object) - Method in class alluxio.worker.netty.HeartbeatHandler
 
channelRead(ChannelHandlerContext, Object) - Method in class alluxio.worker.netty.UnsupportedMessageHandler
 
ChannelType - Enum in alluxio.network
What type of netty channel to use.
channelUnregistered(ChannelHandlerContext) - Method in class alluxio.network.netty.NettyRPC.RPCHandler
 
check(boolean, ExceptionMessage, Object...) - Static method in exception alluxio.exception.LineageDoesNotExistException
Ensures the truth of an expression involving the state of the calling instance, but not involving any parameters to the calling method.
checkConsistency(AlluxioURI, CheckConsistencyOptions) - 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, CheckConsistencyOptions) - Static method in class alluxio.client.file.FileSystemUtils
Checks the consistency of Alluxio metadata against the under storage for all files and directories in a given subtree.
checkConsistency(AlluxioURI, CheckConsistencyOptions) - Method in class alluxio.client.file.RetryHandlingFileSystemMasterClient
 
checkConsistency(AlluxioURI, CheckConsistencyOptions) - Method in class alluxio.master.file.DefaultFileSystemMaster
 
checkConsistency(AlluxioURI, CheckConsistencyOptions) - Method in interface alluxio.master.file.FileSystemMaster
Checks the consistency of the files and directories in the subtree under the path.
checkConsistency(String, CheckConsistencyTOptions) - Method in class alluxio.master.file.FileSystemMasterClientServiceHandler
 
checkConsistency(String, CheckConsistencyTOptions, AsyncMethodCallback) - Method in class alluxio.thrift.FileSystemMasterClientService.AsyncClient
 
checkConsistency(String, CheckConsistencyTOptions, AsyncMethodCallback) - Method in interface alluxio.thrift.FileSystemMasterClientService.AsyncIface
 
checkConsistency() - Constructor for class alluxio.thrift.FileSystemMasterClientService.AsyncProcessor.checkConsistency
 
checkConsistency(String, CheckConsistencyTOptions) - Method in class alluxio.thrift.FileSystemMasterClientService.Client
 
checkConsistency(String, CheckConsistencyTOptions) - Method in interface alluxio.thrift.FileSystemMasterClientService.Iface
Checks the consistency of the files and directores with the path as the root of the subtree
checkConsistency() - Constructor for class alluxio.thrift.FileSystemMasterClientService.Processor.checkConsistency
 
checkConsistency_args() - Constructor for class alluxio.thrift.FileSystemMasterClientService.checkConsistency_args
 
checkConsistency_args(String, CheckConsistencyTOptions) - Constructor for class alluxio.thrift.FileSystemMasterClientService.checkConsistency_args
 
checkConsistency_args(FileSystemMasterClientService.checkConsistency_args) - Constructor for class alluxio.thrift.FileSystemMasterClientService.checkConsistency_args
Performs a deep copy on other.
checkConsistency_call(String, CheckConsistencyTOptions, AsyncMethodCallback, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class alluxio.thrift.FileSystemMasterClientService.AsyncClient.checkConsistency_call
 
checkConsistency_result() - Constructor for class alluxio.thrift.FileSystemMasterClientService.checkConsistency_result
 
checkConsistency_result(CheckConsistencyTResponse, AlluxioTException) - Constructor for class alluxio.thrift.FileSystemMasterClientService.checkConsistency_result
 
checkConsistency_result(FileSystemMasterClientService.checkConsistency_result) - Constructor for class alluxio.thrift.FileSystemMasterClientService.checkConsistency_result
Performs a deep copy on other.
CheckConsistencyCommand - Class in alluxio.cli.fs.command
Command for checking the consistency of a file or folder between Alluxio and the under storage.
CheckConsistencyCommand(FileSystem) - Constructor for class alluxio.cli.fs.command.CheckConsistencyCommand
 
CheckConsistencyOptions - Class in alluxio.client.file.options
Options for checking the consistency of an Alluxio subtree.
CheckConsistencyOptions - Class in alluxio.master.file.options
Method options for checking the consistency of a path.
CheckConsistencyOptions(CheckConsistencyTOptions) - Constructor for class alluxio.master.file.options.CheckConsistencyOptions
Constructs an instance of CheckConsistencyOptions from CheckConsistencyTOptions.
CheckConsistencyTOptions - Class in alluxio.thrift
 
CheckConsistencyTOptions() - Constructor for class alluxio.thrift.CheckConsistencyTOptions
 
CheckConsistencyTOptions(CheckConsistencyTOptions) - Constructor for class alluxio.thrift.CheckConsistencyTOptions
Performs a deep copy on other.
CheckConsistencyTOptions._Fields - Enum in alluxio.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
CheckConsistencyTResponse - Class in alluxio.thrift
 
CheckConsistencyTResponse() - Constructor for class alluxio.thrift.CheckConsistencyTResponse
 
CheckConsistencyTResponse(List<String>) - Constructor for class alluxio.thrift.CheckConsistencyTResponse
 
CheckConsistencyTResponse(CheckConsistencyTResponse) - Constructor for class alluxio.thrift.CheckConsistencyTResponse
Performs a deep copy on other.
CheckConsistencyTResponse._Fields - Enum in alluxio.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
checkDirectory(InodeDirectory, AlluxioURI) - Method in class alluxio.master.file.UfsSyncChecker
Check if immediate children of directory are in sync with UFS.
CheckerMapper() - Constructor for class alluxio.checker.MapReduceIntegrationChecker.CheckerMapper
 
CheckerReducer() - Constructor for class alluxio.checker.MapReduceIntegrationChecker.CheckerReducer
 
CheckerUtils - Class in alluxio.checker
Class for common methods used by integration checkers.
CheckerUtils.Status - Enum in alluxio.checker
The performIntegrationChecks results.
checkInodeList(String, List<String>, Mode.Bits, String, List<Inode<?>>, boolean) - Method in class alluxio.master.file.DefaultPermissionChecker
This method provides basic permission checking logic on a list of inodes.
checkMasterClientService() - Static method in class alluxio.cli.fsadmin.FileSystemAdminShellUtils
Checks if the master client service is available.
checkMinimalPollingPeriod(TimeUnit, int) - Static method in class alluxio.metrics.MetricsSystem
Checks if the poll period is smaller that the minimal poll period which is 1 second.
checkNumOfArgsEquals(Command, CommandLine, int) - Static method in class alluxio.cli.CommandUtils
Checks the number of non-option arguments equals n for command.
checkNumOfArgsNoLessThan(Command, CommandLine, int) - Static method in class alluxio.cli.CommandUtils
Checks the number of non-option arguments is no less than n for command.
checkNumOfArgsNoMoreThan(Command, CommandLine, int) - Static method in class alluxio.cli.CommandUtils
Checks the number of non-option arguments is no more than n for command.
checkOutputSpecs(JobContext) - Method in class alluxio.hadoop.mapreduce.KeyValueOutputFormat
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(String, List<String>, Inode<?>, Mode.Bits) - Method in class alluxio.master.file.DefaultInodePermissionChecker
 
checkPermission(Mode.Bits, LockedInodePath) - Method in class alluxio.master.file.DefaultPermissionChecker
 
checkPermission(String, List<String>, Inode<?>, Mode.Bits) - Method in interface alluxio.master.file.InodePermissionChecker
Checks whether user has the specified permission on the file or directory at path.
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.
CHECKPOINT_SESSION_ID - Static variable in class alluxio.Sessions
 
CheckpointLatestPlanner - Class in alluxio.master.lineage.checkpoint
This class tries to checkpoint the latest created lineage that is ready for persistence.
CheckpointLatestPlanner(LineageStoreView, FileSystemMasterView) - Constructor for class alluxio.master.lineage.checkpoint.CheckpointLatestPlanner
Creates a new instance of CheckpointLatestPlanner, which does not use the lineage store view.
CheckpointPlan - Class in alluxio.master.lineage.checkpoint
A plan for checkpointing lineage.
CheckpointPlan(List<Long>) - Constructor for class alluxio.master.lineage.checkpoint.CheckpointPlan
Creates a new instance of CheckpointPlan.
CheckpointPlanner - Interface in alluxio.master.lineage.checkpoint
Generates plans for lineage checkpointing.
CheckpointPlanner.Factory - Class in alluxio.master.lineage.checkpoint
Factory for CheckpointPlanner.
CheckpointSchedulingExecutor - Class in alluxio.master.lineage.checkpoint
Schedules a checkpoint plan.
CheckpointSchedulingExecutor(LineageMaster, FileSystemMaster) - Constructor for class alluxio.master.lineage.checkpoint.CheckpointSchedulingExecutor
 
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.
ChecksumCommand - Class in alluxio.cli.fs.command
Calculates the MD5 checksum for a file.
ChecksumCommand(FileSystem) - Constructor for class alluxio.cli.fs.command.ChecksumCommand
 
checkType(FileSystemCommandOptions._Fields, Object) - Method in class alluxio.thrift.FileSystemCommandOptions
 
checkUnderWritableMountPoint(AlluxioURI) - Method in class alluxio.master.file.meta.MountTable
Checks to see if a write operation is allowed for the specified Alluxio path, by determining if it is under a readonly mount point.
checkVersion(AlluxioService.Client, 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(FileSystem) - Constructor for class alluxio.cli.fs.command.ChgrpCommand
Creates a new instance of ChgrpCommand.
ChmodCommand - Class in alluxio.cli.fs.command
Changes the permission of a file or directory specified by args.
ChmodCommand(FileSystem) - Constructor for class alluxio.cli.fs.command.ChmodCommand
Creates a new instance of ChmodCommand.
ChownCommand - Class in alluxio.cli.fs.command
Changes the owner of a file or directory specified by args.
ChownCommand(FileSystem) - Constructor for class alluxio.cli.fs.command.ChownCommand
Creates a new instance of ChownCommand.
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.
cleanupRequest(BlockWriteRequestContext) - Method in class alluxio.worker.netty.BlockWriteHandler.BlockPacketWriter
 
cleanupRequest(UfsFileWriteRequestContext) - Method in class alluxio.worker.netty.UfsFileWriteHandler.UfsFilePacketWriter
 
cleanupSession(long) - Method in class alluxio.worker.block.BlockLockManager
Cleans up the locks currently hold by a specific session.
cleanupSession(long) - Method in interface alluxio.worker.block.BlockStore
Cleans up the data associated with a specific session (typically a dead session).
cleanupSession(long) - Method in class alluxio.worker.block.DefaultBlockWorker
 
cleanupSession(long) - Method in class alluxio.worker.block.TieredBlockStore
 
cleanupSession(long) - Method in class alluxio.worker.block.UnderFileSystemBlockStore
Cleans up all the block information(e.g.
cleanupSession(long) - Method in interface alluxio.worker.SessionCleanable
Cleans up the session.
cleanupSessionTempBlocks(long, List<Long>) - Method in class alluxio.worker.block.BlockMetadataManager
Deprecated.
As of version 0.8.
cleanupSessionTempBlocks(long, List<Long>) - Method in class alluxio.worker.block.meta.StorageDir
Cleans up the temp block metadata for each block id passed in.
clear() - Method in class alluxio.collections.ConcurrentHashSet
 
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.master.file.meta.MountTable
Clears all the mount points except the root.
clear() - Method in class alluxio.master.metrics.MetricsStore
Clears all the metrics.
clear() - Method in class alluxio.proto.dataserver.Protocol.AsyncCacheRequest.Builder
 
clear() - Method in class alluxio.proto.dataserver.Protocol.CreateUfsFileOptions.Builder
 
clear() - Method in class alluxio.proto.dataserver.Protocol.Heartbeat.Builder
 
clear() - Method in class alluxio.proto.dataserver.Protocol.LocalBlockCloseRequest.Builder
 
clear() - Method in class alluxio.proto.dataserver.Protocol.LocalBlockCompleteRequest.Builder
 
clear() - Method in class alluxio.proto.dataserver.Protocol.LocalBlockCreateRequest.Builder
 
clear() - Method in class alluxio.proto.dataserver.Protocol.LocalBlockCreateResponse.Builder
 
clear() - Method in class alluxio.proto.dataserver.Protocol.LocalBlockOpenRequest.Builder
 
clear() - Method in class alluxio.proto.dataserver.Protocol.LocalBlockOpenResponse.Builder
 
clear() - Method in class alluxio.proto.dataserver.Protocol.OpenUfsBlockOptions.Builder
 
clear() - Method in class alluxio.proto.dataserver.Protocol.ReadRequest.Builder
 
clear() - Method in class alluxio.proto.dataserver.Protocol.ReadResponse.Builder
 
clear() - Method in class alluxio.proto.dataserver.Protocol.Response.Builder
 
clear() - Method in class alluxio.proto.dataserver.Protocol.WriteRequest.Builder
 
clear() - Method in class alluxio.proto.journal.Block.BlockContainerIdGeneratorEntry.Builder
 
clear() - Method in class alluxio.proto.journal.Block.BlockInfoEntry.Builder
 
clear() - Method in class alluxio.proto.journal.Block.DeleteBlockEntry.Builder
 
clear() - Method in class alluxio.proto.journal.File.AddMountPointEntry.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.PersistDirectoryEntry.Builder
 
clear() - Method in class alluxio.proto.journal.File.PersistFileEntry.Builder
 
clear() - Method in class alluxio.proto.journal.File.ReinitializeFileEntry.Builder
 
clear() - Method in class alluxio.proto.journal.File.RenameEntry.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.UpdateUfsModeEntry.Builder
 
clear() - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
 
clear() - Method in class alluxio.proto.journal.KeyValue.CompletePartitionEntry.Builder
 
clear() - Method in class alluxio.proto.journal.KeyValue.CompleteStoreEntry.Builder
 
clear() - Method in class alluxio.proto.journal.KeyValue.CreateStoreEntry.Builder
 
clear() - Method in class alluxio.proto.journal.KeyValue.DeleteStoreEntry.Builder
 
clear() - Method in class alluxio.proto.journal.KeyValue.MergeStoreEntry.Builder
 
clear() - Method in class alluxio.proto.journal.KeyValue.RenameStoreEntry.Builder
 
clear() - Method in class alluxio.proto.journal.Lineage.DeleteLineageEntry.Builder
 
clear() - Method in class alluxio.proto.journal.Lineage.LineageEntry.Builder
 
clear() - Method in class alluxio.proto.journal.Lineage.LineageIdGeneratorEntry.Builder
 
clear() - Method in class alluxio.thrift.AccessBlockTOptions
 
clear() - Method in class alluxio.thrift.AccessBlockTResponse
 
clear() - Method in class alluxio.thrift.AlluxioService.getServiceVersion_args
 
clear() - Method in class alluxio.thrift.AlluxioService.getServiceVersion_result
 
clear() - Method in exception alluxio.thrift.AlluxioTException
 
clear() - Method in class alluxio.thrift.BackupTOptions
 
clear() - Method in class alluxio.thrift.BackupTResponse
 
clear() - Method in class alluxio.thrift.BlockHeartbeatTOptions
 
clear() - Method in class alluxio.thrift.BlockHeartbeatTResponse
 
clear() - Method in class alluxio.thrift.BlockInfo
 
clear() - Method in class alluxio.thrift.BlockLocation
 
clear() - Method in class alluxio.thrift.BlockMasterClientService.getBlockInfo_args
 
clear() - Method in class alluxio.thrift.BlockMasterClientService.getBlockInfo_result
 
clear() - Method in class alluxio.thrift.BlockMasterClientService.getBlockMasterInfo_args
 
clear() - Method in class alluxio.thrift.BlockMasterClientService.getBlockMasterInfo_result
 
clear() - Method in class alluxio.thrift.BlockMasterClientService.getCapacityBytes_args
 
clear() - Method in class alluxio.thrift.BlockMasterClientService.getCapacityBytes_result
 
clear() - Method in class alluxio.thrift.BlockMasterClientService.getUsedBytes_args
 
clear() - Method in class alluxio.thrift.BlockMasterClientService.getUsedBytes_result
 
clear() - Method in class alluxio.thrift.BlockMasterClientService.getWorkerInfoList_args
 
clear() - Method in class alluxio.thrift.BlockMasterClientService.getWorkerInfoList_result
 
clear() - Method in class alluxio.thrift.BlockMasterClientService.getWorkerReport_args
 
clear() - Method in class alluxio.thrift.BlockMasterClientService.getWorkerReport_result
 
clear() - Method in class alluxio.thrift.BlockMasterInfo
 
clear() - Method in class alluxio.thrift.BlockMasterWorkerService.blockHeartbeat_args
 
clear() - Method in class alluxio.thrift.BlockMasterWorkerService.blockHeartbeat_result
 
clear() - Method in class alluxio.thrift.BlockMasterWorkerService.commitBlock_args
 
clear() - Method in class alluxio.thrift.BlockMasterWorkerService.commitBlock_result
 
clear() - Method in class alluxio.thrift.BlockMasterWorkerService.getWorkerId_args
 
clear() - Method in class alluxio.thrift.BlockMasterWorkerService.getWorkerId_result
 
clear() - Method in class alluxio.thrift.BlockMasterWorkerService.registerWorker_args
 
clear() - Method in class alluxio.thrift.BlockMasterWorkerService.registerWorker_result
 
clear() - Method in class alluxio.thrift.BlockWorkerClientService.accessBlock_args
 
clear() - Method in class alluxio.thrift.BlockWorkerClientService.accessBlock_result
 
clear() - Method in class alluxio.thrift.BlockWorkerClientService.cacheBlock_args
 
clear() - Method in class alluxio.thrift.BlockWorkerClientService.cacheBlock_result
 
clear() - Method in class alluxio.thrift.BlockWorkerClientService.cancelBlock_args
 
clear() - Method in class alluxio.thrift.BlockWorkerClientService.cancelBlock_result
 
clear() - Method in class alluxio.thrift.BlockWorkerClientService.lockBlock_args
 
clear() - Method in class alluxio.thrift.BlockWorkerClientService.lockBlock_result
 
clear() - Method in class alluxio.thrift.BlockWorkerClientService.promoteBlock_args
 
clear() - Method in class alluxio.thrift.BlockWorkerClientService.promoteBlock_result
 
clear() - Method in class alluxio.thrift.BlockWorkerClientService.removeBlock_args
 
clear() - Method in class alluxio.thrift.BlockWorkerClientService.removeBlock_result
 
clear() - Method in class alluxio.thrift.BlockWorkerClientService.requestBlockLocation_args
 
clear() - Method in class alluxio.thrift.BlockWorkerClientService.requestBlockLocation_result
 
clear() - Method in class alluxio.thrift.BlockWorkerClientService.requestSpace_args
 
clear() - Method in class alluxio.thrift.BlockWorkerClientService.requestSpace_result
 
clear() - Method in class alluxio.thrift.BlockWorkerClientService.sessionBlockHeartbeat_args
 
clear() - Method in class alluxio.thrift.BlockWorkerClientService.sessionBlockHeartbeat_result
 
clear() - Method in class alluxio.thrift.BlockWorkerClientService.unlockBlock_args
 
clear() - Method in class alluxio.thrift.BlockWorkerClientService.unlockBlock_result
 
clear() - Method in class alluxio.thrift.CacheBlockTOptions
 
clear() - Method in class alluxio.thrift.CacheBlockTResponse
 
clear() - Method in class alluxio.thrift.CancelBlockTOptions
 
clear() - Method in class alluxio.thrift.CancelBlockTResponse
 
clear() - Method in class alluxio.thrift.CancelUfsFileTOptions
 
clear() - Method in class alluxio.thrift.CancelUfsFileTResponse
 
clear() - Method in class alluxio.thrift.CheckConsistencyTOptions
 
clear() - Method in class alluxio.thrift.CheckConsistencyTResponse
 
clear() - Method in class alluxio.thrift.CloseUfsFileTOptions
 
clear() - Method in class alluxio.thrift.CloseUfsFileTResponse
 
clear() - Method in class alluxio.thrift.Command
 
clear() - Method in class alluxio.thrift.CommandLineJobInfo
 
clear() - Method in class alluxio.thrift.CommitBlockTOptions
 
clear() - Method in class alluxio.thrift.CommitBlockTResponse
 
clear() - Method in class alluxio.thrift.CompleteFileTOptions
 
clear() - Method in class alluxio.thrift.CompleteFileTResponse
 
clear() - Method in class alluxio.thrift.CompletePartitionTOptions
 
clear() - Method in class alluxio.thrift.CompletePartitionTResponse
 
clear() - Method in class alluxio.thrift.CompleteStoreTOptions
 
clear() - Method in class alluxio.thrift.CompleteStoreTResponse
 
clear() - Method in class alluxio.thrift.CompleteUfsFileTOptions
 
clear() - Method in class alluxio.thrift.CompleteUfsFileTReponse
 
clear() - Method in class alluxio.thrift.ConfigCheckReport
 
clear() - Method in class alluxio.thrift.ConfigProperty
 
clear() - Method in class alluxio.thrift.CreateDirectoryTOptions
 
clear() - Method in class alluxio.thrift.CreateDirectoryTResponse
 
clear() - Method in class alluxio.thrift.CreateFileTOptions
 
clear() - Method in class alluxio.thrift.CreateFileTResponse
 
clear() - Method in class alluxio.thrift.CreateLineageTOptions
 
clear() - Method in class alluxio.thrift.CreateLineageTResponse
 
clear() - Method in class alluxio.thrift.CreateStoreTOptions
 
clear() - Method in class alluxio.thrift.CreateStoreTResponse
 
clear() - Method in class alluxio.thrift.CreateUfsFileTOptions
 
clear() - Method in class alluxio.thrift.CreateUfsFileTResponse
 
clear() - Method in class alluxio.thrift.DeleteLineageTOptions
 
clear() - Method in class alluxio.thrift.DeleteLineageTResponse
 
clear() - Method in class alluxio.thrift.DeleteStoreTOptions
 
clear() - Method in class alluxio.thrift.DeleteStoreTResponse
 
clear() - Method in class alluxio.thrift.DeleteTOptions
 
clear() - Method in class alluxio.thrift.DeleteTResponse
 
clear() - Method in class alluxio.thrift.DependencyInfo
 
clear() - Method in class alluxio.thrift.FileBlockInfo
 
clear() - Method in class alluxio.thrift.FileInfo
 
clear() - Method in class alluxio.thrift.FileSystemCommand
 
clear() - Method in class alluxio.thrift.FileSystemHeartbeatTOptions
 
clear() - Method in class alluxio.thrift.FileSystemHeartbeatTResponse
 
clear() - Method in class alluxio.thrift.FileSystemMasterClientService.checkConsistency_args
 
clear() - Method in class alluxio.thrift.FileSystemMasterClientService.checkConsistency_result
 
clear() - Method in class alluxio.thrift.FileSystemMasterClientService.completeFile_args
 
clear() - Method in class alluxio.thrift.FileSystemMasterClientService.completeFile_result
 
clear() - Method in class alluxio.thrift.FileSystemMasterClientService.createDirectory_args
 
clear() - Method in class alluxio.thrift.FileSystemMasterClientService.createDirectory_result
 
clear() - Method in class alluxio.thrift.FileSystemMasterClientService.createFile_args
 
clear() - Method in class alluxio.thrift.FileSystemMasterClientService.createFile_result
 
clear() - Method in class alluxio.thrift.FileSystemMasterClientService.free_args
 
clear() - Method in class alluxio.thrift.FileSystemMasterClientService.free_result
 
clear() - Method in class alluxio.thrift.FileSystemMasterClientService.getFilePath_args
 
clear() - Method in class alluxio.thrift.FileSystemMasterClientService.getFilePath_result
 
clear() - Method in class alluxio.thrift.FileSystemMasterClientService.getMountTable_args
 
clear() - Method in class alluxio.thrift.FileSystemMasterClientService.getMountTable_result
 
clear() - Method in class alluxio.thrift.FileSystemMasterClientService.getNewBlockIdForFile_args
 
clear() - Method in class alluxio.thrift.FileSystemMasterClientService.getNewBlockIdForFile_result
 
clear() - Method in class alluxio.thrift.FileSystemMasterClientService.getStatus_args
 
clear() - Method in class alluxio.thrift.FileSystemMasterClientService.getStatus_result
 
clear() - Method in class alluxio.thrift.FileSystemMasterClientService.listStatus_args
 
clear() - Method in class alluxio.thrift.FileSystemMasterClientService.listStatus_result
 
clear() - Method in class alluxio.thrift.FileSystemMasterClientService.loadMetadata_args
 
clear() - Method in class alluxio.thrift.FileSystemMasterClientService.loadMetadata_result
 
clear() - Method in class alluxio.thrift.FileSystemMasterClientService.mount_args
 
clear() - Method in class alluxio.thrift.FileSystemMasterClientService.mount_result
 
clear() - Method in class alluxio.thrift.FileSystemMasterClientService.remove_args
 
clear() - Method in class alluxio.thrift.FileSystemMasterClientService.remove_result
 
clear() - Method in class alluxio.thrift.FileSystemMasterClientService.rename_args
 
clear() - Method in class alluxio.thrift.FileSystemMasterClientService.rename_result
 
clear() - Method in class alluxio.thrift.FileSystemMasterClientService.scheduleAsyncPersistence_args
 
clear() - Method in class alluxio.thrift.FileSystemMasterClientService.scheduleAsyncPersistence_result
 
clear() - Method in class alluxio.thrift.FileSystemMasterClientService.setAttribute_args
 
clear() - Method in class alluxio.thrift.FileSystemMasterClientService.setAttribute_result
 
clear() - Method in class alluxio.thrift.FileSystemMasterClientService.unmount_args
 
clear() - Method in class alluxio.thrift.FileSystemMasterClientService.unmount_result
 
clear() - Method in class alluxio.thrift.FileSystemMasterClientService.updateUfsMode_args
 
clear() - Method in class alluxio.thrift.FileSystemMasterClientService.updateUfsMode_result
 
clear() - Method in class alluxio.thrift.FileSystemMasterCommonTOptions
 
clear() - Method in class alluxio.thrift.FileSystemMasterWorkerService.fileSystemHeartbeat_args
 
clear() - Method in class alluxio.thrift.FileSystemMasterWorkerService.fileSystemHeartbeat_result
 
clear() - Method in class alluxio.thrift.FileSystemMasterWorkerService.getFileInfo_args
 
clear() - Method in class alluxio.thrift.FileSystemMasterWorkerService.getFileInfo_result
 
clear() - Method in class alluxio.thrift.FileSystemMasterWorkerService.getPinnedFileIds_args
 
clear() - Method in class alluxio.thrift.FileSystemMasterWorkerService.getPinnedFileIds_result
 
clear() - Method in class alluxio.thrift.FileSystemMasterWorkerService.getUfsInfo_args
 
clear() - Method in class alluxio.thrift.FileSystemMasterWorkerService.getUfsInfo_result
 
clear() - Method in class alluxio.thrift.FileSystemWorkerClientService.cancelUfsFile_args
 
clear() - Method in class alluxio.thrift.FileSystemWorkerClientService.cancelUfsFile_result
 
clear() - Method in class alluxio.thrift.FileSystemWorkerClientService.closeUfsFile_args
 
clear() - Method in class alluxio.thrift.FileSystemWorkerClientService.closeUfsFile_result
 
clear() - Method in class alluxio.thrift.FileSystemWorkerClientService.completeUfsFile_args
 
clear() - Method in class alluxio.thrift.FileSystemWorkerClientService.completeUfsFile_result
 
clear() - Method in class alluxio.thrift.FileSystemWorkerClientService.createUfsFile_args
 
clear() - Method in class alluxio.thrift.FileSystemWorkerClientService.createUfsFile_result
 
clear() - Method in class alluxio.thrift.FileSystemWorkerClientService.openUfsFile_args
 
clear() - Method in class alluxio.thrift.FileSystemWorkerClientService.openUfsFile_result
 
clear() - Method in class alluxio.thrift.FileSystemWorkerClientService.sessionFileSystemHeartbeat_args
 
clear() - Method in class alluxio.thrift.FileSystemWorkerClientService.sessionFileSystemHeartbeat_result
 
clear() - Method in class alluxio.thrift.FreeTOptions
 
clear() - Method in class alluxio.thrift.FreeTResponse
 
clear() - Method in class alluxio.thrift.GetBlockInfoTOptions
 
clear() - Method in class alluxio.thrift.GetBlockInfoTResponse
 
clear() - Method in class alluxio.thrift.GetBlockMasterInfoTOptions
 
clear() - Method in class alluxio.thrift.GetBlockMasterInfoTResponse
 
clear() - Method in class alluxio.thrift.GetCapacityBytesTOptions
 
clear() - Method in class alluxio.thrift.GetCapacityBytesTResponse
 
clear() - Method in class alluxio.thrift.GetConfigReportTOptions
 
clear() - Method in class alluxio.thrift.GetConfigReportTResponse
 
clear() - Method in class alluxio.thrift.GetConfigurationTOptions
 
clear() - Method in class alluxio.thrift.GetConfigurationTResponse
 
clear() - Method in class alluxio.thrift.GetFileInfoTOptions
 
clear() - Method in class alluxio.thrift.GetFileInfoTResponse
 
clear() - Method in class alluxio.thrift.GetFilePathTOptions
 
clear() - Method in class alluxio.thrift.GetFilePathTResponse
 
clear() - Method in class alluxio.thrift.GetLineageInfoListTOptions
 
clear() - Method in class alluxio.thrift.GetLineageInfoListTResponse
 
clear() - Method in class alluxio.thrift.GetMasterIdTOptions
 
clear() - Method in class alluxio.thrift.GetMasterIdTResponse
 
clear() - Method in class alluxio.thrift.GetMasterInfoTOptions
 
clear() - Method in class alluxio.thrift.GetMasterInfoTResponse
 
clear() - Method in class alluxio.thrift.GetMetricsTOptions
 
clear() - Method in class alluxio.thrift.GetMetricsTResponse
 
clear() - Method in class alluxio.thrift.GetMountTableTResponse
 
clear() - Method in class alluxio.thrift.GetNewBlockIdForFileTOptions
 
clear() - Method in class alluxio.thrift.GetNewBlockIdForFileTResponse
 
clear() - Method in class alluxio.thrift.GetNextKeysTOptions
 
clear() - Method in class alluxio.thrift.GetNextKeysTResponse
 
clear() - Method in class alluxio.thrift.GetPartitionInfoTOptions
 
clear() - Method in class alluxio.thrift.GetPartitionInfoTResponse
 
clear() - Method in class alluxio.thrift.GetPinnedFileIdsTOptions
 
clear() - Method in class alluxio.thrift.GetPinnedFileIdsTResponse
 
clear() - Method in class alluxio.thrift.GetServiceVersionTOptions
 
clear() - Method in class alluxio.thrift.GetServiceVersionTResponse
 
clear() - Method in class alluxio.thrift.GetSizeTOptions
 
clear() - Method in class alluxio.thrift.GetSizeTResponse
 
clear() - Method in class alluxio.thrift.GetStatusTOptions
 
clear() - Method in class alluxio.thrift.GetStatusTResponse
 
clear() - Method in class alluxio.thrift.GetTOptions
 
clear() - Method in class alluxio.thrift.GetTResponse
 
clear() - Method in class alluxio.thrift.GetUfsInfoTOptions
 
clear() - Method in class alluxio.thrift.GetUfsInfoTResponse
 
clear() - Method in class alluxio.thrift.GetUsedBytesTOptions
 
clear() - Method in class alluxio.thrift.GetUsedBytesTResponse
 
clear() - Method in class alluxio.thrift.GetWorkerIdTOptions
 
clear() - Method in class alluxio.thrift.GetWorkerIdTResponse
 
clear() - Method in class alluxio.thrift.GetWorkerInfoListTOptions
 
clear() - Method in class alluxio.thrift.GetWorkerInfoListTResponse
 
clear() - Method in class alluxio.thrift.GetWorkerReportTOptions
 
clear() - Method in class alluxio.thrift.InconsistentProperty
 
clear() - Method in class alluxio.thrift.JobConfInfo
 
clear() - Method in class alluxio.thrift.KeyValueMasterClientService.completePartition_args
 
clear() - Method in class alluxio.thrift.KeyValueMasterClientService.completePartition_result
 
clear() - Method in class alluxio.thrift.KeyValueMasterClientService.completeStore_args
 
clear() - Method in class alluxio.thrift.KeyValueMasterClientService.completeStore_result
 
clear() - Method in class alluxio.thrift.KeyValueMasterClientService.createStore_args
 
clear() - Method in class alluxio.thrift.KeyValueMasterClientService.createStore_result
 
clear() - Method in class alluxio.thrift.KeyValueMasterClientService.deleteStore_args
 
clear() - Method in class alluxio.thrift.KeyValueMasterClientService.deleteStore_result
 
clear() - Method in class alluxio.thrift.KeyValueMasterClientService.getPartitionInfo_args
 
clear() - Method in class alluxio.thrift.KeyValueMasterClientService.getPartitionInfo_result
 
clear() - Method in class alluxio.thrift.KeyValueMasterClientService.mergeStore_args
 
clear() - Method in class alluxio.thrift.KeyValueMasterClientService.mergeStore_result
 
clear() - Method in class alluxio.thrift.KeyValueMasterClientService.renameStore_args
 
clear() - Method in class alluxio.thrift.KeyValueMasterClientService.renameStore_result
 
clear() - Method in class alluxio.thrift.KeyValueWorkerClientService.get_args
 
clear() - Method in class alluxio.thrift.KeyValueWorkerClientService.get_result
 
clear() - Method in class alluxio.thrift.KeyValueWorkerClientService.getNextKeys_args
 
clear() - Method in class alluxio.thrift.KeyValueWorkerClientService.getNextKeys_result
 
clear() - Method in class alluxio.thrift.KeyValueWorkerClientService.getSize_args
 
clear() - Method in class alluxio.thrift.KeyValueWorkerClientService.getSize_result
 
clear() - Method in class alluxio.thrift.LineageInfo
 
clear() - Method in class alluxio.thrift.LineageMasterClientService.createLineage_args
 
clear() - Method in class alluxio.thrift.LineageMasterClientService.createLineage_result
 
clear() - Method in class alluxio.thrift.LineageMasterClientService.deleteLineage_args
 
clear() - Method in class alluxio.thrift.LineageMasterClientService.deleteLineage_result
 
clear() - Method in class alluxio.thrift.LineageMasterClientService.getLineageInfoList_args
 
clear() - Method in class alluxio.thrift.LineageMasterClientService.getLineageInfoList_result
 
clear() - Method in class alluxio.thrift.LineageMasterClientService.reinitializeFile_args
 
clear() - Method in class alluxio.thrift.LineageMasterClientService.reinitializeFile_result
 
clear() - Method in class alluxio.thrift.LineageMasterClientService.reportLostFile_args
 
clear() - Method in class alluxio.thrift.LineageMasterClientService.reportLostFile_result
 
clear() - Method in class alluxio.thrift.ListStatusTOptions
 
clear() - Method in class alluxio.thrift.ListStatusTResponse
 
clear() - Method in class alluxio.thrift.LoadMetadataTOptions
 
clear() - Method in class alluxio.thrift.LoadMetadataTResponse
 
clear() - Method in class alluxio.thrift.LocalityTier
 
clear() - Method in class alluxio.thrift.LockBlockTOptions
 
clear() - Method in class alluxio.thrift.LockBlockTResponse
 
clear() - Method in class alluxio.thrift.MasterHeartbeatTOptions
 
clear() - Method in class alluxio.thrift.MasterHeartbeatTResponse
 
clear() - Method in class alluxio.thrift.MasterInfo
 
clear() - Method in class alluxio.thrift.MasterNetAddress
 
clear() - Method in class alluxio.thrift.MergeStoreTOptions
 
clear() - Method in class alluxio.thrift.MergeStoreTResponse
 
clear() - Method in class alluxio.thrift.MetaMasterClientService.backup_args
 
clear() - Method in class alluxio.thrift.MetaMasterClientService.backup_result
 
clear() - Method in class alluxio.thrift.MetaMasterClientService.getConfigReport_args
 
clear() - Method in class alluxio.thrift.MetaMasterClientService.getConfigReport_result
 
clear() - Method in class alluxio.thrift.MetaMasterClientService.getConfiguration_args
 
clear() - Method in class alluxio.thrift.MetaMasterClientService.getConfiguration_result
 
clear() - Method in class alluxio.thrift.MetaMasterClientService.getMasterInfo_args
 
clear() - Method in class alluxio.thrift.MetaMasterClientService.getMasterInfo_result
 
clear() - Method in class alluxio.thrift.MetaMasterClientService.getMetrics_args
 
clear() - Method in class alluxio.thrift.MetaMasterClientService.getMetrics_result
 
clear() - Method in class alluxio.thrift.MetaMasterMasterService.getMasterId_args
 
clear() - Method in class alluxio.thrift.MetaMasterMasterService.getMasterId_result
 
clear() - Method in class alluxio.thrift.MetaMasterMasterService.masterHeartbeat_args
 
clear() - Method in class alluxio.thrift.MetaMasterMasterService.masterHeartbeat_result
 
clear() - Method in class alluxio.thrift.MetaMasterMasterService.registerMaster_args
 
clear() - Method in class alluxio.thrift.MetaMasterMasterService.registerMaster_result
 
clear() - Method in class alluxio.thrift.Metric
 
clear() - Method in class alluxio.thrift.MetricsHeartbeatTOptions
 
clear() - Method in class alluxio.thrift.MetricsHeartbeatTResponse
 
clear() - Method in class alluxio.thrift.MetricsMasterClientService.metricsHeartbeat_args
 
clear() - Method in class alluxio.thrift.MetricsMasterClientService.metricsHeartbeat_result
 
clear() - Method in class alluxio.thrift.MetricValue
 
clear() - Method in class alluxio.thrift.MountPointInfo
 
clear() - Method in class alluxio.thrift.MountTOptions
 
clear() - Method in class alluxio.thrift.MountTResponse
 
clear() - Method in class alluxio.thrift.OpenUfsFileTOptions
 
clear() - Method in class alluxio.thrift.OpenUfsFileTResponse
 
clear() - Method in class alluxio.thrift.OptionalString
 
clear() - Method in class alluxio.thrift.PartitionInfo
 
clear() - Method in class alluxio.thrift.PersistCommandOptions
 
clear() - Method in class alluxio.thrift.PersistFile
 
clear() - Method in class alluxio.thrift.PromoteBlockTOptions
 
clear() - Method in class alluxio.thrift.PromoteBlockTResponse
 
clear() - Method in class alluxio.thrift.RegisterMasterTOptions
 
clear() - Method in class alluxio.thrift.RegisterMasterTResponse
 
clear() - Method in class alluxio.thrift.RegisterWorkerTOptions
 
clear() - Method in class alluxio.thrift.RegisterWorkerTResponse
 
clear() - Method in class alluxio.thrift.ReinitializeFileTOptions
 
clear() - Method in class alluxio.thrift.ReinitializeFileTResponse
 
clear() - Method in class alluxio.thrift.RemoveBlockTOptions
 
clear() - Method in class alluxio.thrift.RemoveBlockTResponse
 
clear() - Method in class alluxio.thrift.RenameStoreTOptions
 
clear() - Method in class alluxio.thrift.RenameStoreTResponse
 
clear() - Method in class alluxio.thrift.RenameTOptions
 
clear() - Method in class alluxio.thrift.RenameTResponse
 
clear() - Method in class alluxio.thrift.ReportLostFileTOptions
 
clear() - Method in class alluxio.thrift.ReportLostFileTResponse
 
clear() - Method in class alluxio.thrift.RequestBlockLocationTOptions
 
clear() - Method in class alluxio.thrift.RequestBlockLocationTResponse
 
clear() - Method in class alluxio.thrift.RequestSpaceTOptions
 
clear() - Method in class alluxio.thrift.RequestSpaceTResponse
 
clear() - Method in class alluxio.thrift.ScheduleAsyncPersistenceTOptions
 
clear() - Method in class alluxio.thrift.ScheduleAsyncPersistenceTResponse
 
clear() - Method in class alluxio.thrift.SessionBlockHeartbeatTOptions
 
clear() - Method in class alluxio.thrift.SessionBlockHeartbeatTResponse
 
clear() - Method in class alluxio.thrift.SessionFileSystemHeartbeatTOptions
 
clear() - Method in class alluxio.thrift.SessionFileSystemHeartbeatTResponse
 
clear() - Method in class alluxio.thrift.SetAttributeTOptions
 
clear() - Method in class alluxio.thrift.SetAttributeTResponse
 
clear() - Method in class alluxio.thrift.SyncMetadataTOptions
 
clear() - Method in class alluxio.thrift.SyncMetadataTResponse
 
clear() - Method in class alluxio.thrift.TieredIdentity
 
clear() - Method in class alluxio.thrift.UfsInfo
 
clear() - Method in class alluxio.thrift.UnlockBlockTOptions
 
clear() - Method in class alluxio.thrift.UnlockBlockTResponse
 
clear() - Method in class alluxio.thrift.UnmountTOptions
 
clear() - Method in class alluxio.thrift.UnmountTResponse
 
clear() - Method in class alluxio.thrift.UpdateUfsModeTOptions
 
clear() - Method in class alluxio.thrift.UpdateUfsModeTResponse
 
clear() - Method in class alluxio.thrift.WorkerInfo
 
clear() - Method in class alluxio.thrift.WorkerNetAddress
 
clearAddMountPoint() - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
optional .alluxio.proto.journal.AddMountPointEntry add_mount_point = 2;
clearAllMetrics() - Static method in class alluxio.metrics.MetricsSystem
Resets the metric registry and removes all the metrics.
clearAlluxioOnly() - Method in class alluxio.proto.journal.File.DeleteFileEntry.Builder
optional bool alluxioOnly = 4;
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;
clearAsyncPersistRequest() - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
optional .alluxio.proto.journal.AsyncPersistRequestEntry async_persist_request = 16;
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.proto.dataserver.Protocol.AsyncCacheRequest.Builder
optional int64 block_id = 1;
clearBlockId() - Method in class alluxio.proto.dataserver.Protocol.LocalBlockCloseRequest.Builder
optional int64 block_id = 1;
clearBlockId() - Method in class alluxio.proto.dataserver.Protocol.LocalBlockCompleteRequest.Builder
optional int64 block_id = 1;
clearBlockId() - Method in class alluxio.proto.dataserver.Protocol.LocalBlockCreateRequest.Builder
optional int64 block_id = 1;
clearBlockId() - Method in class alluxio.proto.dataserver.Protocol.LocalBlockOpenRequest.Builder
optional int64 block_id = 1;
clearBlockId() - Method in class alluxio.proto.dataserver.Protocol.ReadRequest.Builder
optional int64 block_id = 1;
clearBlockId() - Method in class alluxio.proto.journal.Block.BlockInfoEntry.Builder
optional int64 block_id = 1;
clearBlockId() - Method in class alluxio.proto.journal.Block.DeleteBlockEntry.Builder
optional int64 block_id = 1;
clearBlockId() - Method in class alluxio.proto.journal.KeyValue.CompletePartitionEntry.Builder
optional int64 block_id = 4;
clearBlockIds() - Method in class alluxio.proto.journal.File.CompleteFileEntry.Builder
repeated int64 block_ids = 1;
clearBlockInfo() - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
optional .alluxio.proto.journal.BlockInfoEntry block_info = 4;
clearBlockMarks() - Method in class alluxio.worker.block.BlockMetadataManagerView
Clears all marks of blocks to move in/out in all dir views.
clearBlockMarks() - Method in class alluxio.worker.block.meta.StorageDirView
Clears all marks about blocks to move in/out in this view.
clearBlocks() - Method in class alluxio.proto.journal.File.InodeFileEntry.Builder
repeated int64 blocks = 12;
clearBlockSize() - Method in class alluxio.proto.dataserver.Protocol.OpenUfsBlockOptions.Builder
optional int64 block_size = 3;
clearBlockSizeBytes() - Method in class alluxio.proto.journal.File.InodeFileEntry.Builder
optional int64 block_size_bytes = 8;
clearBlockSizeBytes() - Method in class alluxio.proto.journal.File.ReinitializeFileEntry.Builder
optional int64 block_size_bytes = 2;
clearCache() - Static method in class alluxio.client.file.FileSystemContext
Clears the context cache.
clearCacheable() - Method in class alluxio.proto.journal.File.InodeFileEntry.Builder
optional bool cacheable = 11;
clearCancel() - Method in class alluxio.proto.dataserver.Protocol.LocalBlockCompleteRequest.Builder
optional bool cancel = 2;
clearCancel() - Method in class alluxio.proto.dataserver.Protocol.ReadRequest.Builder
optional bool cancel = 4;
clearCancel() - Method in class alluxio.proto.dataserver.Protocol.WriteRequest.Builder
optional bool cancel = 6;
clearCascade() - Method in class alluxio.proto.journal.Lineage.DeleteLineageEntry.Builder
optional bool cascade = 2;
clearClients() - Method in class alluxio.master.LocalAlluxioMaster
Clears all the clients.
clearCompleted() - Method in class alluxio.proto.journal.File.InodeFileEntry.Builder
optional bool completed = 10;
clearCompleteFile() - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
optional .alluxio.proto.journal.CompleteFileEntry complete_file = 5;
clearCompletePartition() - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
optional .alluxio.proto.journal.CompletePartitionEntry complete_partition = 21;
clearCompleteStore() - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
optional .alluxio.proto.journal.CompleteStoreEntry complete_store = 22;
clearContainerId() - Method in class alluxio.proto.journal.File.InodeDirectoryIdGeneratorEntry.Builder
optional int64 container_id = 1;
clearCreateStore() - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
optional .alluxio.proto.journal.CreateStoreEntry create_store = 23;
clearCreateUfsFileOptions() - Method in class alluxio.proto.dataserver.Protocol.WriteRequest.Builder
optional .alluxio.proto.dataserver.CreateUfsFileOptions create_ufs_file_options = 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.Lineage.LineageEntry.Builder
optional int64 creation_time_ms = 6;
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;
clearDeleteLineage() - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
optional .alluxio.proto.journal.DeleteLineageEntry delete_lineage = 7;
clearDeleteMountPoint() - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
optional .alluxio.proto.journal.DeleteMountPointEntry delete_mount_point = 8;
clearDeleteStore() - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
optional .alluxio.proto.journal.DeleteStoreEntry delete_store = 25;
clearDirectChildrenLoaded() - Method in class alluxio.proto.journal.File.InodeDirectoryEntry.Builder
optional bool direct_children_loaded = 12;
clearDstPath() - Method in class alluxio.proto.journal.File.RenameEntry.Builder
optional string dst_path = 2;
clearEof() - Method in class alluxio.proto.dataserver.Protocol.WriteRequest.Builder
optional bool eof = 5;
clearFileId() - Method in class alluxio.proto.journal.File.AsyncPersistRequestEntry.Builder
optional int64 file_id = 1;
clearFromStoreId() - Method in class alluxio.proto.journal.KeyValue.MergeStoreEntry.Builder
optional int64 from_store_id = 1;
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;
clearId() - Method in class alluxio.proto.dataserver.Protocol.WriteRequest.Builder
optional int64 id = 2;
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.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.SetAttributeEntry.Builder
optional int64 id = 1;
clearId() - Method in class alluxio.proto.journal.Lineage.LineageEntry.Builder
optional int64 id = 1;
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;
clearInputFiles() - Method in class alluxio.proto.journal.Lineage.LineageEntry.Builder
repeated int64 input_files = 2;
clearJobCommand() - Method in class alluxio.proto.journal.Lineage.LineageEntry.Builder
optional string job_command = 4;
clearJobOutputPath() - Method in class alluxio.proto.journal.Lineage.LineageEntry.Builder
optional string job_output_path = 5;
clearKey() - Method in class alluxio.proto.journal.File.StringPairEntry.Builder
optional string key = 1;
clearKeyCount() - Method in class alluxio.proto.journal.KeyValue.CompletePartitionEntry.Builder
optional int32 key_count = 5;
clearKeyLimit() - Method in class alluxio.proto.journal.KeyValue.CompletePartitionEntry.Builder
optional string key_limit = 3;
clearKeyStart() - Method in class alluxio.proto.journal.KeyValue.CompletePartitionEntry.Builder
optional string key_start = 2;
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;
clearLength() - Method in class alluxio.proto.dataserver.Protocol.AsyncCacheRequest.Builder
optional int64 length = 5;
clearLength() - Method in class alluxio.proto.dataserver.Protocol.ReadRequest.Builder
optional int64 length = 3;
clearLength() - Method in class alluxio.proto.journal.Block.BlockInfoEntry.Builder
optional int64 length = 2;
clearLength() - Method in class alluxio.proto.journal.File.CompleteFileEntry.Builder
optional int64 length = 3;
clearLength() - Method in class alluxio.proto.journal.File.InodeFileEntry.Builder
optional int64 length = 9;
clearLength() - Method in class alluxio.proto.journal.File.PersistFileEntry.Builder
optional int64 length = 2;
clearLineage() - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
optional .alluxio.proto.journal.LineageEntry lineage = 13;
clearLineageId() - Method in class alluxio.proto.journal.Lineage.DeleteLineageEntry.Builder
optional int64 lineage_id = 1;
clearLineageIdGenerator() - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
optional .alluxio.proto.journal.LineageIdGeneratorEntry lineage_id_generator = 14;
clearMaxUfsReadConcurrency() - Method in class alluxio.proto.dataserver.Protocol.OpenUfsBlockOptions.Builder
optional int32 maxUfsReadConcurrency = 4;
clearMergeStore() - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
optional .alluxio.proto.journal.MergeStoreEntry merge_store = 26;
clearMessage() - Method in class alluxio.proto.dataserver.Protocol.Response.Builder
optional string message = 2;
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;
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.AddMountPointEntry.Builder
optional int64 mount_id = 6;
clearMountPoint() - Method in class alluxio.proto.journal.File.InodeDirectoryEntry.Builder
optional bool mount_point = 11;
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;
clearNewStoreId() - Method in class alluxio.proto.journal.KeyValue.RenameStoreEntry.Builder
optional int64 new_store_id = 2;
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
optional bool no_cache = 6;
clearOffset() - Method in class alluxio.proto.dataserver.Protocol.ReadRequest.Builder
optional int64 offset = 2;
clearOffset() - Method in class alluxio.proto.dataserver.Protocol.WriteRequest.Builder
optional int64 offset = 3;
clearOffsetInFile() - Method in class alluxio.proto.dataserver.Protocol.OpenUfsBlockOptions.Builder
optional int64 offset_in_file = 2;
clearOldStoreId() - Method in class alluxio.proto.journal.KeyValue.RenameStoreEntry.Builder
optional int64 old_store_id = 1;
clearOnlyReserveSpace() - Method in class alluxio.proto.dataserver.Protocol.LocalBlockCreateRequest.Builder
optional bool only_reserve_space = 5;
clearOpenUfsBlockOptions() - Method in class alluxio.proto.dataserver.Protocol.AsyncCacheRequest.Builder
optional .alluxio.proto.dataserver.OpenUfsBlockOptions open_ufs_block_options = 4;
clearOpenUfsBlockOptions() - Method in class alluxio.proto.dataserver.Protocol.ReadRequest.Builder
optional .alluxio.proto.dataserver.OpenUfsBlockOptions open_ufs_block_options = 6;
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.SetAttributeEntry.Builder
optional int64 op_time_ms = 2;
clearOutputFileIds() - Method in class alluxio.proto.journal.Lineage.LineageEntry.Builder
repeated int64 output_file_ids = 3;
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;
clearPacketSize() - Method in class alluxio.proto.dataserver.Protocol.ReadRequest.Builder
optional int64 packet_size = 5;
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;
clearPath() - Method in class alluxio.proto.dataserver.Protocol.LocalBlockCreateResponse.Builder
optional string path = 1;
clearPath() - Method in class alluxio.proto.dataserver.Protocol.LocalBlockOpenResponse.Builder
optional string path = 1;
clearPath() - Method in class alluxio.proto.journal.File.ReinitializeFileEntry.Builder
optional string path = 1;
clearPermission() - Method in class alluxio.proto.journal.File.SetAttributeEntry.Builder
optional int32 permission = 8;
clearPersistDirectory() - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
optional .alluxio.proto.journal.PersistDirectoryEntry persist_directory = 15;
clearPersisted() - Method in class alluxio.proto.journal.File.SetAttributeEntry.Builder
optional bool persisted = 5;
clearPersistedFiles(List<Long>) - Method in class alluxio.worker.file.FileDataManager
Clears the given persisted files stored in FileDataManager.mPersistedUfsFingerprints.
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;
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;
clearPromote() - Method in class alluxio.proto.dataserver.Protocol.LocalBlockOpenRequest.Builder
optional bool promote = 2;
clearPromote() - Method in class alluxio.proto.dataserver.Protocol.ReadRequest.Builder
optional bool promote = 7;
clearProperties() - Method in class alluxio.proto.journal.File.AddMountPointEntry.Builder
repeated .alluxio.proto.journal.StringPairEntry properties = 4;
clearReadOnly() - Method in class alluxio.proto.journal.File.AddMountPointEntry.Builder
optional bool readOnly = 3;
clearRecursive() - Method in class alluxio.proto.journal.File.DeleteFileEntry.Builder
optional bool recursive = 2;
clearReinitializeFile() - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
optional .alluxio.proto.journal.ReinitializeFileEntry reinitialize_file = 18;
clearRename() - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
optional .alluxio.proto.journal.RenameEntry rename = 19;
clearRenameStore() - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
optional .alluxio.proto.journal.RenameStoreEntry rename_store = 28;
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;
clearSequenceNumber() - Method in class alluxio.proto.journal.Lineage.LineageIdGeneratorEntry.Builder
optional int64 sequence_number = 1;
clearSetAttribute() - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
optional .alluxio.proto.journal.SetAttributeEntry set_attribute = 27;
clearShared() - Method in class alluxio.proto.journal.File.AddMountPointEntry.Builder
optional bool shared = 5;
clearSourceHost() - Method in class alluxio.proto.dataserver.Protocol.AsyncCacheRequest.Builder
optional string source_host = 2;
clearSourcePort() - Method in class alluxio.proto.dataserver.Protocol.AsyncCacheRequest.Builder
optional int32 source_port = 3;
clearSpaceToReserve() - Method in class alluxio.proto.dataserver.Protocol.LocalBlockCreateRequest.Builder
optional int64 space_to_reserve = 4;
clearStatus() - Method in class alluxio.proto.dataserver.Protocol.Response.Builder
optional .alluxio.proto.status.PStatus status = 1;
clearStoreId() - Method in class alluxio.proto.journal.KeyValue.CompletePartitionEntry.Builder
optional int64 store_id = 1;
clearStoreId() - Method in class alluxio.proto.journal.KeyValue.CompleteStoreEntry.Builder
optional int64 store_id = 1;
clearStoreId() - Method in class alluxio.proto.journal.KeyValue.CreateStoreEntry.Builder
optional int64 store_id = 1;
clearStoreId() - Method in class alluxio.proto.journal.KeyValue.DeleteStoreEntry.Builder
optional int64 store_id = 1;
clearTier() - Method in class alluxio.proto.dataserver.Protocol.LocalBlockCreateRequest.Builder
optional int32 tier = 3;
clearTier() - Method in class alluxio.proto.dataserver.Protocol.WriteRequest.Builder
optional int32 tier = 4;
clearTimer(String) - Static method in class alluxio.heartbeat.HeartbeatScheduler
Removes a timer name from the scheduler if it exists.
clearToStoreId() - Method in class alluxio.proto.journal.KeyValue.MergeStoreEntry.Builder
optional int64 to_store_id = 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.ReinitializeFileEntry.Builder
optional int64 ttl = 3;
clearTtl() - Method in class alluxio.proto.journal.File.SetAttributeEntry.Builder
optional int64 ttl = 4;
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.ReinitializeFileEntry.Builder
optional .alluxio.proto.journal.PTtlAction ttlAction = 4 [default = DELETE];
clearTtlAction() - Method in class alluxio.proto.journal.File.SetAttributeEntry.Builder
optional .alluxio.proto.journal.PTtlAction ttlAction = 9 [default = DELETE];
clearType() - Method in class alluxio.proto.dataserver.Protocol.ReadResponse.Builder
optional .alluxio.proto.dataserver.ReadResponse.Type type = 1;
clearType() - Method in class alluxio.proto.dataserver.Protocol.WriteRequest.Builder
optional .alluxio.proto.dataserver.RequestType type = 1;
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;
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.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;
clearUpdateUfsMode() - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
optional .alluxio.proto.journal.UpdateUfsModeEntry update_ufs_mode = 30;
clearUser() - Method in class alluxio.proto.dataserver.Protocol.OpenUfsBlockOptions.Builder
optional string user = 7;
clearValue() - Method in class alluxio.proto.journal.File.StringPairEntry.Builder
optional string value = 2;
Client - Interface in alluxio
Interface for a client in the Alluxio system.
Client(TProtocol) - Constructor for class alluxio.thrift.AlluxioService.Client
 
Client(TProtocol, TProtocol) - Constructor for class alluxio.thrift.AlluxioService.Client
 
Client(TProtocol) - Constructor for class alluxio.thrift.BlockMasterClientService.Client
 
Client(TProtocol, TProtocol) - Constructor for class alluxio.thrift.BlockMasterClientService.Client
 
Client(TProtocol) - Constructor for class alluxio.thrift.BlockMasterWorkerService.Client
 
Client(TProtocol, TProtocol) - Constructor for class alluxio.thrift.BlockMasterWorkerService.Client
 
Client(TProtocol) - Constructor for class alluxio.thrift.BlockWorkerClientService.Client
 
Client(TProtocol, TProtocol) - Constructor for class alluxio.thrift.BlockWorkerClientService.Client
 
Client(TProtocol) - Constructor for class alluxio.thrift.FileSystemMasterClientService.Client
 
Client(TProtocol, TProtocol) - Constructor for class alluxio.thrift.FileSystemMasterClientService.Client
 
Client(TProtocol) - Constructor for class alluxio.thrift.FileSystemMasterWorkerService.Client
 
Client(TProtocol, TProtocol) - Constructor for class alluxio.thrift.FileSystemMasterWorkerService.Client
 
Client(TProtocol) - Constructor for class alluxio.thrift.FileSystemWorkerClientService.Client
 
Client(TProtocol, TProtocol) - Constructor for class alluxio.thrift.FileSystemWorkerClientService.Client
 
Client(TProtocol) - Constructor for class alluxio.thrift.KeyValueMasterClientService.Client
 
Client(TProtocol, TProtocol) - Constructor for class alluxio.thrift.KeyValueMasterClientService.Client
 
Client(TProtocol) - Constructor for class alluxio.thrift.KeyValueWorkerClientService.Client
 
Client(TProtocol, TProtocol) - Constructor for class alluxio.thrift.KeyValueWorkerClientService.Client
 
Client(TProtocol) - Constructor for class alluxio.thrift.LineageMasterClientService.Client
 
Client(TProtocol, TProtocol) - Constructor for class alluxio.thrift.LineageMasterClientService.Client
 
Client(TProtocol) - Constructor for class alluxio.thrift.MetaMasterClientService.Client
 
Client(TProtocol, TProtocol) - Constructor for class alluxio.thrift.MetaMasterClientService.Client
 
Client(TProtocol) - Constructor for class alluxio.thrift.MetaMasterMasterService.Client
 
Client(TProtocol, TProtocol) - Constructor for class alluxio.thrift.MetaMasterMasterService.Client
 
Client(TProtocol) - Constructor for class alluxio.thrift.MetricsMasterClientService.Client
 
Client(TProtocol, TProtocol) - Constructor for class alluxio.thrift.MetricsMasterClientService.Client
 
clientHeartbeat(String, String, List<Metric>) - Method in class alluxio.master.metrics.DefaultMetricsMaster
 
clientHeartbeat(String, String, List<Metric>) - Method in interface alluxio.master.metrics.MetricsMaster
Handles the client's heartbeat request for metrics collection.
ClientMasterSync - Class in alluxio.client.metrics
Task that carries the client metrics information to master through heartheat.
ClientMasterSync(MetricsMasterClient, FileSystemContext) - Constructor for class alluxio.client.metrics.ClientMasterSync
Constructs a new ClientMasterSync.
ClientMetrics - Class in alluxio.metrics
Metrics of an Alluxio client.
ClientPool - Class in alluxio.master
Keeps a collection of all clients (FileSystem) returned.
ClientRWLock - Class in alluxio.worker.block
Read/write lock associated with clients rather than threads.
ClientRWLock() - Constructor for class alluxio.worker.block.ClientRWLock
Constructs a new ClientRWLock.
CliUtils - Class in alluxio.cli
Utilities to run the examples.
clone() - Method in class alluxio.proto.dataserver.Protocol.AsyncCacheRequest.Builder
 
clone() - Method in class alluxio.proto.dataserver.Protocol.CreateUfsFileOptions.Builder
 
clone() - Method in class alluxio.proto.dataserver.Protocol.Heartbeat.Builder
 
clone() - Method in class alluxio.proto.dataserver.Protocol.LocalBlockCloseRequest.Builder
 
clone() - Method in class alluxio.proto.dataserver.Protocol.LocalBlockCompleteRequest.Builder
 
clone() - Method in class alluxio.proto.dataserver.Protocol.LocalBlockCreateRequest.Builder
 
clone() - Method in class alluxio.proto.dataserver.Protocol.LocalBlockCreateResponse.Builder
 
clone() - Method in class alluxio.proto.dataserver.Protocol.LocalBlockOpenRequest.Builder
 
clone() - Method in class alluxio.proto.dataserver.Protocol.LocalBlockOpenResponse.Builder
 
clone() - Method in class alluxio.proto.dataserver.Protocol.OpenUfsBlockOptions.Builder
 
clone() - Method in class alluxio.proto.dataserver.Protocol.ReadRequest.Builder
 
clone() - Method in class alluxio.proto.dataserver.Protocol.ReadResponse.Builder
 
clone() - Method in class alluxio.proto.dataserver.Protocol.Response.Builder
 
clone() - Method in class alluxio.proto.dataserver.Protocol.WriteRequest.Builder
 
clone() - Method in class alluxio.proto.journal.Block.BlockContainerIdGeneratorEntry.Builder
 
clone() - Method in class alluxio.proto.journal.Block.BlockInfoEntry.Builder
 
clone() - Method in class alluxio.proto.journal.Block.DeleteBlockEntry.Builder
 
clone() - Method in class alluxio.proto.journal.File.AddMountPointEntry.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.PersistDirectoryEntry.Builder
 
clone() - Method in class alluxio.proto.journal.File.PersistFileEntry.Builder
 
clone() - Method in class alluxio.proto.journal.File.ReinitializeFileEntry.Builder
 
clone() - Method in class alluxio.proto.journal.File.RenameEntry.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.UpdateUfsModeEntry.Builder
 
clone() - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
 
clone() - Method in class alluxio.proto.journal.KeyValue.CompletePartitionEntry.Builder
 
clone() - Method in class alluxio.proto.journal.KeyValue.CompleteStoreEntry.Builder
 
clone() - Method in class alluxio.proto.journal.KeyValue.CreateStoreEntry.Builder
 
clone() - Method in class alluxio.proto.journal.KeyValue.DeleteStoreEntry.Builder
 
clone() - Method in class alluxio.proto.journal.KeyValue.MergeStoreEntry.Builder
 
clone() - Method in class alluxio.proto.journal.KeyValue.RenameStoreEntry.Builder
 
clone() - Method in class alluxio.proto.journal.Lineage.DeleteLineageEntry.Builder
 
clone() - Method in class alluxio.proto.journal.Lineage.LineageEntry.Builder
 
clone() - Method in class alluxio.proto.journal.Lineage.LineageIdGeneratorEntry.Builder
 
cloneByteBuffer(ByteBuffer) - Static method in class alluxio.util.io.BufferUtils
Clones a ByteBuffer.
cloneByteBufferList(List<ByteBuffer>) - Static method in class alluxio.util.io.BufferUtils
Clones a list of ByteBuffers.
CloneStoreMapper() - Constructor for class alluxio.examples.keyvalue.hadoop.CloneStoreMapReduce.CloneStoreMapper
CloneStoreMapReduce - Class in alluxio.examples.keyvalue.hadoop
This MapReduce job reads a key-value store and saves the same key-value data to another key-value store with a different URI.
CloneStoreMapReduce() - Constructor for class alluxio.examples.keyvalue.hadoop.CloneStoreMapReduce
Constructs a new CloneStoreMapReduce.
CloneStoreMapReduce.CloneStoreMapper - Class in alluxio.examples.keyvalue.hadoop
The mapper emits all key-value pairs it receives to reducers.
CloneStoreMapReduce.CloneStoreReducer - Class in alluxio.examples.keyvalue.hadoop
The reducer writes all key-value pairs it receives to the new key-value store.
CloneStoreReducer() - Constructor for class alluxio.examples.keyvalue.hadoop.CloneStoreMapReduce.CloneStoreReducer
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.client.block.stream.BlockInStream
 
close() - Method in class alluxio.client.block.stream.BlockOutStream
 
close() - Method in class alluxio.client.block.stream.LocalFilePacketReader
 
close() - Method in class alluxio.client.block.stream.LocalFilePacketReader.Factory
 
close() - Method in class alluxio.client.block.stream.LocalFilePacketWriter
 
close() - Method in class alluxio.client.block.stream.NettyPacketReader
 
close() - Method in class alluxio.client.block.stream.NettyPacketReader.Factory
 
close() - Method in class alluxio.client.block.stream.NettyPacketWriter
 
close() - Method in class alluxio.client.file.FileInStream
 
close() - Method in class alluxio.client.file.FileOutStream
 
close() - Method in class alluxio.client.file.FileSystemContext
Closes all the resources associated with the context.
close() - Method in class alluxio.client.keyvalue.ByteBufferKeyValuePartitionReader
 
close() - Method in class alluxio.client.lineage.DummyFileOutputStream
 
close() - Method in class alluxio.client.metrics.ClientMasterSync
 
close() - Method in class alluxio.hadoop.HdfsFileInputStream
 
close() - Method in interface alluxio.heartbeat.HeartbeatExecutor
Cleans up any resources used by the heartbeat executor.
close() - Method in interface alluxio.master.audit.AuditContext
 
close() - Method in class alluxio.master.ClientPool
 
close() - Method in class alluxio.master.file.BlockIntegrityChecker
 
close() - Method in class alluxio.master.file.DefaultBlockDeletionContext
 
close() - Method in class alluxio.master.file.FileSystemMasterAuditContext
 
close() - Method in class alluxio.master.file.meta.InodeLockList
 
close() - Method in class alluxio.master.file.meta.InodePathPair
 
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.NoopBlockDeletionContext
 
close() - Method in class alluxio.master.file.RpcContext
 
close() - Method in interface alluxio.master.journal.JournalContext
 
close() - Method in class alluxio.master.journal.JournalEntryStreamReader
 
close() - Method in class alluxio.master.journal.MasterJournalContext
 
close() - Method in class alluxio.master.journal.noop.NoopJournal
 
close() - Method in class alluxio.master.journal.noop.NoopJournalReader
 
close() - Method in class alluxio.master.journal.NoopJournalContext
 
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.lineage.checkpoint.CheckpointSchedulingExecutor
 
close() - Method in class alluxio.master.lineage.recompute.RecomputeExecutor
 
close() - Method in class alluxio.master.meta.MetaMasterSync
 
close() - Method in class alluxio.master.PrimarySelectorClient
 
close() - Method in class alluxio.master.ZkMasterInquireClient
 
close() - Method in class alluxio.multi.process.Master
 
close() - Method in class alluxio.multi.process.Worker
 
close() - Method in class alluxio.network.thrift.BootstrapClientTransport
 
close() - Method in class alluxio.network.thrift.BootstrapServerTransport
 
close() - Method in class alluxio.network.thrift.PeekableTransport
 
close() - Method in class alluxio.network.thrift.SocketTrackingTServerSocket
 
CLOSE - Static variable in class alluxio.proxy.StreamsRestServiceHandler
 
close(Integer) - Method in class alluxio.proxy.StreamsRestServiceHandler
 
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.ResourcePool
Closes the resource pool.
close() - Method in class alluxio.underfs.AbstractUfsManager
 
close() - Method in class alluxio.underfs.AtomicFileOutputStream
 
close() - Method in class alluxio.underfs.cos.COSOutputStream
Closes this output stream.
close() - Method in class alluxio.underfs.gcs.GCSInputStream
 
close() - Method in class alluxio.underfs.gcs.GCSOutputStream
 
close() - Method in class alluxio.underfs.hdfs.HdfsUnderFileOutputStream
 
close() - Method in class alluxio.underfs.hdfs.HdfsUnderFileSystem
 
close() - Method in class alluxio.underfs.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.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 interface alluxio.util.interfaces.Scoped
 
close() - Method in class alluxio.worker.block.BlockMasterClientPool
 
close() - Method in class alluxio.worker.block.BlockMasterSync
 
close() - Method in class alluxio.worker.block.io.LocalFileBlockReader
 
close() - Method in class alluxio.worker.block.io.LocalFileBlockWriter
 
close() - Method in class alluxio.worker.block.PinListSync
 
close() - Method in class alluxio.worker.block.RemoteBlockReader
 
close() - Method in class alluxio.worker.block.SpaceReserver
 
close() - Method in class alluxio.worker.block.UnderFileSystemBlockReader
Closes the block reader.
close() - Method in class alluxio.worker.netty.NettyDataServer
 
CloseableResource<T> - Class in alluxio.resource
A CloseableResource<T> is a wrapper around a resource of type T which must do some sort of cleanup when it is no longer in use.
CloseableResource(T) - Constructor for class alluxio.resource.CloseableResource
Creates a CloseableResource wrapper around the given resource.
closeAndRethrow(Closer, Throwable) - Static method in class alluxio.util.CommonUtils
Closes the Closer and re-throws the Throwable.
closeChannel(Channel) - Static method in class alluxio.util.CommonUtils
Closes the netty channel from outside the netty I/O thread.
closeChannelSync(Channel) - Static method in class alluxio.util.CommonUtils
Closes the netty channel synchronously.
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(FileSystemMasterClient) - Method in class alluxio.client.file.FileSystemMasterClientPool
 
closeResource(Channel) - Method in class alluxio.network.netty.NettyChannelPool
 
closeResource(T) - Method in class alluxio.resource.DynamicResourcePool
Closes the resource.
closeResourceSync(BlockMasterClient) - Method in class alluxio.client.block.BlockMasterClientPool
 
closeResourceSync(FileSystemMasterClient) - Method in class alluxio.client.file.FileSystemMasterClientPool
 
closeResourceSync(Channel) - Method in class alluxio.network.netty.NettyChannelPool
 
closeResourceSync(T) - Method in class alluxio.resource.DynamicResourcePool
Similar as above but this guarantees that the resource is closed after the function returns unless it fails to close.
closeUfsBlock(long, long) - Method in interface alluxio.worker.block.BlockWorker
Closes a UFS block for a client session.
closeUfsBlock(long, long) - Method in class alluxio.worker.block.DefaultBlockWorker
 
closeUfsFile(long, long, CloseUfsFileTOptions, AsyncMethodCallback) - Method in class alluxio.thrift.FileSystemWorkerClientService.AsyncClient
 
closeUfsFile(long, long, CloseUfsFileTOptions, AsyncMethodCallback) - Method in interface alluxio.thrift.FileSystemWorkerClientService.AsyncIface
 
closeUfsFile() - Constructor for class alluxio.thrift.FileSystemWorkerClientService.AsyncProcessor.closeUfsFile
 
closeUfsFile(long, long, CloseUfsFileTOptions) - Method in class alluxio.thrift.FileSystemWorkerClientService.Client
 
closeUfsFile(long, long, CloseUfsFileTOptions) - Method in interface alluxio.thrift.FileSystemWorkerClientService.Iface
Closes a file in the under file system which was previously opened for reading.
closeUfsFile() - Constructor for class alluxio.thrift.FileSystemWorkerClientService.Processor.closeUfsFile
 
closeUfsFile(long, long, CloseUfsFileTOptions) - Method in class alluxio.worker.file.FileSystemWorkerClientServiceHandler
 
closeUfsFile_args() - Constructor for class alluxio.thrift.FileSystemWorkerClientService.closeUfsFile_args
 
closeUfsFile_args(long, long, CloseUfsFileTOptions) - Constructor for class alluxio.thrift.FileSystemWorkerClientService.closeUfsFile_args
 
closeUfsFile_args(FileSystemWorkerClientService.closeUfsFile_args) - Constructor for class alluxio.thrift.FileSystemWorkerClientService.closeUfsFile_args
Performs a deep copy on other.
closeUfsFile_call(long, long, CloseUfsFileTOptions, AsyncMethodCallback, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class alluxio.thrift.FileSystemWorkerClientService.AsyncClient.closeUfsFile_call
 
closeUfsFile_result() - Constructor for class alluxio.thrift.FileSystemWorkerClientService.closeUfsFile_result
 
closeUfsFile_result(CloseUfsFileTResponse, AlluxioTException) - Constructor for class alluxio.thrift.FileSystemWorkerClientService.closeUfsFile_result
 
closeUfsFile_result(FileSystemWorkerClientService.closeUfsFile_result) - Constructor for class alluxio.thrift.FileSystemWorkerClientService.closeUfsFile_result
Performs a deep copy on other.
CloseUfsFileOptions - Class in alluxio.client.file.options
Options for closing a UFS file.
CloseUfsFileTOptions - Class in alluxio.thrift
 
CloseUfsFileTOptions() - Constructor for class alluxio.thrift.CloseUfsFileTOptions
 
CloseUfsFileTOptions(CloseUfsFileTOptions) - Constructor for class alluxio.thrift.CloseUfsFileTOptions
Performs a deep copy on other.
CloseUfsFileTOptions._Fields - Enum in alluxio.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
CloseUfsFileTResponse - Class in alluxio.thrift
 
CloseUfsFileTResponse() - Constructor for class alluxio.thrift.CloseUfsFileTResponse
 
CloseUfsFileTResponse(CloseUfsFileTResponse) - Constructor for class alluxio.thrift.CloseUfsFileTResponse
Performs a deep copy on other.
CloseUfsFileTResponse._Fields - Enum in alluxio.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
CLUSTER - Static variable in class alluxio.metrics.MetricsSystem
 
CLUSTER_DEFAULT - Static variable in class alluxio.conf.Source
 
ClusterConfConsistencyValidationTask - Class in alluxio.cli.validation
Task for validating system limit for current user.
ClusterConfConsistencyValidationTask() - Constructor for class alluxio.cli.validation.ClusterConfConsistencyValidationTask
 
Command - Interface in alluxio.cli
An interface for all the commands that can be run from a shell.
Command - Class in alluxio.thrift
 
Command() - Constructor for class alluxio.thrift.Command
 
Command(CommandType, List<Long>) - Constructor for class alluxio.thrift.Command
 
Command(Command) - Constructor for class alluxio.thrift.Command
Performs a deep copy on other.
Command._Fields - Enum in alluxio.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
CommandLineJob - Class in alluxio.job
A job that wraps a programmed run by command line.
CommandLineJob(String, JobConf) - Constructor for class alluxio.job.CommandLineJob
Creates a new instance of CommandLineJob.
CommandLineJobInfo - Class in alluxio.thrift
 
CommandLineJobInfo() - Constructor for class alluxio.thrift.CommandLineJobInfo
 
CommandLineJobInfo(String, JobConfInfo) - Constructor for class alluxio.thrift.CommandLineJobInfo
 
CommandLineJobInfo(CommandLineJobInfo) - Constructor for class alluxio.thrift.CommandLineJobInfo
Performs a deep copy on other.
CommandLineJobInfo - Class in alluxio.wire
The lineage command-line job information.
CommandLineJobInfo() - Constructor for class alluxio.wire.CommandLineJobInfo
Creates a new instance of CommandLineJobInfo.
CommandLineJobInfo._Fields - Enum in alluxio.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
CommandType - Enum in alluxio.thrift
 
CommandUtils - Class in alluxio.cli
Class for convenience methods used by instances of Command.
commit() - Method in class alluxio.security.login.AlluxioLoginModule
Commits the authentication (second phase).
commit() - Method in class alluxio.security.login.AppLoginModule
Commits the authentication (second phase).
commitBlock(long, long, String, long, long) - Method in interface alluxio.master.block.BlockMaster
Marks a block as committed on a specific worker.
commitBlock(long, long, String, long, long, CommitBlockTOptions) - Method in class alluxio.master.block.BlockMasterWorkerServiceHandler
 
commitBlock(long, long, String, long, long) - Method in class alluxio.master.block.DefaultBlockMaster
 
commitBlock(long, long, String, long, long, CommitBlockTOptions, AsyncMethodCallback) - Method in class alluxio.thrift.BlockMasterWorkerService.AsyncClient
 
commitBlock(long, long, String, long, long, CommitBlockTOptions, AsyncMethodCallback) - Method in interface alluxio.thrift.BlockMasterWorkerService.AsyncIface
 
commitBlock() - Constructor for class alluxio.thrift.BlockMasterWorkerService.AsyncProcessor.commitBlock
 
commitBlock(long, long, String, long, long, CommitBlockTOptions) - Method in class alluxio.thrift.BlockMasterWorkerService.Client
 
commitBlock(long, long, String, long, long, CommitBlockTOptions) - Method in interface alluxio.thrift.BlockMasterWorkerService.Iface
Marks the given block as committed.
commitBlock() - Constructor for class alluxio.thrift.BlockMasterWorkerService.Processor.commitBlock
 
commitBlock(long, long, String, long, long) - Method in class alluxio.worker.block.BlockMasterClient
Commits a block on a worker.
commitBlock(long, long) - Method in interface alluxio.worker.block.BlockStore
Commits a temporary block to the local store.
commitBlock(long, long) - Method in interface alluxio.worker.block.BlockWorker
Commits a block to Alluxio managed space.
commitBlock(long, long) - Method in class alluxio.worker.block.DefaultBlockWorker
 
commitBlock(long, long) - Method in class alluxio.worker.block.TieredBlockStore
 
commitBlock_args() - Constructor for class alluxio.thrift.BlockMasterWorkerService.commitBlock_args
 
commitBlock_args(long, long, String, long, long, CommitBlockTOptions) - Constructor for class alluxio.thrift.BlockMasterWorkerService.commitBlock_args
 
commitBlock_args(BlockMasterWorkerService.commitBlock_args) - Constructor for class alluxio.thrift.BlockMasterWorkerService.commitBlock_args
Performs a deep copy on other.
commitBlock_call(long, long, String, long, long, CommitBlockTOptions, AsyncMethodCallback, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class alluxio.thrift.BlockMasterWorkerService.AsyncClient.commitBlock_call
 
commitBlock_result() - Constructor for class alluxio.thrift.BlockMasterWorkerService.commitBlock_result
 
commitBlock_result(CommitBlockTResponse, AlluxioTException) - Constructor for class alluxio.thrift.BlockMasterWorkerService.commitBlock_result
 
commitBlock_result(BlockMasterWorkerService.commitBlock_result) - Constructor for class alluxio.thrift.BlockMasterWorkerService.commitBlock_result
Performs a deep copy on other.
commitBlockInUFS(long, long) - Method in interface alluxio.master.block.BlockMaster
Marks a block as committed, but without a worker location.
commitBlockInUFS(long, long) - Method in class alluxio.master.block.DefaultBlockMaster
 
CommitBlockTOptions - Class in alluxio.thrift
 
CommitBlockTOptions() - Constructor for class alluxio.thrift.CommitBlockTOptions
 
CommitBlockTOptions(CommitBlockTOptions) - Constructor for class alluxio.thrift.CommitBlockTOptions
Performs a deep copy on other.
CommitBlockTOptions._Fields - Enum in alluxio.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
CommitBlockTResponse - Class in alluxio.thrift
 
CommitBlockTResponse() - Constructor for class alluxio.thrift.CommitBlockTResponse
 
CommitBlockTResponse(CommitBlockTResponse) - Constructor for class alluxio.thrift.CommitBlockTResponse
Performs a deep copy on other.
CommitBlockTResponse._Fields - Enum in alluxio.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
commitPath(StorageDir, long) - Static method in class alluxio.worker.block.meta.AbstractBlockMeta
Committed block is stored in BlockStore under its StorageDir as a block file named after its blockId.
commitTask(TaskAttemptContext) - Method in class alluxio.hadoop.mapreduce.KeyValueOutputCommitter

Merges the completed key-value store under the task's temporary output directory to the key-value store at job output directory, then calls FileOutputCommitter.commitTask(TaskAttemptContext).

commitTempBlockMeta(TempBlockMeta) - Method in class alluxio.worker.block.BlockMetadataManager
Commits a temp block.
COMMON_SSH_OPTS - Static variable in class alluxio.util.ShellUtils
Common shell OPTS to prevent stalling.
CommonMetrics - Class in alluxio.metrics
Common metrics between Alluxio Servers and Clients.
CommonOptions - Class in alluxio.wire
Common method options.
CommonOptions() - Constructor for class alluxio.wire.CommonOptions
 
CommonOptions(FileSystemMasterCommonTOptions) - Constructor for class alluxio.wire.CommonOptions
Creates a new instance of CommonOptions from FileSystemMasterCommonTOptions.
CommonOptions(CommonOptions) - Constructor for class alluxio.wire.CommonOptions
Copies from CommonOptions.
CommonUtils - Class in alluxio.util
Common utilities shared by all components in Alluxio.
CommonUtils.ProcessType - Enum in alluxio.util
Alluxio process types.
compare(WorkerInfo, WorkerInfo) - Method in class alluxio.wire.WorkerInfo.LastContactSecComparator
 
compareAndSwap(PersistenceState, PersistenceState) - Method in class alluxio.master.file.meta.Inode
Compare-and-swaps the persistence state.
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(KeyValuePair) - Method in class alluxio.client.keyvalue.KeyValuePair
Compares this key-value pair to another.
compareTo(Source) - Method in class alluxio.conf.Source
 
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(PropertyKey) - Method in class alluxio.PropertyKey
 
compareTo(URI) - Method in class alluxio.StandardURI
 
compareTo(AccessBlockTOptions) - Method in class alluxio.thrift.AccessBlockTOptions
 
compareTo(AccessBlockTResponse) - Method in class alluxio.thrift.AccessBlockTResponse
 
compareTo(AlluxioService.getServiceVersion_args) - Method in class alluxio.thrift.AlluxioService.getServiceVersion_args
 
compareTo(AlluxioService.getServiceVersion_result) - Method in class alluxio.thrift.AlluxioService.getServiceVersion_result
 
compareTo(AlluxioTException) - Method in exception alluxio.thrift.AlluxioTException
 
compareTo(BackupTOptions) - Method in class alluxio.thrift.BackupTOptions
 
compareTo(BackupTResponse) - Method in class alluxio.thrift.BackupTResponse
 
compareTo(BlockHeartbeatTOptions) - Method in class alluxio.thrift.BlockHeartbeatTOptions
 
compareTo(BlockHeartbeatTResponse) - Method in class alluxio.thrift.BlockHeartbeatTResponse
 
compareTo(BlockInfo) - Method in class alluxio.thrift.BlockInfo
 
compareTo(BlockLocation) - Method in class alluxio.thrift.BlockLocation
 
compareTo(BlockMasterClientService.getBlockInfo_args) - Method in class alluxio.thrift.BlockMasterClientService.getBlockInfo_args
 
compareTo(BlockMasterClientService.getBlockInfo_result) - Method in class alluxio.thrift.BlockMasterClientService.getBlockInfo_result
 
compareTo(BlockMasterClientService.getBlockMasterInfo_args) - Method in class alluxio.thrift.BlockMasterClientService.getBlockMasterInfo_args
 
compareTo(BlockMasterClientService.getBlockMasterInfo_result) - Method in class alluxio.thrift.BlockMasterClientService.getBlockMasterInfo_result
 
compareTo(BlockMasterClientService.getCapacityBytes_args) - Method in class alluxio.thrift.BlockMasterClientService.getCapacityBytes_args
 
compareTo(BlockMasterClientService.getCapacityBytes_result) - Method in class alluxio.thrift.BlockMasterClientService.getCapacityBytes_result
 
compareTo(BlockMasterClientService.getUsedBytes_args) - Method in class alluxio.thrift.BlockMasterClientService.getUsedBytes_args
 
compareTo(BlockMasterClientService.getUsedBytes_result) - Method in class alluxio.thrift.BlockMasterClientService.getUsedBytes_result
 
compareTo(BlockMasterClientService.getWorkerInfoList_args) - Method in class alluxio.thrift.BlockMasterClientService.getWorkerInfoList_args
 
compareTo(BlockMasterClientService.getWorkerInfoList_result) - Method in class alluxio.thrift.BlockMasterClientService.getWorkerInfoList_result
 
compareTo(BlockMasterClientService.getWorkerReport_args) - Method in class alluxio.thrift.BlockMasterClientService.getWorkerReport_args
 
compareTo(BlockMasterClientService.getWorkerReport_result) - Method in class alluxio.thrift.BlockMasterClientService.getWorkerReport_result
 
compareTo(BlockMasterInfo) - Method in class alluxio.thrift.BlockMasterInfo
 
compareTo(BlockMasterWorkerService.blockHeartbeat_args) - Method in class alluxio.thrift.BlockMasterWorkerService.blockHeartbeat_args
 
compareTo(BlockMasterWorkerService.blockHeartbeat_result) - Method in class alluxio.thrift.BlockMasterWorkerService.blockHeartbeat_result
 
compareTo(BlockMasterWorkerService.commitBlock_args) - Method in class alluxio.thrift.BlockMasterWorkerService.commitBlock_args
 
compareTo(BlockMasterWorkerService.commitBlock_result) - Method in class alluxio.thrift.BlockMasterWorkerService.commitBlock_result
 
compareTo(BlockMasterWorkerService.getWorkerId_args) - Method in class alluxio.thrift.BlockMasterWorkerService.getWorkerId_args
 
compareTo(BlockMasterWorkerService.getWorkerId_result) - Method in class alluxio.thrift.BlockMasterWorkerService.getWorkerId_result
 
compareTo(BlockMasterWorkerService.registerWorker_args) - Method in class alluxio.thrift.BlockMasterWorkerService.registerWorker_args
 
compareTo(BlockMasterWorkerService.registerWorker_result) - Method in class alluxio.thrift.BlockMasterWorkerService.registerWorker_result
 
compareTo(BlockWorkerClientService.accessBlock_args) - Method in class alluxio.thrift.BlockWorkerClientService.accessBlock_args
 
compareTo(BlockWorkerClientService.accessBlock_result) - Method in class alluxio.thrift.BlockWorkerClientService.accessBlock_result
 
compareTo(BlockWorkerClientService.cacheBlock_args) - Method in class alluxio.thrift.BlockWorkerClientService.cacheBlock_args
 
compareTo(BlockWorkerClientService.cacheBlock_result) - Method in class alluxio.thrift.BlockWorkerClientService.cacheBlock_result
 
compareTo(BlockWorkerClientService.cancelBlock_args) - Method in class alluxio.thrift.BlockWorkerClientService.cancelBlock_args
 
compareTo(BlockWorkerClientService.cancelBlock_result) - Method in class alluxio.thrift.BlockWorkerClientService.cancelBlock_result
 
compareTo(BlockWorkerClientService.lockBlock_args) - Method in class alluxio.thrift.BlockWorkerClientService.lockBlock_args
 
compareTo(BlockWorkerClientService.lockBlock_result) - Method in class alluxio.thrift.BlockWorkerClientService.lockBlock_result
 
compareTo(BlockWorkerClientService.promoteBlock_args) - Method in class alluxio.thrift.BlockWorkerClientService.promoteBlock_args
 
compareTo(BlockWorkerClientService.promoteBlock_result) - Method in class alluxio.thrift.BlockWorkerClientService.promoteBlock_result
 
compareTo(BlockWorkerClientService.removeBlock_args) - Method in class alluxio.thrift.BlockWorkerClientService.removeBlock_args
 
compareTo(BlockWorkerClientService.removeBlock_result) - Method in class alluxio.thrift.BlockWorkerClientService.removeBlock_result
 
compareTo(BlockWorkerClientService.requestBlockLocation_args) - Method in class alluxio.thrift.BlockWorkerClientService.requestBlockLocation_args
 
compareTo(BlockWorkerClientService.requestBlockLocation_result) - Method in class alluxio.thrift.BlockWorkerClientService.requestBlockLocation_result
 
compareTo(BlockWorkerClientService.requestSpace_args) - Method in class alluxio.thrift.BlockWorkerClientService.requestSpace_args
 
compareTo(BlockWorkerClientService.requestSpace_result) - Method in class alluxio.thrift.BlockWorkerClientService.requestSpace_result
 
compareTo(BlockWorkerClientService.sessionBlockHeartbeat_args) - Method in class alluxio.thrift.BlockWorkerClientService.sessionBlockHeartbeat_args
 
compareTo(BlockWorkerClientService.sessionBlockHeartbeat_result) - Method in class alluxio.thrift.BlockWorkerClientService.sessionBlockHeartbeat_result
 
compareTo(BlockWorkerClientService.unlockBlock_args) - Method in class alluxio.thrift.BlockWorkerClientService.unlockBlock_args
 
compareTo(BlockWorkerClientService.unlockBlock_result) - Method in class alluxio.thrift.BlockWorkerClientService.unlockBlock_result
 
compareTo(CacheBlockTOptions) - Method in class alluxio.thrift.CacheBlockTOptions
 
compareTo(CacheBlockTResponse) - Method in class alluxio.thrift.CacheBlockTResponse
 
compareTo(CancelBlockTOptions) - Method in class alluxio.thrift.CancelBlockTOptions
 
compareTo(CancelBlockTResponse) - Method in class alluxio.thrift.CancelBlockTResponse
 
compareTo(CancelUfsFileTOptions) - Method in class alluxio.thrift.CancelUfsFileTOptions
 
compareTo(CancelUfsFileTResponse) - Method in class alluxio.thrift.CancelUfsFileTResponse
 
compareTo(CheckConsistencyTOptions) - Method in class alluxio.thrift.CheckConsistencyTOptions
 
compareTo(CheckConsistencyTResponse) - Method in class alluxio.thrift.CheckConsistencyTResponse
 
compareTo(CloseUfsFileTOptions) - Method in class alluxio.thrift.CloseUfsFileTOptions
 
compareTo(CloseUfsFileTResponse) - Method in class alluxio.thrift.CloseUfsFileTResponse
 
compareTo(Command) - Method in class alluxio.thrift.Command
 
compareTo(CommandLineJobInfo) - Method in class alluxio.thrift.CommandLineJobInfo
 
compareTo(CommitBlockTOptions) - Method in class alluxio.thrift.CommitBlockTOptions
 
compareTo(CommitBlockTResponse) - Method in class alluxio.thrift.CommitBlockTResponse
 
compareTo(CompleteFileTOptions) - Method in class alluxio.thrift.CompleteFileTOptions
 
compareTo(CompleteFileTResponse) - Method in class alluxio.thrift.CompleteFileTResponse
 
compareTo(CompletePartitionTOptions) - Method in class alluxio.thrift.CompletePartitionTOptions
 
compareTo(CompletePartitionTResponse) - Method in class alluxio.thrift.CompletePartitionTResponse
 
compareTo(CompleteStoreTOptions) - Method in class alluxio.thrift.CompleteStoreTOptions
 
compareTo(CompleteStoreTResponse) - Method in class alluxio.thrift.CompleteStoreTResponse
 
compareTo(CompleteUfsFileTOptions) - Method in class alluxio.thrift.CompleteUfsFileTOptions
 
compareTo(CompleteUfsFileTReponse) - Method in class alluxio.thrift.CompleteUfsFileTReponse
 
compareTo(ConfigCheckReport) - Method in class alluxio.thrift.ConfigCheckReport
 
compareTo(ConfigProperty) - Method in class alluxio.thrift.ConfigProperty
 
compareTo(CreateDirectoryTOptions) - Method in class alluxio.thrift.CreateDirectoryTOptions
 
compareTo(CreateDirectoryTResponse) - Method in class alluxio.thrift.CreateDirectoryTResponse
 
compareTo(CreateFileTOptions) - Method in class alluxio.thrift.CreateFileTOptions
 
compareTo(CreateFileTResponse) - Method in class alluxio.thrift.CreateFileTResponse
 
compareTo(CreateLineageTOptions) - Method in class alluxio.thrift.CreateLineageTOptions
 
compareTo(CreateLineageTResponse) - Method in class alluxio.thrift.CreateLineageTResponse
 
compareTo(CreateStoreTOptions) - Method in class alluxio.thrift.CreateStoreTOptions
 
compareTo(CreateStoreTResponse) - Method in class alluxio.thrift.CreateStoreTResponse
 
compareTo(CreateUfsFileTOptions) - Method in class alluxio.thrift.CreateUfsFileTOptions
 
compareTo(CreateUfsFileTResponse) - Method in class alluxio.thrift.CreateUfsFileTResponse
 
compareTo(DeleteLineageTOptions) - Method in class alluxio.thrift.DeleteLineageTOptions
 
compareTo(DeleteLineageTResponse) - Method in class alluxio.thrift.DeleteLineageTResponse
 
compareTo(DeleteStoreTOptions) - Method in class alluxio.thrift.DeleteStoreTOptions
 
compareTo(DeleteStoreTResponse) - Method in class alluxio.thrift.DeleteStoreTResponse
 
compareTo(DeleteTOptions) - Method in class alluxio.thrift.DeleteTOptions
 
compareTo(DeleteTResponse) - Method in class alluxio.thrift.DeleteTResponse
 
compareTo(DependencyInfo) - Method in class alluxio.thrift.DependencyInfo
 
compareTo(FileBlockInfo) - Method in class alluxio.thrift.FileBlockInfo
 
compareTo(FileInfo) - Method in class alluxio.thrift.FileInfo
 
compareTo(FileSystemCommand) - Method in class alluxio.thrift.FileSystemCommand
 
compareTo(FileSystemCommandOptions) - Method in class alluxio.thrift.FileSystemCommandOptions
 
compareTo(FileSystemHeartbeatTOptions) - Method in class alluxio.thrift.FileSystemHeartbeatTOptions
 
compareTo(FileSystemHeartbeatTResponse) - Method in class alluxio.thrift.FileSystemHeartbeatTResponse
 
compareTo(FileSystemMasterClientService.checkConsistency_args) - Method in class alluxio.thrift.FileSystemMasterClientService.checkConsistency_args
 
compareTo(FileSystemMasterClientService.checkConsistency_result) - Method in class alluxio.thrift.FileSystemMasterClientService.checkConsistency_result
 
compareTo(FileSystemMasterClientService.completeFile_args) - Method in class alluxio.thrift.FileSystemMasterClientService.completeFile_args
 
compareTo(FileSystemMasterClientService.completeFile_result) - Method in class alluxio.thrift.FileSystemMasterClientService.completeFile_result
 
compareTo(FileSystemMasterClientService.createDirectory_args) - Method in class alluxio.thrift.FileSystemMasterClientService.createDirectory_args
 
compareTo(FileSystemMasterClientService.createDirectory_result) - Method in class alluxio.thrift.FileSystemMasterClientService.createDirectory_result
 
compareTo(FileSystemMasterClientService.createFile_args) - Method in class alluxio.thrift.FileSystemMasterClientService.createFile_args
 
compareTo(FileSystemMasterClientService.createFile_result) - Method in class alluxio.thrift.FileSystemMasterClientService.createFile_result
 
compareTo(FileSystemMasterClientService.free_args) - Method in class alluxio.thrift.FileSystemMasterClientService.free_args
 
compareTo(FileSystemMasterClientService.free_result) - Method in class alluxio.thrift.FileSystemMasterClientService.free_result
 
compareTo(FileSystemMasterClientService.getFilePath_args) - Method in class alluxio.thrift.FileSystemMasterClientService.getFilePath_args
 
compareTo(FileSystemMasterClientService.getFilePath_result) - Method in class alluxio.thrift.FileSystemMasterClientService.getFilePath_result
 
compareTo(FileSystemMasterClientService.getMountTable_args) - Method in class alluxio.thrift.FileSystemMasterClientService.getMountTable_args
 
compareTo(FileSystemMasterClientService.getMountTable_result) - Method in class alluxio.thrift.FileSystemMasterClientService.getMountTable_result
 
compareTo(FileSystemMasterClientService.getNewBlockIdForFile_args) - Method in class alluxio.thrift.FileSystemMasterClientService.getNewBlockIdForFile_args
 
compareTo(FileSystemMasterClientService.getNewBlockIdForFile_result) - Method in class alluxio.thrift.FileSystemMasterClientService.getNewBlockIdForFile_result
 
compareTo(FileSystemMasterClientService.getStatus_args) - Method in class alluxio.thrift.FileSystemMasterClientService.getStatus_args
 
compareTo(FileSystemMasterClientService.getStatus_result) - Method in class alluxio.thrift.FileSystemMasterClientService.getStatus_result
 
compareTo(FileSystemMasterClientService.listStatus_args) - Method in class alluxio.thrift.FileSystemMasterClientService.listStatus_args
 
compareTo(FileSystemMasterClientService.listStatus_result) - Method in class alluxio.thrift.FileSystemMasterClientService.listStatus_result
 
compareTo(FileSystemMasterClientService.loadMetadata_args) - Method in class alluxio.thrift.FileSystemMasterClientService.loadMetadata_args
 
compareTo(FileSystemMasterClientService.loadMetadata_result) - Method in class alluxio.thrift.FileSystemMasterClientService.loadMetadata_result
 
compareTo(FileSystemMasterClientService.mount_args) - Method in class alluxio.thrift.FileSystemMasterClientService.mount_args
 
compareTo(FileSystemMasterClientService.mount_result) - Method in class alluxio.thrift.FileSystemMasterClientService.mount_result
 
compareTo(FileSystemMasterClientService.remove_args) - Method in class alluxio.thrift.FileSystemMasterClientService.remove_args
 
compareTo(FileSystemMasterClientService.remove_result) - Method in class alluxio.thrift.FileSystemMasterClientService.remove_result
 
compareTo(FileSystemMasterClientService.rename_args) - Method in class alluxio.thrift.FileSystemMasterClientService.rename_args
 
compareTo(FileSystemMasterClientService.rename_result) - Method in class alluxio.thrift.FileSystemMasterClientService.rename_result
 
compareTo(FileSystemMasterClientService.scheduleAsyncPersistence_args) - Method in class alluxio.thrift.FileSystemMasterClientService.scheduleAsyncPersistence_args
 
compareTo(FileSystemMasterClientService.scheduleAsyncPersistence_result) - Method in class alluxio.thrift.FileSystemMasterClientService.scheduleAsyncPersistence_result
 
compareTo(FileSystemMasterClientService.setAttribute_args) - Method in class alluxio.thrift.FileSystemMasterClientService.setAttribute_args
 
compareTo(FileSystemMasterClientService.setAttribute_result) - Method in class alluxio.thrift.FileSystemMasterClientService.setAttribute_result
 
compareTo(FileSystemMasterClientService.unmount_args) - Method in class alluxio.thrift.FileSystemMasterClientService.unmount_args
 
compareTo(FileSystemMasterClientService.unmount_result) - Method in class alluxio.thrift.FileSystemMasterClientService.unmount_result
 
compareTo(FileSystemMasterClientService.updateUfsMode_args) - Method in class alluxio.thrift.FileSystemMasterClientService.updateUfsMode_args
 
compareTo(FileSystemMasterClientService.updateUfsMode_result) - Method in class alluxio.thrift.FileSystemMasterClientService.updateUfsMode_result
 
compareTo(FileSystemMasterCommonTOptions) - Method in class alluxio.thrift.FileSystemMasterCommonTOptions
 
compareTo(FileSystemMasterWorkerService.fileSystemHeartbeat_args) - Method in class alluxio.thrift.FileSystemMasterWorkerService.fileSystemHeartbeat_args
 
compareTo(FileSystemMasterWorkerService.fileSystemHeartbeat_result) - Method in class alluxio.thrift.FileSystemMasterWorkerService.fileSystemHeartbeat_result
 
compareTo(FileSystemMasterWorkerService.getFileInfo_args) - Method in class alluxio.thrift.FileSystemMasterWorkerService.getFileInfo_args
 
compareTo(FileSystemMasterWorkerService.getFileInfo_result) - Method in class alluxio.thrift.FileSystemMasterWorkerService.getFileInfo_result
 
compareTo(FileSystemMasterWorkerService.getPinnedFileIds_args) - Method in class alluxio.thrift.FileSystemMasterWorkerService.getPinnedFileIds_args
 
compareTo(FileSystemMasterWorkerService.getPinnedFileIds_result) - Method in class alluxio.thrift.FileSystemMasterWorkerService.getPinnedFileIds_result
 
compareTo(FileSystemMasterWorkerService.getUfsInfo_args) - Method in class alluxio.thrift.FileSystemMasterWorkerService.getUfsInfo_args
 
compareTo(FileSystemMasterWorkerService.getUfsInfo_result) - Method in class alluxio.thrift.FileSystemMasterWorkerService.getUfsInfo_result
 
compareTo(FileSystemWorkerClientService.cancelUfsFile_args) - Method in class alluxio.thrift.FileSystemWorkerClientService.cancelUfsFile_args
 
compareTo(FileSystemWorkerClientService.cancelUfsFile_result) - Method in class alluxio.thrift.FileSystemWorkerClientService.cancelUfsFile_result
 
compareTo(FileSystemWorkerClientService.closeUfsFile_args) - Method in class alluxio.thrift.FileSystemWorkerClientService.closeUfsFile_args
 
compareTo(FileSystemWorkerClientService.closeUfsFile_result) - Method in class alluxio.thrift.FileSystemWorkerClientService.closeUfsFile_result
 
compareTo(FileSystemWorkerClientService.completeUfsFile_args) - Method in class alluxio.thrift.FileSystemWorkerClientService.completeUfsFile_args
 
compareTo(FileSystemWorkerClientService.completeUfsFile_result) - Method in class alluxio.thrift.FileSystemWorkerClientService.completeUfsFile_result
 
compareTo(FileSystemWorkerClientService.createUfsFile_args) - Method in class alluxio.thrift.FileSystemWorkerClientService.createUfsFile_args
 
compareTo(FileSystemWorkerClientService.createUfsFile_result) - Method in class alluxio.thrift.FileSystemWorkerClientService.createUfsFile_result
 
compareTo(FileSystemWorkerClientService.openUfsFile_args) - Method in class alluxio.thrift.FileSystemWorkerClientService.openUfsFile_args
 
compareTo(FileSystemWorkerClientService.openUfsFile_result) - Method in class alluxio.thrift.FileSystemWorkerClientService.openUfsFile_result
 
compareTo(FileSystemWorkerClientService.sessionFileSystemHeartbeat_args) - Method in class alluxio.thrift.FileSystemWorkerClientService.sessionFileSystemHeartbeat_args
 
compareTo(FileSystemWorkerClientService.sessionFileSystemHeartbeat_result) - Method in class alluxio.thrift.FileSystemWorkerClientService.sessionFileSystemHeartbeat_result
 
compareTo(FreeTOptions) - Method in class alluxio.thrift.FreeTOptions
 
compareTo(FreeTResponse) - Method in class alluxio.thrift.FreeTResponse
 
compareTo(GetBlockInfoTOptions) - Method in class alluxio.thrift.GetBlockInfoTOptions
 
compareTo(GetBlockInfoTResponse) - Method in class alluxio.thrift.GetBlockInfoTResponse
 
compareTo(GetBlockMasterInfoTOptions) - Method in class alluxio.thrift.GetBlockMasterInfoTOptions
 
compareTo(GetBlockMasterInfoTResponse) - Method in class alluxio.thrift.GetBlockMasterInfoTResponse
 
compareTo(GetCapacityBytesTOptions) - Method in class alluxio.thrift.GetCapacityBytesTOptions
 
compareTo(GetCapacityBytesTResponse) - Method in class alluxio.thrift.GetCapacityBytesTResponse
 
compareTo(GetConfigReportTOptions) - Method in class alluxio.thrift.GetConfigReportTOptions
 
compareTo(GetConfigReportTResponse) - Method in class alluxio.thrift.GetConfigReportTResponse
 
compareTo(GetConfigurationTOptions) - Method in class alluxio.thrift.GetConfigurationTOptions
 
compareTo(GetConfigurationTResponse) - Method in class alluxio.thrift.GetConfigurationTResponse
 
compareTo(GetFileInfoTOptions) - Method in class alluxio.thrift.GetFileInfoTOptions
 
compareTo(GetFileInfoTResponse) - Method in class alluxio.thrift.GetFileInfoTResponse
 
compareTo(GetFilePathTOptions) - Method in class alluxio.thrift.GetFilePathTOptions
 
compareTo(GetFilePathTResponse) - Method in class alluxio.thrift.GetFilePathTResponse
 
compareTo(GetLineageInfoListTOptions) - Method in class alluxio.thrift.GetLineageInfoListTOptions
 
compareTo(GetLineageInfoListTResponse) - Method in class alluxio.thrift.GetLineageInfoListTResponse
 
compareTo(GetMasterIdTOptions) - Method in class alluxio.thrift.GetMasterIdTOptions
 
compareTo(GetMasterIdTResponse) - Method in class alluxio.thrift.GetMasterIdTResponse
 
compareTo(GetMasterInfoTOptions) - Method in class alluxio.thrift.GetMasterInfoTOptions
 
compareTo(GetMasterInfoTResponse) - Method in class alluxio.thrift.GetMasterInfoTResponse
 
compareTo(GetMetricsTOptions) - Method in class alluxio.thrift.GetMetricsTOptions
 
compareTo(GetMetricsTResponse) - Method in class alluxio.thrift.GetMetricsTResponse
 
compareTo(GetMountTableTResponse) - Method in class alluxio.thrift.GetMountTableTResponse
 
compareTo(GetNewBlockIdForFileTOptions) - Method in class alluxio.thrift.GetNewBlockIdForFileTOptions
 
compareTo(GetNewBlockIdForFileTResponse) - Method in class alluxio.thrift.GetNewBlockIdForFileTResponse
 
compareTo(GetNextKeysTOptions) - Method in class alluxio.thrift.GetNextKeysTOptions
 
compareTo(GetNextKeysTResponse) - Method in class alluxio.thrift.GetNextKeysTResponse
 
compareTo(GetPartitionInfoTOptions) - Method in class alluxio.thrift.GetPartitionInfoTOptions
 
compareTo(GetPartitionInfoTResponse) - Method in class alluxio.thrift.GetPartitionInfoTResponse
 
compareTo(GetPinnedFileIdsTOptions) - Method in class alluxio.thrift.GetPinnedFileIdsTOptions
 
compareTo(GetPinnedFileIdsTResponse) - Method in class alluxio.thrift.GetPinnedFileIdsTResponse
 
compareTo(GetServiceVersionTOptions) - Method in class alluxio.thrift.GetServiceVersionTOptions
 
compareTo(GetServiceVersionTResponse) - Method in class alluxio.thrift.GetServiceVersionTResponse
 
compareTo(GetSizeTOptions) - Method in class alluxio.thrift.GetSizeTOptions
 
compareTo(GetSizeTResponse) - Method in class alluxio.thrift.GetSizeTResponse
 
compareTo(GetStatusTOptions) - Method in class alluxio.thrift.GetStatusTOptions
 
compareTo(GetStatusTResponse) - Method in class alluxio.thrift.GetStatusTResponse
 
compareTo(GetTOptions) - Method in class alluxio.thrift.GetTOptions
 
compareTo(GetTResponse) - Method in class alluxio.thrift.GetTResponse
 
compareTo(GetUfsInfoTOptions) - Method in class alluxio.thrift.GetUfsInfoTOptions
 
compareTo(GetUfsInfoTResponse) - Method in class alluxio.thrift.GetUfsInfoTResponse
 
compareTo(GetUsedBytesTOptions) - Method in class alluxio.thrift.GetUsedBytesTOptions
 
compareTo(GetUsedBytesTResponse) - Method in class alluxio.thrift.GetUsedBytesTResponse
 
compareTo(GetWorkerIdTOptions) - Method in class alluxio.thrift.GetWorkerIdTOptions
 
compareTo(GetWorkerIdTResponse) - Method in class alluxio.thrift.GetWorkerIdTResponse
 
compareTo(GetWorkerInfoListTOptions) - Method in class alluxio.thrift.GetWorkerInfoListTOptions
 
compareTo(GetWorkerInfoListTResponse) - Method in class alluxio.thrift.GetWorkerInfoListTResponse
 
compareTo(GetWorkerReportTOptions) - Method in class alluxio.thrift.GetWorkerReportTOptions
 
compareTo(InconsistentProperty) - Method in class alluxio.thrift.InconsistentProperty
 
compareTo(JobConfInfo) - Method in class alluxio.thrift.JobConfInfo
 
compareTo(KeyValueMasterClientService.completePartition_args) - Method in class alluxio.thrift.KeyValueMasterClientService.completePartition_args
 
compareTo(KeyValueMasterClientService.completePartition_result) - Method in class alluxio.thrift.KeyValueMasterClientService.completePartition_result
 
compareTo(KeyValueMasterClientService.completeStore_args) - Method in class alluxio.thrift.KeyValueMasterClientService.completeStore_args
 
compareTo(KeyValueMasterClientService.completeStore_result) - Method in class alluxio.thrift.KeyValueMasterClientService.completeStore_result
 
compareTo(KeyValueMasterClientService.createStore_args) - Method in class alluxio.thrift.KeyValueMasterClientService.createStore_args
 
compareTo(KeyValueMasterClientService.createStore_result) - Method in class alluxio.thrift.KeyValueMasterClientService.createStore_result
 
compareTo(KeyValueMasterClientService.deleteStore_args) - Method in class alluxio.thrift.KeyValueMasterClientService.deleteStore_args
 
compareTo(KeyValueMasterClientService.deleteStore_result) - Method in class alluxio.thrift.KeyValueMasterClientService.deleteStore_result
 
compareTo(KeyValueMasterClientService.getPartitionInfo_args) - Method in class alluxio.thrift.KeyValueMasterClientService.getPartitionInfo_args
 
compareTo(KeyValueMasterClientService.getPartitionInfo_result) - Method in class alluxio.thrift.KeyValueMasterClientService.getPartitionInfo_result
 
compareTo(KeyValueMasterClientService.mergeStore_args) - Method in class alluxio.thrift.KeyValueMasterClientService.mergeStore_args
 
compareTo(KeyValueMasterClientService.mergeStore_result) - Method in class alluxio.thrift.KeyValueMasterClientService.mergeStore_result
 
compareTo(KeyValueMasterClientService.renameStore_args) - Method in class alluxio.thrift.KeyValueMasterClientService.renameStore_args
 
compareTo(KeyValueMasterClientService.renameStore_result) - Method in class alluxio.thrift.KeyValueMasterClientService.renameStore_result
 
compareTo(KeyValueWorkerClientService.get_args) - Method in class alluxio.thrift.KeyValueWorkerClientService.get_args
 
compareTo(KeyValueWorkerClientService.get_result) - Method in class alluxio.thrift.KeyValueWorkerClientService.get_result
 
compareTo(KeyValueWorkerClientService.getNextKeys_args) - Method in class alluxio.thrift.KeyValueWorkerClientService.getNextKeys_args
 
compareTo(KeyValueWorkerClientService.getNextKeys_result) - Method in class alluxio.thrift.KeyValueWorkerClientService.getNextKeys_result
 
compareTo(KeyValueWorkerClientService.getSize_args) - Method in class alluxio.thrift.KeyValueWorkerClientService.getSize_args
 
compareTo(KeyValueWorkerClientService.getSize_result) - Method in class alluxio.thrift.KeyValueWorkerClientService.getSize_result
 
compareTo(LineageInfo) - Method in class alluxio.thrift.LineageInfo
 
compareTo(LineageMasterClientService.createLineage_args) - Method in class alluxio.thrift.LineageMasterClientService.createLineage_args
 
compareTo(LineageMasterClientService.createLineage_result) - Method in class alluxio.thrift.LineageMasterClientService.createLineage_result
 
compareTo(LineageMasterClientService.deleteLineage_args) - Method in class alluxio.thrift.LineageMasterClientService.deleteLineage_args
 
compareTo(LineageMasterClientService.deleteLineage_result) - Method in class alluxio.thrift.LineageMasterClientService.deleteLineage_result
 
compareTo(LineageMasterClientService.getLineageInfoList_args) - Method in class alluxio.thrift.LineageMasterClientService.getLineageInfoList_args
 
compareTo(LineageMasterClientService.getLineageInfoList_result) - Method in class alluxio.thrift.LineageMasterClientService.getLineageInfoList_result
 
compareTo(LineageMasterClientService.reinitializeFile_args) - Method in class alluxio.thrift.LineageMasterClientService.reinitializeFile_args
 
compareTo(LineageMasterClientService.reinitializeFile_result) - Method in class alluxio.thrift.LineageMasterClientService.reinitializeFile_result
 
compareTo(LineageMasterClientService.reportLostFile_args) - Method in class alluxio.thrift.LineageMasterClientService.reportLostFile_args
 
compareTo(LineageMasterClientService.reportLostFile_result) - Method in class alluxio.thrift.LineageMasterClientService.reportLostFile_result
 
compareTo(ListStatusTOptions) - Method in class alluxio.thrift.ListStatusTOptions
 
compareTo(ListStatusTResponse) - Method in class alluxio.thrift.ListStatusTResponse
 
compareTo(LoadMetadataTOptions) - Method in class alluxio.thrift.LoadMetadataTOptions
 
compareTo(LoadMetadataTResponse) - Method in class alluxio.thrift.LoadMetadataTResponse
 
compareTo(LocalityTier) - Method in class alluxio.thrift.LocalityTier
 
compareTo(LockBlockTOptions) - Method in class alluxio.thrift.LockBlockTOptions
 
compareTo(LockBlockTResponse) - Method in class alluxio.thrift.LockBlockTResponse
 
compareTo(MasterHeartbeatTOptions) - Method in class alluxio.thrift.MasterHeartbeatTOptions
 
compareTo(MasterHeartbeatTResponse) - Method in class alluxio.thrift.MasterHeartbeatTResponse
 
compareTo(MasterInfo) - Method in class alluxio.thrift.MasterInfo
 
compareTo(MasterNetAddress) - Method in class alluxio.thrift.MasterNetAddress
 
compareTo(MergeStoreTOptions) - Method in class alluxio.thrift.MergeStoreTOptions
 
compareTo(MergeStoreTResponse) - Method in class alluxio.thrift.MergeStoreTResponse
 
compareTo(MetaMasterClientService.backup_args) - Method in class alluxio.thrift.MetaMasterClientService.backup_args
 
compareTo(MetaMasterClientService.backup_result) - Method in class alluxio.thrift.MetaMasterClientService.backup_result
 
compareTo(MetaMasterClientService.getConfigReport_args) - Method in class alluxio.thrift.MetaMasterClientService.getConfigReport_args
 
compareTo(MetaMasterClientService.getConfigReport_result) - Method in class alluxio.thrift.MetaMasterClientService.getConfigReport_result
 
compareTo(MetaMasterClientService.getConfiguration_args) - Method in class alluxio.thrift.MetaMasterClientService.getConfiguration_args
 
compareTo(MetaMasterClientService.getConfiguration_result) - Method in class alluxio.thrift.MetaMasterClientService.getConfiguration_result
 
compareTo(MetaMasterClientService.getMasterInfo_args) - Method in class alluxio.thrift.MetaMasterClientService.getMasterInfo_args
 
compareTo(MetaMasterClientService.getMasterInfo_result) - Method in class alluxio.thrift.MetaMasterClientService.getMasterInfo_result
 
compareTo(MetaMasterClientService.getMetrics_args) - Method in class alluxio.thrift.MetaMasterClientService.getMetrics_args
 
compareTo(MetaMasterClientService.getMetrics_result) - Method in class alluxio.thrift.MetaMasterClientService.getMetrics_result
 
compareTo(MetaMasterMasterService.getMasterId_args) - Method in class alluxio.thrift.MetaMasterMasterService.getMasterId_args
 
compareTo(MetaMasterMasterService.getMasterId_result) - Method in class alluxio.thrift.MetaMasterMasterService.getMasterId_result
 
compareTo(MetaMasterMasterService.masterHeartbeat_args) - Method in class alluxio.thrift.MetaMasterMasterService.masterHeartbeat_args
 
compareTo(MetaMasterMasterService.masterHeartbeat_result) - Method in class alluxio.thrift.MetaMasterMasterService.masterHeartbeat_result
 
compareTo(MetaMasterMasterService.registerMaster_args) - Method in class alluxio.thrift.MetaMasterMasterService.registerMaster_args
 
compareTo(MetaMasterMasterService.registerMaster_result) - Method in class alluxio.thrift.MetaMasterMasterService.registerMaster_result
 
compareTo(Metric) - Method in class alluxio.thrift.Metric
 
compareTo(MetricsHeartbeatTOptions) - Method in class alluxio.thrift.MetricsHeartbeatTOptions
 
compareTo(MetricsHeartbeatTResponse) - Method in class alluxio.thrift.MetricsHeartbeatTResponse
 
compareTo(MetricsMasterClientService.metricsHeartbeat_args) - Method in class alluxio.thrift.MetricsMasterClientService.metricsHeartbeat_args
 
compareTo(MetricsMasterClientService.metricsHeartbeat_result) - Method in class alluxio.thrift.MetricsMasterClientService.metricsHeartbeat_result
 
compareTo(MetricValue) - Method in class alluxio.thrift.MetricValue
 
compareTo(MountPointInfo) - Method in class alluxio.thrift.MountPointInfo
 
compareTo(MountTOptions) - Method in class alluxio.thrift.MountTOptions
 
compareTo(MountTResponse) - Method in class alluxio.thrift.MountTResponse
 
compareTo(OpenUfsFileTOptions) - Method in class alluxio.thrift.OpenUfsFileTOptions
 
compareTo(OpenUfsFileTResponse) - Method in class alluxio.thrift.OpenUfsFileTResponse
 
compareTo(OptionalString) - Method in class alluxio.thrift.OptionalString
 
compareTo(PartitionInfo) - Method in class alluxio.thrift.PartitionInfo
 
compareTo(PersistCommandOptions) - Method in class alluxio.thrift.PersistCommandOptions
 
compareTo(PersistFile) - Method in class alluxio.thrift.PersistFile
 
compareTo(PromoteBlockTOptions) - Method in class alluxio.thrift.PromoteBlockTOptions
 
compareTo(PromoteBlockTResponse) - Method in class alluxio.thrift.PromoteBlockTResponse
 
compareTo(RegisterMasterTOptions) - Method in class alluxio.thrift.RegisterMasterTOptions
 
compareTo(RegisterMasterTResponse) - Method in class alluxio.thrift.RegisterMasterTResponse
 
compareTo(RegisterWorkerTOptions) - Method in class alluxio.thrift.RegisterWorkerTOptions
 
compareTo(RegisterWorkerTResponse) - Method in class alluxio.thrift.RegisterWorkerTResponse
 
compareTo(ReinitializeFileTOptions) - Method in class alluxio.thrift.ReinitializeFileTOptions
 
compareTo(ReinitializeFileTResponse) - Method in class alluxio.thrift.ReinitializeFileTResponse
 
compareTo(RemoveBlockTOptions) - Method in class alluxio.thrift.RemoveBlockTOptions
 
compareTo(RemoveBlockTResponse) - Method in class alluxio.thrift.RemoveBlockTResponse
 
compareTo(RenameStoreTOptions) - Method in class alluxio.thrift.RenameStoreTOptions
 
compareTo(RenameStoreTResponse) - Method in class alluxio.thrift.RenameStoreTResponse
 
compareTo(RenameTOptions) - Method in class alluxio.thrift.RenameTOptions
 
compareTo(RenameTResponse) - Method in class alluxio.thrift.RenameTResponse
 
compareTo(ReportLostFileTOptions) - Method in class alluxio.thrift.ReportLostFileTOptions
 
compareTo(ReportLostFileTResponse) - Method in class alluxio.thrift.ReportLostFileTResponse
 
compareTo(RequestBlockLocationTOptions) - Method in class alluxio.thrift.RequestBlockLocationTOptions
 
compareTo(RequestBlockLocationTResponse) - Method in class alluxio.thrift.RequestBlockLocationTResponse
 
compareTo(RequestSpaceTOptions) - Method in class alluxio.thrift.RequestSpaceTOptions
 
compareTo(RequestSpaceTResponse) - Method in class alluxio.thrift.RequestSpaceTResponse
 
compareTo(ScheduleAsyncPersistenceTOptions) - Method in class alluxio.thrift.ScheduleAsyncPersistenceTOptions
 
compareTo(ScheduleAsyncPersistenceTResponse) - Method in class alluxio.thrift.ScheduleAsyncPersistenceTResponse
 
compareTo(SessionBlockHeartbeatTOptions) - Method in class alluxio.thrift.SessionBlockHeartbeatTOptions
 
compareTo(SessionBlockHeartbeatTResponse) - Method in class alluxio.thrift.SessionBlockHeartbeatTResponse
 
compareTo(SessionFileSystemHeartbeatTOptions) - Method in class alluxio.thrift.SessionFileSystemHeartbeatTOptions
 
compareTo(SessionFileSystemHeartbeatTResponse) - Method in class alluxio.thrift.SessionFileSystemHeartbeatTResponse
 
compareTo(SetAttributeTOptions) - Method in class alluxio.thrift.SetAttributeTOptions
 
compareTo(SetAttributeTResponse) - Method in class alluxio.thrift.SetAttributeTResponse
 
compareTo(SyncMetadataTOptions) - Method in class alluxio.thrift.SyncMetadataTOptions
 
compareTo(SyncMetadataTResponse) - Method in class alluxio.thrift.SyncMetadataTResponse
 
compareTo(TieredIdentity) - Method in class alluxio.thrift.TieredIdentity
 
compareTo(UfsInfo) - Method in class alluxio.thrift.UfsInfo
 
compareTo(UnlockBlockTOptions) - Method in class alluxio.thrift.UnlockBlockTOptions
 
compareTo(UnlockBlockTResponse) - Method in class alluxio.thrift.UnlockBlockTResponse
 
compareTo(UnmountTOptions) - Method in class alluxio.thrift.UnmountTOptions
 
compareTo(UnmountTResponse) - Method in class alluxio.thrift.UnmountTResponse
 
compareTo(UpdateUfsModeTOptions) - Method in class alluxio.thrift.UpdateUfsModeTOptions
 
compareTo(UpdateUfsModeTResponse) - Method in class alluxio.thrift.UpdateUfsModeTResponse
 
compareTo(WorkerInfo) - Method in class alluxio.thrift.WorkerInfo
 
compareTo(WorkerNetAddress) - Method in class alluxio.thrift.WorkerNetAddress
 
compareTo(WebInterfaceWorkersServlet.NodeInfo) - Method in class alluxio.web.WebInterfaceWorkersServlet.NodeInfo
Compare WebInterfaceWorkersServlet.NodeInfo by lexicographical order of their associated host.
complete(long) - Method in class alluxio.master.file.meta.InodeFile
Completes the file.
complete(List<AlluxioURI>) - Static method in class alluxio.master.file.StartupConsistencyCheck
 
COMPLETE_FILE - Static variable in class alluxio.master.file.FileSystemMasterClientRestServiceHandler
Deprecated.
 
COMPLETE_FILE_FIELD_NUMBER - Static variable in class alluxio.proto.journal.Journal.JournalEntry
 
COMPLETE_FILE_OPS - Static variable in class alluxio.metrics.MasterMetrics
 
COMPLETE_PARTITION_FIELD_NUMBER - Static variable in class alluxio.proto.journal.Journal.JournalEntry
 
COMPLETE_STORE_FIELD_NUMBER - Static variable in class alluxio.proto.journal.Journal.JournalEntry
 
completeCurrentLog() - Method in interface alluxio.master.journalv0.JournalWriter
Marks the current log as completed.
completeCurrentLog() - Method in class alluxio.master.journalv0.ufs.UfsJournalWriter
 
COMPLETED_FIELD_NUMBER - Static variable in class alluxio.proto.journal.File.InodeFileEntry
 
completeFile(AlluxioURI, CompleteFileOptions) - Method in interface alluxio.client.file.FileSystemMasterClient
Marks a file as completed.
completeFile(AlluxioURI, CompleteFileOptions) - Method in class alluxio.client.file.RetryHandlingFileSystemMasterClient
 
completeFile(AlluxioURI, CompleteFileOptions) - Method in class alluxio.master.file.DefaultFileSystemMaster
 
completeFile(AlluxioURI, CompleteFileOptions) - Method in interface alluxio.master.file.FileSystemMaster
Completes a file.
completeFile(String, Long) - Method in class alluxio.master.file.FileSystemMasterClientRestServiceHandler
Deprecated.
 
completeFile(String, CompleteFileTOptions) - Method in class alluxio.master.file.FileSystemMasterClientServiceHandler
 
completeFile(String, CompleteFileTOptions, AsyncMethodCallback) - Method in class alluxio.thrift.FileSystemMasterClientService.AsyncClient
 
completeFile(String, CompleteFileTOptions, AsyncMethodCallback) - Method in interface alluxio.thrift.FileSystemMasterClientService.AsyncIface
 
completeFile() - Constructor for class alluxio.thrift.FileSystemMasterClientService.AsyncProcessor.completeFile
 
completeFile(String, CompleteFileTOptions) - Method in class alluxio.thrift.FileSystemMasterClientService.Client
 
completeFile(String, CompleteFileTOptions) - Method in interface alluxio.thrift.FileSystemMasterClientService.Iface
Marks a file as completed.
completeFile() - Constructor for class alluxio.thrift.FileSystemMasterClientService.Processor.completeFile
 
completeFile_args() - Constructor for class alluxio.thrift.FileSystemMasterClientService.completeFile_args
 
completeFile_args(String, CompleteFileTOptions) - Constructor for class alluxio.thrift.FileSystemMasterClientService.completeFile_args
 
completeFile_args(FileSystemMasterClientService.completeFile_args) - Constructor for class alluxio.thrift.FileSystemMasterClientService.completeFile_args
Performs a deep copy on other.
completeFile_call(String, CompleteFileTOptions, AsyncMethodCallback, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class alluxio.thrift.FileSystemMasterClientService.AsyncClient.completeFile_call
 
completeFile_result() - Constructor for class alluxio.thrift.FileSystemMasterClientService.completeFile_result
 
completeFile_result(CompleteFileTResponse, AlluxioTException) - Constructor for class alluxio.thrift.FileSystemMasterClientService.completeFile_result
 
completeFile_result(FileSystemMasterClientService.completeFile_result) - Constructor for class alluxio.thrift.FileSystemMasterClientService.completeFile_result
Performs a deep copy on other.
CompleteFileOptions - Class in alluxio.client.file.options
Method options for completing a file.
CompleteFileOptions - Class in alluxio.master.file.options
Method options for completing a file.
CompleteFileOptions(CompleteFileTOptions) - Constructor for class alluxio.master.file.options.CompleteFileOptions
Creates a new instance of CompleteFileOptions from CompleteFileTOptions.
CompleteFileTOptions - Class in alluxio.thrift
 
CompleteFileTOptions() - Constructor for class alluxio.thrift.CompleteFileTOptions
 
CompleteFileTOptions(CompleteFileTOptions) - Constructor for class alluxio.thrift.CompleteFileTOptions
Performs a deep copy on other.
CompleteFileTOptions._Fields - Enum in alluxio.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
CompleteFileTResponse - Class in alluxio.thrift
 
CompleteFileTResponse() - Constructor for class alluxio.thrift.CompleteFileTResponse
 
CompleteFileTResponse(CompleteFileTResponse) - Constructor for class alluxio.thrift.CompleteFileTResponse
Performs a deep copy on other.
CompleteFileTResponse._Fields - Enum in alluxio.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
completeLogs() - Method in interface alluxio.master.journalv0.JournalWriter
Marks all logs as completed.
completeLogs() - Method in class alluxio.master.journalv0.ufs.UfsJournalWriter
 
CompleteMultipartUploadResult - Class in alluxio.proxy.s3
Result returned after requests for completing a multipart upload.
CompleteMultipartUploadResult() - Constructor for class alluxio.proxy.s3.CompleteMultipartUploadResult
Constructs an CompleteMultipartUploadResult with fields initialized to empty strings.
CompleteMultipartUploadResult(String, String, String, String) - Constructor for class alluxio.proxy.s3.CompleteMultipartUploadResult
Constructs an CompleteMultipartUploadResult with the specified values.
completePartition(AlluxioURI, PartitionInfo) - Method in class alluxio.client.keyvalue.KeyValueMasterClient
Marks a partition complete and adds it to an incomplete key-value store.
completePartition(AlluxioURI, PartitionInfo) - Method in class alluxio.master.keyvalue.DefaultKeyValueMaster
 
completePartition(AlluxioURI, PartitionInfo) - Method in interface alluxio.master.keyvalue.KeyValueMaster
Marks a partition complete and adds it to an incomplete key-value store.
completePartition(String, PartitionInfo, CompletePartitionTOptions) - Method in class alluxio.master.keyvalue.KeyValueMasterClientServiceHandler
 
completePartition(String, PartitionInfo, CompletePartitionTOptions, AsyncMethodCallback) - Method in class alluxio.thrift.KeyValueMasterClientService.AsyncClient
 
completePartition(String, PartitionInfo, CompletePartitionTOptions, AsyncMethodCallback) - Method in interface alluxio.thrift.KeyValueMasterClientService.AsyncIface
 
completePartition() - Constructor for class alluxio.thrift.KeyValueMasterClientService.AsyncProcessor.completePartition
 
completePartition(String, PartitionInfo, CompletePartitionTOptions) - Method in class alluxio.thrift.KeyValueMasterClientService.Client
 
completePartition(String, PartitionInfo, CompletePartitionTOptions) - Method in interface alluxio.thrift.KeyValueMasterClientService.Iface
Marks a partition complete and adds it to the store.
completePartition() - Constructor for class alluxio.thrift.KeyValueMasterClientService.Processor.completePartition
 
completePartition_args() - Constructor for class alluxio.thrift.KeyValueMasterClientService.completePartition_args
 
completePartition_args(String, PartitionInfo, CompletePartitionTOptions) - Constructor for class alluxio.thrift.KeyValueMasterClientService.completePartition_args
 
completePartition_args(KeyValueMasterClientService.completePartition_args) - Constructor for class alluxio.thrift.KeyValueMasterClientService.completePartition_args
Performs a deep copy on other.
completePartition_call(String, PartitionInfo, CompletePartitionTOptions, AsyncMethodCallback, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class alluxio.thrift.KeyValueMasterClientService.AsyncClient.completePartition_call
 
completePartition_result() - Constructor for class alluxio.thrift.KeyValueMasterClientService.completePartition_result
 
completePartition_result(CompletePartitionTResponse, AlluxioTException) - Constructor for class alluxio.thrift.KeyValueMasterClientService.completePartition_result
 
completePartition_result(KeyValueMasterClientService.completePartition_result) - Constructor for class alluxio.thrift.KeyValueMasterClientService.completePartition_result
Performs a deep copy on other.
CompletePartitionTOptions - Class in alluxio.thrift
 
CompletePartitionTOptions() - Constructor for class alluxio.thrift.CompletePartitionTOptions
 
CompletePartitionTOptions(CompletePartitionTOptions) - Constructor for class alluxio.thrift.CompletePartitionTOptions
Performs a deep copy on other.
CompletePartitionTOptions._Fields - Enum in alluxio.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
CompletePartitionTResponse - Class in alluxio.thrift
 
CompletePartitionTResponse() - Constructor for class alluxio.thrift.CompletePartitionTResponse
 
CompletePartitionTResponse(CompletePartitionTResponse) - Constructor for class alluxio.thrift.CompletePartitionTResponse
Performs a deep copy on other.
CompletePartitionTResponse._Fields - Enum in alluxio.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
completeRequest(BlockReadRequestContext) - Method in class alluxio.worker.netty.BlockReadHandler.BlockPacketReader
 
completeRequest(BlockWriteRequestContext, Channel) - Method in class alluxio.worker.netty.BlockWriteHandler.BlockPacketWriter
 
completeRequest(UfsFileWriteRequestContext, Channel) - Method in class alluxio.worker.netty.UfsFileWriteHandler.UfsFilePacketWriter
 
completeStore(AlluxioURI) - Method in class alluxio.client.keyvalue.KeyValueMasterClient
Marks a key-value store complete.
completeStore(AlluxioURI) - Method in class alluxio.master.keyvalue.DefaultKeyValueMaster
 
completeStore(AlluxioURI) - Method in interface alluxio.master.keyvalue.KeyValueMaster
Marks a key-value store complete.
completeStore(String, CompleteStoreTOptions) - Method in class alluxio.master.keyvalue.KeyValueMasterClientServiceHandler
 
completeStore(String, CompleteStoreTOptions, AsyncMethodCallback) - Method in class alluxio.thrift.KeyValueMasterClientService.AsyncClient
 
completeStore(String, CompleteStoreTOptions, AsyncMethodCallback) - Method in interface alluxio.thrift.KeyValueMasterClientService.AsyncIface
 
completeStore() - Constructor for class alluxio.thrift.KeyValueMasterClientService.AsyncProcessor.completeStore
 
completeStore(String, CompleteStoreTOptions) - Method in class alluxio.thrift.KeyValueMasterClientService.Client
 
completeStore(String, CompleteStoreTOptions) - Method in interface alluxio.thrift.KeyValueMasterClientService.Iface
Marks a store complete with its filesystem path.
completeStore() - Constructor for class alluxio.thrift.KeyValueMasterClientService.Processor.completeStore
 
completeStore_args() - Constructor for class alluxio.thrift.KeyValueMasterClientService.completeStore_args
 
completeStore_args(String, CompleteStoreTOptions) - Constructor for class alluxio.thrift.KeyValueMasterClientService.completeStore_args
 
completeStore_args(KeyValueMasterClientService.completeStore_args) - Constructor for class alluxio.thrift.KeyValueMasterClientService.completeStore_args
Performs a deep copy on other.
completeStore_call(String, CompleteStoreTOptions, AsyncMethodCallback, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class alluxio.thrift.KeyValueMasterClientService.AsyncClient.completeStore_call
 
completeStore_result() - Constructor for class alluxio.thrift.KeyValueMasterClientService.completeStore_result
 
completeStore_result(CompleteStoreTResponse, AlluxioTException) - Constructor for class alluxio.thrift.KeyValueMasterClientService.completeStore_result
 
completeStore_result(KeyValueMasterClientService.completeStore_result) - Constructor for class alluxio.thrift.KeyValueMasterClientService.completeStore_result
Performs a deep copy on other.
CompleteStoreTOptions - Class in alluxio.thrift
 
CompleteStoreTOptions() - Constructor for class alluxio.thrift.CompleteStoreTOptions
 
CompleteStoreTOptions(CompleteStoreTOptions) - Constructor for class alluxio.thrift.CompleteStoreTOptions
Performs a deep copy on other.
CompleteStoreTOptions._Fields - Enum in alluxio.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
CompleteStoreTResponse - Class in alluxio.thrift
 
CompleteStoreTResponse() - Constructor for class alluxio.thrift.CompleteStoreTResponse
 
CompleteStoreTResponse(CompleteStoreTResponse) - Constructor for class alluxio.thrift.CompleteStoreTResponse
Performs a deep copy on other.
CompleteStoreTResponse._Fields - Enum in alluxio.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
completeUfsFile(long, long, CompleteUfsFileTOptions, AsyncMethodCallback) - Method in class alluxio.thrift.FileSystemWorkerClientService.AsyncClient
 
completeUfsFile(long, long, CompleteUfsFileTOptions, AsyncMethodCallback) - Method in interface alluxio.thrift.FileSystemWorkerClientService.AsyncIface
 
completeUfsFile() - Constructor for class alluxio.thrift.FileSystemWorkerClientService.AsyncProcessor.completeUfsFile
 
completeUfsFile(long, long, CompleteUfsFileTOptions) - Method in class alluxio.thrift.FileSystemWorkerClientService.Client
 
completeUfsFile(long, long, CompleteUfsFileTOptions) - Method in interface alluxio.thrift.FileSystemWorkerClientService.Iface
Completes a file in the under file system.
completeUfsFile() - Constructor for class alluxio.thrift.FileSystemWorkerClientService.Processor.completeUfsFile
 
completeUfsFile(long, long, CompleteUfsFileTOptions) - Method in class alluxio.worker.file.FileSystemWorkerClientServiceHandler
 
completeUfsFile_args() - Constructor for class alluxio.thrift.FileSystemWorkerClientService.completeUfsFile_args
 
completeUfsFile_args(long, long, CompleteUfsFileTOptions) - Constructor for class alluxio.thrift.FileSystemWorkerClientService.completeUfsFile_args
 
completeUfsFile_args(FileSystemWorkerClientService.completeUfsFile_args) - Constructor for class alluxio.thrift.FileSystemWorkerClientService.completeUfsFile_args
Performs a deep copy on other.
completeUfsFile_call(long, long, CompleteUfsFileTOptions, AsyncMethodCallback, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class alluxio.thrift.FileSystemWorkerClientService.AsyncClient.completeUfsFile_call
 
completeUfsFile_result() - Constructor for class alluxio.thrift.FileSystemWorkerClientService.completeUfsFile_result
 
completeUfsFile_result(CompleteUfsFileTReponse, AlluxioTException) - Constructor for class alluxio.thrift.FileSystemWorkerClientService.completeUfsFile_result
 
completeUfsFile_result(FileSystemWorkerClientService.completeUfsFile_result) - Constructor for class alluxio.thrift.FileSystemWorkerClientService.completeUfsFile_result
Performs a deep copy on other.
CompleteUfsFileOptions - Class in alluxio.client.file.options
Options for completing a UFS file.
CompleteUfsFileTOptions - Class in alluxio.thrift
 
CompleteUfsFileTOptions() - Constructor for class alluxio.thrift.CompleteUfsFileTOptions
 
CompleteUfsFileTOptions(CompleteUfsFileTOptions) - Constructor for class alluxio.thrift.CompleteUfsFileTOptions
Performs a deep copy on other.
CompleteUfsFileTOptions._Fields - Enum in alluxio.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
CompleteUfsFileTReponse - Class in alluxio.thrift
 
CompleteUfsFileTReponse() - Constructor for class alluxio.thrift.CompleteUfsFileTReponse
 
CompleteUfsFileTReponse(long) - Constructor for class alluxio.thrift.CompleteUfsFileTReponse
 
CompleteUfsFileTReponse(CompleteUfsFileTReponse) - Constructor for class alluxio.thrift.CompleteUfsFileTReponse
Performs a deep copy on other.
CompleteUfsFileTReponse._Fields - Enum in alluxio.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
CompositeInodeLockList - Class in alluxio.master.file.meta
Manages the locks for a list of Inodes, based off an existing lock list.
CompositeInodeLockList(InodeLockList) - Constructor for class alluxio.master.file.meta.CompositeInodeLockList
Constructs a new lock list, using an existing lock list as the base list.
CompositeInodeLockList(InodeLockList, InodeLockList) - Constructor for class alluxio.master.file.meta.CompositeInodeLockList
Constructs a new lock list, using an existing lock list as the base list.
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 UfsStatus, returns a UfsSyncUtils.SyncPlan describing how to sync the inode with the ufs.
concatPath(Object, Object...) - Static method in class alluxio.util.io.PathUtils
Joins each element in paths in order, separated by AlluxioURI.SEPARATOR.
ConcurrentHashSet<T> - Class in alluxio.collections
A concurrent hash set.
ConcurrentHashSet() - Constructor for class alluxio.collections.ConcurrentHashSet
Creates a new ConcurrentHashSet.
ConcurrentHashSet(int, float, int) - Constructor for class alluxio.collections.ConcurrentHashSet
Creates a new ConcurrentHashSet.
CONF_DIR - Static variable in class alluxio.PropertyKey
 
CONF_DIR - Static variable in class alluxio.PropertyKey.Name
 
CONF_VALIDATION_ENABLED - Static variable in class alluxio.PropertyKey
 
CONF_VALIDATION_ENABLED - Static variable in class alluxio.PropertyKey.Name
 
CONFIG_CHECKER_MULTI_MASTERS - Static variable in class alluxio.multi.process.PortCoordination
 
CONFIG_CHECKER_MULTI_NODES - Static variable in class alluxio.multi.process.PortCoordination
 
CONFIG_CHECKER_MULTI_WORKERS - Static variable in class alluxio.multi.process.PortCoordination
 
CONFIG_CHECKER_UNSET_VS_SET - Static variable in class alluxio.multi.process.PortCoordination
 
ConfigCheckReport - Class in alluxio.thrift
 
ConfigCheckReport() - Constructor for class alluxio.thrift.ConfigCheckReport
 
ConfigCheckReport(Map<Scope, List<InconsistentProperty>>, Map<Scope, List<InconsistentProperty>>, ConfigStatus) - Constructor for class alluxio.thrift.ConfigCheckReport
 
ConfigCheckReport(ConfigCheckReport) - Constructor for class alluxio.thrift.ConfigCheckReport
Performs a deep copy on other.
ConfigCheckReport - Class in alluxio.wire
Represents a configuration report which records the configuration checker results.
ConfigCheckReport() - Constructor for class alluxio.wire.ConfigCheckReport
Creates a new instance of ConfigCheckReport.
ConfigCheckReport(Map<Scope, List<InconsistentProperty>>, Map<Scope, List<InconsistentProperty>>, ConfigCheckReport.ConfigStatus) - Constructor for class alluxio.wire.ConfigCheckReport
Creates a new instance of ConfigCheckReport.
ConfigCheckReport(ConfigCheckReport) - Constructor for class alluxio.wire.ConfigCheckReport
Creates a new instance of ConfigCheckReport from a thrift representation.
ConfigCheckReport._Fields - Enum in alluxio.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
ConfigCheckReport.ConfigStatus - Enum in alluxio.wire
Config status of the config check.
ConfigProperty - Class in alluxio.thrift
 
ConfigProperty() - Constructor for class alluxio.thrift.ConfigProperty
 
ConfigProperty(String, String, String) - Constructor for class alluxio.thrift.ConfigProperty
 
ConfigProperty(ConfigProperty) - Constructor for class alluxio.thrift.ConfigProperty
Performs a deep copy on other.
ConfigProperty - Class in alluxio.wire
The Alluxio runtime configuration information.
ConfigProperty() - Constructor for class alluxio.wire.ConfigProperty
Creates a new instance of ConfigProperty.
ConfigProperty._Fields - Enum in alluxio.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
ConfigRecord - Class in alluxio.master.meta.checkconf
An Alluxio configuration record.
ConfigRecord() - Constructor for class alluxio.master.meta.checkconf.ConfigRecord
Creates a new instance of ConfigRecord.
ConfigRecord(PropertyKey, String, String) - Constructor for class alluxio.master.meta.checkconf.ConfigRecord
Creates a new instance of ConfigRecord.
ConfigStatus - Enum in alluxio.thrift
 
Configuration - Class in alluxio
Global configuration properties of Alluxio.
ConfigurationCommand - Class in alluxio.cli.fsadmin.doctor
Prints server-side configuration errors and warnings.
ConfigurationCommand(MetaMasterClient, PrintStream) - Constructor for class alluxio.cli.fsadmin.doctor.ConfigurationCommand
Creates a new instance of ConfigurationCommand.
ConfigurationDocGenerator - Class in alluxio.cli
CSV_FILE_DIR utility to generate property keys to csv files.
ConfigurationUtils - Class in alluxio.util
Utilities for working with Alluxio configurations.
ConfigurationValueOptions - Class in alluxio
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.
connectFromMaster(String) - Method in class alluxio.underfs.hdfs.HdfsUnderFileSystem
 
connectFromMaster(String) - Method in class alluxio.underfs.local.LocalUnderFileSystem
 
connectFromMaster(String) - Method in class alluxio.underfs.ObjectUnderFileSystem
 
connectFromMaster(String) - Method in interface alluxio.underfs.UnderFileSystem
Takes any necessary actions required to establish a connection to the under file system from the given master host e.g.
connectFromMaster(String) - Method in class alluxio.underfs.UnderFileSystemWithLogging
 
connectFromWorker(String) - Method in class alluxio.underfs.hdfs.HdfsUnderFileSystem
 
connectFromWorker(String) - Method in class alluxio.underfs.local.LocalUnderFileSystem
 
connectFromWorker(String) - Method in class alluxio.underfs.ObjectUnderFileSystem
 
connectFromWorker(String) - Method in interface alluxio.underfs.UnderFileSystem
Takes any necessary actions required to establish a connection to the under file system from the given worker host e.g.
connectFromWorker(String) - Method in class alluxio.underfs.UnderFileSystemWithLogging
 
ConnectionFailedException - Exception in alluxio.exception
Exception used when a network connection failure occurs.
ConnectionFailedException(String) - Constructor for exception alluxio.exception.ConnectionFailedException
Constructs a new exception with the specified detail message.
ConnectionFailedException(String, Throwable) - Constructor for exception alluxio.exception.ConnectionFailedException
Constructs a new exception with the specified detail message and cause.
ConnectionFailedException(ExceptionMessage, Object...) - Constructor for exception alluxio.exception.ConnectionFailedException
Constructs a new exception with the specified exception message and multiple parameters.
ConnectionFailedException(ExceptionMessage, Throwable, Object...) - Constructor for exception alluxio.exception.ConnectionFailedException
Constructs a new exception with the specified exception message, the cause and multiple parameters.
connectUfs(UnderFileSystem) - Method in class alluxio.underfs.AbstractUfsManager
Takes any necessary actions required to establish a connection to the under file system.
connectUfs(UnderFileSystem) - Method in class alluxio.underfs.MasterUfsManager
 
connectUfs(UnderFileSystem) - Method in class alluxio.underfs.WorkerUfsManager
 
ConsoleSink - Class in alluxio.metrics.sink
A sink which outputs metric values to the console.
ConsoleSink(Properties, MetricRegistry) - Constructor for class alluxio.metrics.sink.ConsoleSink
Creates a new ConsoleSink with a Properties and MetricRegistry.
constantExecutorServiceFactory(ExecutorService) - Static method in class alluxio.util.executor.ExecutorServiceFactories
 
Constants - Class in alluxio
System wide constants.
consumeBuffer(int) - Method in class alluxio.network.thrift.PeekableTransport
Consumes len bytes from the buffer.
CONTAINER_ID_FIELD_NUMBER - Static variable in class alluxio.proto.journal.File.InodeDirectoryIdGeneratorEntry
 
ContainerIdGenerable - Interface in alluxio.master.block
Provides generation of container IDs.
contains(Object) - Method in class alluxio.collections.ConcurrentHashSet
 
contains(T) - Method in class alluxio.collections.DirectedAcyclicGraph
Checks if a node with the given payload is in the DAG.
contains(IndexDefinition<T>, Object) - Method in class alluxio.collections.IndexedSet
Whether there is an object with the specified index field value in the set.
contains(Scope) - Method in enum alluxio.wire.Scope
Check whether the scope contains another scope.
containsAll(Collection<?>) - Method in class alluxio.collections.ConcurrentHashSet
 
containsField(Object) - Method in interface alluxio.collections.FieldIndex
Returns whether there is an object with the specified index field value in the set.
containsField(Object) - Method in class alluxio.collections.NonUniqueFieldIndex
 
containsField(Object) - Method in class alluxio.collections.UniqueFieldIndex
 
containsKey(PropertyKey) - Static method in class alluxio.Configuration
Deprecated.
due to misleading method name, use {Configuration.isSet(PropertyKey)} instead
containsKey(PropertyKey) - Method in class alluxio.underfs.UnderFileSystemConfiguration
 
containsMountPoint(AlluxioURI) - Method in class alluxio.master.file.meta.MountTable
 
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
 
containsWildcard() - Method in class alluxio.AlluxioURI
Whether or not the AlluxioURI contains wildcard(s).
Content() - Constructor for class alluxio.proxy.s3.ListBucketResult.Content
Constructs a new ListBucketResult.Content.
Content(String, String, String, String, String) - Constructor for class alluxio.proxy.s3.ListBucketResult.Content
Constructs a new ListBucketResult.Content.
Context - Class in alluxio.cli.fsadmin.command
Context for running an fsadmin command.
Context(FileSystemMasterClient, BlockMasterClient, MetaMasterClient, PrintStream) - Constructor for class alluxio.cli.fsadmin.command.Context
 
ControllableQueue<T> - Class in alluxio.util.executor
A controllable queue is a priority queue with ControllableQueue.DelayNodes.
ControllableQueue() - Constructor for class alluxio.util.executor.ControllableQueue
Constructs a new ControllableQueue.
ControllableQueue.DelayNode<T> - Class in alluxio.util.executor
A delay node in delta queue which records the value and the total delay (which is the original delay plus the past time).
ControllableScheduler - Class in alluxio.util.executor
A controllable scheduler supports jump to a future time and run all commands within that time period.
ControllableScheduler() - Constructor for class alluxio.util.executor.ControllableScheduler
 
convert(String) - Method in class alluxio.checker.HiveIntegrationChecker.ModeConverter
 
convertMsToClockTime(long) - Static method in class alluxio.util.CommonUtils
Converts milliseconds to clock time.
convertMsToDate(long) - Static method in class alluxio.util.CommonUtils
Converts a millisecond number to a formatted date String.
convertToFolderName(String) - Method in class alluxio.underfs.ObjectUnderFileSystem
Appends the directory suffix to the key.
convertToNames(UfsStatus[]) - Static method in class alluxio.underfs.UfsStatus
Converts an array of UFS file status to a listing result where each element in the array is a file or directory name.
copy() - Method in class alluxio.underfs.UfsDirectoryStatus
 
copy() - Method in class alluxio.underfs.UfsFileStatus
 
copy() - Method in class alluxio.underfs.UfsStatus
Create a copy of UfsStatus.
CopyFromLocalCommand - Class in alluxio.cli.fs.command
Copies the specified file specified by "source path" to the path specified by "remote path".
CopyFromLocalCommand(FileSystem) - 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.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
 
CopyToLocalCommand - Class in alluxio.cli.fs.command
Copies a file or a directory from the Alluxio filesystem to the local filesystem.
CopyToLocalCommand(FileSystem) - Constructor for class alluxio.cli.fs.command.CopyToLocalCommand
 
COS_ACCESS_KEY - Static variable in class alluxio.PropertyKey
 
COS_ACCESS_KEY - Static variable in class alluxio.PropertyKey.Name
 
COS_APP_ID - Static variable in class alluxio.PropertyKey
 
COS_APP_ID - Static variable in class alluxio.PropertyKey.Name
 
COS_CONNECTION_MAX - Static variable in class alluxio.PropertyKey
 
COS_CONNECTION_MAX - Static variable in class alluxio.PropertyKey.Name
 
COS_CONNECTION_TIMEOUT - Static variable in class alluxio.PropertyKey
 
COS_CONNECTION_TIMEOUT - Static variable in class alluxio.PropertyKey.Name
 
COS_REGION - Static variable in class alluxio.PropertyKey
 
COS_REGION - Static variable in class alluxio.PropertyKey.Name
 
COS_SECRET_KEY - Static variable in class alluxio.PropertyKey
 
COS_SECRET_KEY - Static variable in class alluxio.PropertyKey.Name
 
COS_SOCKET_TIMEOUT - Static variable in class alluxio.PropertyKey
 
COS_SOCKET_TIMEOUT - Static variable in class alluxio.PropertyKey.Name
 
COSInputStream - Class in alluxio.underfs.cos
A stream for reading a file from COS.
COSOutputStream - Class in alluxio.underfs.cos
A stream for writing a file into COS.
COSOutputStream(String, String, COSClient) - Constructor for class alluxio.underfs.cos.COSOutputStream
Creates a name instance of COSOutputStream.
COSUnderFileSystem - Class in alluxio.underfs.cos
Tencent Cloud COS UnderFileSystem implementation.
COSUnderFileSystem(AlluxioURI, COSClient, String, String, UnderFileSystemConfiguration) - Constructor for class alluxio.underfs.cos.COSUnderFileSystem
Constructor for COSUnderFileSystem.
COSUnderFileSystemFactory - Class in alluxio.underfs.cos
Factory for creating COSUnderFileSystem.
COSUnderFileSystemFactory() - Constructor for class alluxio.underfs.cos.COSUnderFileSystemFactory
Constructs a new COSUnderFileSystemFactory.
CountCommand - Class in alluxio.cli.fs.command
Displays the number of folders and files matching the specified prefix in args.
CountCommand(FileSystem) - Constructor for class alluxio.cli.fs.command.CountCommand
 
counter(String) - Static method in class alluxio.metrics.MetricsSystem
 
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(FileSystem) - Constructor for class alluxio.cli.fs.command.CpCommand
 
create() - Static method in class alluxio.client.block.AlluxioBlockStore
Creates an Alluxio block store with default file system context and default local hostname.
create(FileSystemContext) - Static method in class alluxio.client.block.AlluxioBlockStore
Creates an Alluxio block store with default local hostname.
create(MasterClientConfig) - Static method in class alluxio.client.block.BlockMasterClient.Factory
Factory method for BlockMasterClient.
create(CreateOptions) - Static method in class alluxio.client.block.policy.BlockLocationPolicy.Factory
Factory for creating BlockLocationPolicy.
create(FileSystemContext, BlockInfo, WorkerNetAddress, BlockInStream.BlockInStreamSource, InStreamOptions) - Static method in class alluxio.client.block.stream.BlockInStream
Creates a BlockInStream.
create(FileSystemContext, long, long, WorkerNetAddress, OutStreamOptions) - Static method in class alluxio.client.block.stream.BlockOutStream
Creates an BlockOutStream.
create(long, long) - Method in class alluxio.client.block.stream.LocalFilePacketReader.Factory
 
create(FileSystemContext, WorkerNetAddress, long, OutStreamOptions) - Static method in class alluxio.client.block.stream.LocalFilePacketWriter
Creates an instance of LocalFilePacketWriter.
create(long, long) - Method in class alluxio.client.block.stream.NettyPacketReader.Factory
 
create(FileSystemContext, WorkerNetAddress, long, long, Protocol.RequestType, OutStreamOptions) - Static method in class alluxio.client.block.stream.NettyPacketWriter
 
create(long, long) - Method in interface alluxio.client.block.stream.PacketReader.Factory
Creates an instance of PacketReader.
create(FileSystemContext, long, long, WorkerNetAddress, OutStreamOptions) - Static method in class alluxio.client.block.stream.PacketWriter.Factory
 
create(FileSystemContext, WorkerNetAddress, OutStreamOptions) - Static method in class alluxio.client.block.stream.UnderFileSystemFileOutStream
Creates an instance of UnderFileSystemFileOutStream that writes to a UFS file.
create(Subject, MasterInquireClient) - Static method in class alluxio.client.file.FileSystemContext
This method is provided for testing, use the FileSystemContext.get() methods.
create(MasterClientConfig) - Static method in class alluxio.client.file.FileSystemMasterClient.Factory
Factory method for FileSystemMasterClient.
create(AlluxioURI) - Static method in class alluxio.client.keyvalue.KeyValuePartitionReader.Factory
Factory method to create a KeyValuePartitionReader given the AlluxioURI of a key-value partition.
create(long) - Static method in class alluxio.client.keyvalue.KeyValuePartitionReader.Factory
Factory method to create a KeyValuePartitionReader given the block id of a key-value partition.
create(AlluxioURI) - Static method in class alluxio.client.keyvalue.KeyValuePartitionWriter.Factory
Factory method to create a KeyValuePartitionWriter instance that writes key-value data to a new partition file in Alluxio.
create() - Static method in class alluxio.client.keyvalue.KeyValueSystem.Factory
 
create(String, S) - Method in interface alluxio.extensions.ExtensionFactory
Creates a new extension for the given path.
create(MasterRegistry, MasterContext) - Method in class alluxio.master.block.BlockMasterFactory
 
create(FileSystemMasterView) - Static method in class alluxio.master.file.async.AsyncPersistHandler.Factory
Creates a new instance of AsyncPersistHandler.
create(MasterRegistry, MasterContext) - Method in class alluxio.master.file.FileSystemMasterFactory
 
create() - Static method in interface alluxio.master.file.InodePermissionChecker
 
create(long, long, String, CreateDirectoryOptions) - Static method in class alluxio.master.file.meta.InodeDirectory
Creates an InodeDirectory.
create(long, long, String, long, CreateFileOptions) - Static method in class alluxio.master.file.meta.InodeFile
Creates an InodeFile.
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(URI) - Static method in class alluxio.master.journal.JournalFileParser.Factory
Creates a journal parser given the location.
create(String) - Method in class alluxio.master.journalv0.Journal.Factory
 
create(URI) - Static method in class alluxio.master.journalv0.Journal.Factory
Creates a new read-only journal using the given location.
create(String) - Method in interface alluxio.master.journalv0.JournalFactory
Creates a new journal using the given name.
create() - Static method in class alluxio.master.journalv0.JournalFormatter.Factory
Factory method for JournalFormatter.
create(String) - Method in class alluxio.master.journalv0.MutableJournal.Factory
 
create(URI) - Static method in class alluxio.master.journalv0.MutableJournal.Factory
Creates a new read-write journal using the given location.
create(MasterRegistry, MasterContext) - Method in class alluxio.master.keyvalue.KeyValueMasterFactory
 
create(LineageStoreView, FileSystemMasterView) - Static method in class alluxio.master.lineage.checkpoint.CheckpointPlanner.Factory
 
create(MasterRegistry, MasterContext) - Method in class alluxio.master.lineage.LineageMasterFactory
 
create() - Static method in class alluxio.master.LocalAlluxioMaster
Creates a new local Alluxio master with an isolated work directory and port.
create(String) - Static method in class alluxio.master.LocalAlluxioMaster
Creates a new local Alluxio master with a isolated port.
create(MasterRegistry, MasterContext) - Method in interface alluxio.master.MasterFactory
Factory method to create a new master instance.
create() - Static method in class alluxio.master.MasterInquireClient.Factory
Creates an instance of MasterInquireClient based on the current configuration.
create(AlluxioConfiguration) - Static method in class alluxio.master.MasterInquireClient.Factory
 
create() - Static method in class alluxio.master.MasterProcess.Factory
 
create(MasterRegistry, MasterContext) - Method in class alluxio.master.meta.MetaMasterFactory
 
create(MasterRegistry, MasterContext) - Method in class alluxio.master.metrics.MetricsMasterFactory
 
create() - Static method in class alluxio.proxy.ProxyProcess.Factory
 
create(AuthType) - Static method in class alluxio.security.authentication.AuthenticationProvider.Factory
 
create() - Static method in class alluxio.security.authentication.TransportProvider.Factory
Creates a new instance of TransportProvider based on authentication type.
create(String) - Method in class alluxio.underfs.BaseUnderFileSystem
 
create(String, UnderFileSystemConfiguration) - Method in class alluxio.underfs.cos.COSUnderFileSystemFactory
 
create(String, UfsStatus) - Static method in class alluxio.underfs.Fingerprint
Parses the input string and returns the fingerprint object.
create(String, UnderFileSystemConfiguration) - Method in class alluxio.underfs.gcs.GCSUnderFileSystemFactory
 
create(String, CreateOptions) - Method in class alluxio.underfs.hdfs.HdfsUnderFileSystem
 
create(String, UnderFileSystemConfiguration) - Method in class alluxio.underfs.hdfs.HdfsUnderFileSystemFactory
 
create(String, CreateOptions) - Method in class alluxio.underfs.local.LocalUnderFileSystem
 
create(String, UnderFileSystemConfiguration) - Method in class alluxio.underfs.local.LocalUnderFileSystemFactory
 
create(String, CreateOptions) - Method in class alluxio.underfs.ObjectUnderFileSystem
 
create(String, UnderFileSystemConfiguration) - Method in class alluxio.underfs.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) - Static method in class alluxio.underfs.UnderFileSystem.Factory
Creates the UnderFileSystem instance according to its UFS path.
create(URI) - Static method in class alluxio.underfs.UnderFileSystem.Factory
Creates the UnderFileSystem instance according to its UFS path.
create(String, UnderFileSystemConfiguration) - Static method in class alluxio.underfs.UnderFileSystem.Factory
Creates a client for operations involved with the under file system.
create(String, UnderFileSystemConfiguration) - Method in interface alluxio.underfs.UnderFileSystemFactory
Creates a new client for accessing the given path.
create(String) - Method in class alluxio.underfs.UnderFileSystemWithLogging
 
create(String, CreateOptions) - Method in class alluxio.underfs.UnderFileSystemWithLogging
 
create(String, UnderFileSystemConfiguration) - Method in class alluxio.underfs.wasb.WasbUnderFileSystemFactory
 
create(String) - Static method in class alluxio.URI.Factory
Creates a URI from a string.
create(String, String, String, String) - Static method in class alluxio.URI.Factory
Creates a URI from components.
create(URI, URI) - Static method in class alluxio.URI.Factory
Resolves a child URI against a parent URI.
create() - Method in interface alluxio.util.executor.ExecutorServiceFactory
 
create(BlockMetadataManagerView) - Static method in class alluxio.worker.block.allocator.Allocator.Factory
Factory for Allocator.
create(BlockMetadataManager) - Static method in class alluxio.worker.block.BlockStoreMeta.Factory
Factory method to return a BlockStoreMeta instance without blockIds.
create(WorkerRegistry, UfsManager) - Method in class alluxio.worker.block.BlockWorkerFactory
 
create(BlockMetadataManagerView, Allocator) - Static method in class alluxio.worker.block.evictor.Evictor.Factory
Factory for Evictor.
create(UnderFileSystemBlockMeta, long, BlockStore, UfsManager, UfsInputStreamManager) - Static method in class alluxio.worker.block.UnderFileSystemBlockReader
Creates an instance of UnderFileSystemBlockReader and initializes it with a reading offset.
create(SocketAddress, WorkerProcess) - Static method in class alluxio.worker.DataServer.Factory
Factory for DataServer.
create(WorkerRegistry, UfsManager) - Method in class alluxio.worker.file.FileSystemWorkerFactory
 
create(WorkerRegistry, UfsManager) - Method in class alluxio.worker.keyvalue.KeyValueWorkerFactory
 
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_DIRECTORIES_OPS - Static variable in class alluxio.metrics.MasterMetrics
 
CREATE_DIRECTORY - Static variable in class alluxio.master.file.FileSystemMasterClientRestServiceHandler
Deprecated.
 
CREATE_DIRECTORY - Static variable in class alluxio.proxy.PathsRestServiceHandler
 
CREATE_FILE - Static variable in class alluxio.master.file.FileSystemMasterClientRestServiceHandler
Deprecated.
 
CREATE_FILE - Static variable in class alluxio.proxy.PathsRestServiceHandler
 
CREATE_FILES_OPS - Static variable in class alluxio.metrics.MasterMetrics
 
CREATE_LINEAGE - Static variable in class alluxio.master.lineage.LineageMasterClientRestServiceHandler
Deprecated.
 
CREATE_STORE_FIELD_NUMBER - Static variable in class alluxio.proto.journal.Journal.JournalEntry
 
CREATE_UFS_FILE_OPTIONS_FIELD_NUMBER - Static variable in class alluxio.proto.dataserver.Protocol.WriteRequest
 
createAwsCredentialsProvider(UnderFileSystemConfiguration) - Static method in class alluxio.underfs.s3a.S3AUnderFileSystem
 
createBlock(long, long, BlockStoreLocation, long) - Method in interface alluxio.worker.block.BlockStore
Creates the metadata of a new block and assigns a temporary path (e.g., a subdir of the final location named after session id) to store its data.
createBlock(long, long, String, long) - Method in interface alluxio.worker.block.BlockWorker
Creates a block in Alluxio managed space.
createBlock(long, long, String, long) - Method in class alluxio.worker.block.DefaultBlockWorker
 
createBlock(long, long, BlockStoreLocation, long) - Method in class alluxio.worker.block.TieredBlockStore
 
createBlockId(long, long) - Static method in class alluxio.master.block.BlockId
 
createBlockMetadataManager() - Static method in class alluxio.worker.block.BlockMetadataManager
Creates a new instance of BlockMetadataManager.
createBlockPath(String) - Static method in class alluxio.util.io.FileUtils
Creates the local block path and all the parent directories.
createBlockRemote(long, long, String, long) - Method in interface alluxio.worker.block.BlockWorker
Creates a block.
createBlockRemote(long, long, String, long) - Method in class alluxio.worker.block.DefaultBlockWorker
 
createBucket(String) - Method in class alluxio.proxy.s3.S3RestServiceHandler
 
createCancelResponse() - Static method in class alluxio.network.protocol.RPCProtoMessage
Creates a response in CANCELLED state.
createClientBootstrap(SocketAddress) - Static method in class alluxio.network.netty.NettyClient
Creates and returns a new Netty client bootstrap for clients to connect to remote servers.
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) - Static method in class alluxio.underfs.wasb.WasbUnderFileSystem
Prepares the configuration for this Wasb as an HDFS configuration.
createDir(String) - Static method in class alluxio.util.io.FileUtils
Creates an empty directory and its intermediate directories if necessary.
createDirect(String, CreateOptions) - Method in interface alluxio.underfs.AtomicFileOutputStreamCallback
Creates a file in the under file system with the specified CreateOptions.
createDirect(String, CreateOptions) - Method in class alluxio.underfs.hdfs.HdfsUnderFileSystem
 
createDirect(String, CreateOptions) - Method in class alluxio.underfs.local.LocalUnderFileSystem
 
createDirectory(AlluxioURI) - Method in class alluxio.client.file.BaseFileSystem
 
createDirectory(AlluxioURI, CreateDirectoryOptions) - Method in class alluxio.client.file.BaseFileSystem
 
createDirectory(AlluxioURI) - Method in interface alluxio.client.file.FileSystem
Convenience method for FileSystem.createDirectory(AlluxioURI, CreateDirectoryOptions) with default options.
createDirectory(AlluxioURI, CreateDirectoryOptions) - Method in interface alluxio.client.file.FileSystem
Creates a directory.
createDirectory(AlluxioURI, CreateDirectoryOptions) - Method in interface alluxio.client.file.FileSystemMasterClient
Creates a new directory.
createDirectory(AlluxioURI, CreateDirectoryOptions) - Method in class alluxio.client.file.RetryHandlingFileSystemMasterClient
 
createDirectory(AlluxioURI, CreateDirectoryOptions) - Method in class alluxio.master.file.DefaultFileSystemMaster
 
createDirectory(AlluxioURI, CreateDirectoryOptions) - Method in interface alluxio.master.file.FileSystemMaster
Creates a directory for a given path.
createDirectory(String, Boolean, Boolean, Boolean) - Method in class alluxio.master.file.FileSystemMasterClientRestServiceHandler
Deprecated.
 
createDirectory(String, CreateDirectoryTOptions) - Method in class alluxio.master.file.FileSystemMasterClientServiceHandler
 
createDirectory(String, CreateDirectoryOptions) - Method in class alluxio.proxy.PathsRestServiceHandler
 
createDirectory(String, CreateDirectoryTOptions, AsyncMethodCallback) - Method in class alluxio.thrift.FileSystemMasterClientService.AsyncClient
 
createDirectory(String, CreateDirectoryTOptions, AsyncMethodCallback) - Method in interface alluxio.thrift.FileSystemMasterClientService.AsyncIface
 
createDirectory() - Constructor for class alluxio.thrift.FileSystemMasterClientService.AsyncProcessor.createDirectory
 
createDirectory(String, CreateDirectoryTOptions) - Method in class alluxio.thrift.FileSystemMasterClientService.Client
 
createDirectory(String, CreateDirectoryTOptions) - Method in interface alluxio.thrift.FileSystemMasterClientService.Iface
Creates a directory.
createDirectory() - Constructor for class alluxio.thrift.FileSystemMasterClientService.Processor.createDirectory
 
createDirectory_args() - Constructor for class alluxio.thrift.FileSystemMasterClientService.createDirectory_args
 
createDirectory_args(String, CreateDirectoryTOptions) - Constructor for class alluxio.thrift.FileSystemMasterClientService.createDirectory_args
 
createDirectory_args(FileSystemMasterClientService.createDirectory_args) - Constructor for class alluxio.thrift.FileSystemMasterClientService.createDirectory_args
Performs a deep copy on other.
createDirectory_call(String, CreateDirectoryTOptions, AsyncMethodCallback, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class alluxio.thrift.FileSystemMasterClientService.AsyncClient.createDirectory_call
 
createDirectory_result() - Constructor for class alluxio.thrift.FileSystemMasterClientService.createDirectory_result
 
createDirectory_result(CreateDirectoryTResponse, AlluxioTException) - Constructor for class alluxio.thrift.FileSystemMasterClientService.createDirectory_result
 
createDirectory_result(FileSystemMasterClientService.createDirectory_result) - Constructor for class alluxio.thrift.FileSystemMasterClientService.createDirectory_result
Performs a deep copy on other.
CreateDirectoryOptions - Class in alluxio.client.file.options
Method options for creating a directory.
CreateDirectoryOptions - Class in alluxio.master.file.options
Method options for creating a directory.
CreateDirectoryOptions(CreateDirectoryTOptions) - Constructor for class alluxio.master.file.options.CreateDirectoryOptions
Constructs an instance of CreateDirectoryOptions from CreateDirectoryTOptions.
CreateDirectoryTOptions - Class in alluxio.thrift
 
CreateDirectoryTOptions() - Constructor for class alluxio.thrift.CreateDirectoryTOptions
 
CreateDirectoryTOptions(CreateDirectoryTOptions) - Constructor for class alluxio.thrift.CreateDirectoryTOptions
Performs a deep copy on other.
CreateDirectoryTOptions._Fields - Enum in alluxio.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
CreateDirectoryTResponse - Class in alluxio.thrift
 
CreateDirectoryTResponse() - Constructor for class alluxio.thrift.CreateDirectoryTResponse
 
CreateDirectoryTResponse(CreateDirectoryTResponse) - Constructor for class alluxio.thrift.CreateDirectoryTResponse
Performs a deep copy on other.
CreateDirectoryTResponse._Fields - Enum in alluxio.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
createEmptyIndex() - Static method in class alluxio.client.keyvalue.LinearProbingIndex
 
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.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
 
createEventLoop(ChannelType, int, String, boolean) - Static method in class alluxio.util.network.NettyUtils
Creates a Netty EventLoopGroup based on ChannelType.
createFile(AlluxioURI) - Method in class alluxio.client.file.BaseFileSystem
 
createFile(AlluxioURI, CreateFileOptions) - Method in class alluxio.client.file.BaseFileSystem
 
createFile(AlluxioURI) - Method in interface alluxio.client.file.FileSystem
Convenience method for FileSystem.createFile(AlluxioURI, CreateFileOptions) with default options.
createFile(AlluxioURI, CreateFileOptions) - Method in interface alluxio.client.file.FileSystem
Creates a file.
createFile(AlluxioURI, CreateFileOptions) - Method in interface alluxio.client.file.FileSystemMasterClient
Creates a new file.
createFile(AlluxioURI, CreateFileOptions) - Method in class alluxio.client.file.RetryHandlingFileSystemMasterClient
 
createFile(AlluxioURI, CreateFileOptions) - Method in class alluxio.client.lineage.LineageFileSystem
Gets the output stream for lineage job.
createFile(AlluxioURI, CreateFileOptions) - Method in class alluxio.master.file.DefaultFileSystemMaster
 
createFile(AlluxioURI, CreateFileOptions) - Method in interface alluxio.master.file.FileSystemMaster
Creates a file (not a directory) for a given path.
createFile(String, Boolean, Boolean, Long, Long, TtlAction) - Method in class alluxio.master.file.FileSystemMasterClientRestServiceHandler
Deprecated.
 
createFile(String, CreateFileTOptions) - Method in class alluxio.master.file.FileSystemMasterClientServiceHandler
 
createFile(String, CreateFileOptions) - Method in class alluxio.proxy.PathsRestServiceHandler
 
createFile(String, CreateFileTOptions, AsyncMethodCallback) - Method in class alluxio.thrift.FileSystemMasterClientService.AsyncClient
 
createFile(String, CreateFileTOptions, AsyncMethodCallback) - Method in interface alluxio.thrift.FileSystemMasterClientService.AsyncIface
 
createFile() - Constructor for class alluxio.thrift.FileSystemMasterClientService.AsyncProcessor.createFile
 
createFile(String, CreateFileTOptions) - Method in class alluxio.thrift.FileSystemMasterClientService.Client
 
createFile(String, CreateFileTOptions) - Method in interface alluxio.thrift.FileSystemMasterClientService.Iface
Creates a file.
createFile() - Constructor for class alluxio.thrift.FileSystemMasterClientService.Processor.createFile
 
createFile(String) - Static method in class alluxio.util.io.FileUtils
Creates an empty file and its intermediate directories if necessary.
createFile_args() - Constructor for class alluxio.thrift.FileSystemMasterClientService.createFile_args
 
createFile_args(String, CreateFileTOptions) - Constructor for class alluxio.thrift.FileSystemMasterClientService.createFile_args
 
createFile_args(FileSystemMasterClientService.createFile_args) - Constructor for class alluxio.thrift.FileSystemMasterClientService.createFile_args
Performs a deep copy on other.
createFile_call(String, CreateFileTOptions, AsyncMethodCallback, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class alluxio.thrift.FileSystemMasterClientService.AsyncClient.createFile_call
 
createFile_result() - Constructor for class alluxio.thrift.FileSystemMasterClientService.createFile_result
 
createFile_result(CreateFileTResponse, AlluxioTException) - Constructor for class alluxio.thrift.FileSystemMasterClientService.createFile_result
 
createFile_result(FileSystemMasterClientService.createFile_result) - Constructor for class alluxio.thrift.FileSystemMasterClientService.createFile_result
Performs a deep copy on other.
createFileId(long) - Static method in class alluxio.util.IdUtils
Creates an id for a file based on the given id of the container.
CreateFileOptions - Class in alluxio.client.file.options
Method options for creating a file.
CreateFileOptions - Class in alluxio.master.file.options
Method options for creating a file.
CreateFileOptions(CreateFileTOptions) - Constructor for class alluxio.master.file.options.CreateFileOptions
Constructs an instance of CreateFileOptions from CreateFileTOptions.
createFiles() - Static method in class alluxio.examples.Performance
Creates the files for this example.
createFileSystemContextId() - Static method in class alluxio.util.IdUtils
 
CreateFileTOptions - Class in alluxio.thrift
 
CreateFileTOptions() - Constructor for class alluxio.thrift.CreateFileTOptions
 
CreateFileTOptions(CreateFileTOptions) - Constructor for class alluxio.thrift.CreateFileTOptions
Performs a deep copy on other.
CreateFileTOptions._Fields - Enum in alluxio.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
CreateFileTResponse - Class in alluxio.thrift
 
CreateFileTResponse() - Constructor for class alluxio.thrift.CreateFileTResponse
 
CreateFileTResponse(CreateFileTResponse) - Constructor for class alluxio.thrift.CreateFileTResponse
Performs a deep copy on other.
CreateFileTResponse._Fields - Enum in alluxio.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
createForRoot() - Static method in class alluxio.underfs.UnderFileSystem.Factory
 
createFrameDecoder() - Static method in class alluxio.network.protocol.RPCMessage
Creates a decoder that splits up the incoming ByteBuf into new ByteBuf's according to a length field in the input.
createFull(BlockMetadataManager) - Static method in class alluxio.worker.block.BlockStoreMeta.Factory
Factory method to return a BlockStoreMeta instance with blockIds.
createFullAccess() - Static method in class alluxio.security.authorization.Mode
Creates the "full access" mode.
createInstance(AlluxioURI, UnderFileSystemConfiguration) - Static method in class alluxio.underfs.cos.COSUnderFileSystem
Constructs a new instance of COSUnderFileSystem.
createInstance(AlluxioURI, UnderFileSystemConfiguration) - Static method in class alluxio.underfs.gcs.GCSUnderFileSystem
Constructs a new instance of GCSUnderFileSystem.
createInstance(AlluxioURI, UnderFileSystemConfiguration) - Static method in class alluxio.underfs.hdfs.HdfsUnderFileSystem
Factory method to constructs a new HDFS UnderFileSystem instance.
createInstance(AlluxioURI, UnderFileSystemConfiguration) - Static method in class alluxio.underfs.oss.OSSUnderFileSystem
Constructs a new instance of OSSUnderFileSystem.
createInstance(AlluxioURI, UnderFileSystemConfiguration) - Static method in class alluxio.underfs.s3a.S3AUnderFileSystem
Constructs a new instance of S3AUnderFileSystem.
createInstance(AlluxioURI, UnderFileSystemConfiguration) - Static method in class alluxio.underfs.wasb.WasbUnderFileSystem
Factory method to construct a new Wasb UnderFileSystem.
createInternalSessionId() - Static method in class alluxio.Sessions
 
createJournal(JournalEntryStateMachine) - Method in interface alluxio.master.journal.JournalSystem
Creates a journal for the given state machine.
createJournal(JournalEntryStateMachine) - Method in class alluxio.master.journal.noop.NoopJournalSystem
 
createJournal(JournalEntryStateMachine) - 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.ufs.UfsJournal
 
createJournalContext() - Method in interface alluxio.master.Master
 
createJournalContext() - Method in class alluxio.master.NoopMaster
 
createLineage(List<AlluxioURI>, List<AlluxioURI>, Job, CreateLineageOptions) - Method in class alluxio.client.lineage.AbstractLineageClient
 
createLineage(List<AlluxioURI>, List<AlluxioURI>, Job) - Method in class alluxio.client.lineage.AlluxioLineage
createLineage(List<String>, List<String>, CommandLineJob) - Method in class alluxio.client.lineage.LineageMasterClient
Creates a lineage.
createLineage(List<AlluxioURI>, List<AlluxioURI>, Job) - Method in class alluxio.master.lineage.DefaultLineageMaster
 
createLineage(List<AlluxioURI>, List<AlluxioURI>, Job) - Method in interface alluxio.master.lineage.LineageMaster
Creates a lineage.
createLineage(String, String, String, String) - Method in class alluxio.master.lineage.LineageMasterClientRestServiceHandler
Deprecated.
 
createLineage(List<String>, List<String>, CommandLineJobInfo, CreateLineageTOptions) - Method in class alluxio.master.lineage.LineageMasterClientServiceHandler
 
createLineage(List<Long>, List<Long>, Job) - Method in class alluxio.master.lineage.meta.LineageStore
Creates a lineage.
createLineage(List<String>, List<String>, CommandLineJobInfo, CreateLineageTOptions, AsyncMethodCallback) - Method in class alluxio.thrift.LineageMasterClientService.AsyncClient
 
createLineage(List<String>, List<String>, CommandLineJobInfo, CreateLineageTOptions, AsyncMethodCallback) - Method in interface alluxio.thrift.LineageMasterClientService.AsyncIface
 
createLineage() - Constructor for class alluxio.thrift.LineageMasterClientService.AsyncProcessor.createLineage
 
createLineage(List<String>, List<String>, CommandLineJobInfo, CreateLineageTOptions) - Method in class alluxio.thrift.LineageMasterClientService.Client
 
createLineage(List<String>, List<String>, CommandLineJobInfo, CreateLineageTOptions) - Method in interface alluxio.thrift.LineageMasterClientService.Iface
Creates a lineage and returns the lineage id.
createLineage() - Constructor for class alluxio.thrift.LineageMasterClientService.Processor.createLineage
 
createLineage_args() - Constructor for class alluxio.thrift.LineageMasterClientService.createLineage_args
 
createLineage_args(List<String>, List<String>, CommandLineJobInfo, CreateLineageTOptions) - Constructor for class alluxio.thrift.LineageMasterClientService.createLineage_args
 
createLineage_args(LineageMasterClientService.createLineage_args) - Constructor for class alluxio.thrift.LineageMasterClientService.createLineage_args
Performs a deep copy on other.
createLineage_call(List<String>, List<String>, CommandLineJobInfo, CreateLineageTOptions, AsyncMethodCallback, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class alluxio.thrift.LineageMasterClientService.AsyncClient.createLineage_call
 
createLineage_result() - Constructor for class alluxio.thrift.LineageMasterClientService.createLineage_result
 
createLineage_result(CreateLineageTResponse, AlluxioTException) - Constructor for class alluxio.thrift.LineageMasterClientService.createLineage_result
 
createLineage_result(LineageMasterClientService.createLineage_result) - Constructor for class alluxio.thrift.LineageMasterClientService.createLineage_result
Performs a deep copy on other.
CreateLineageCommand - Class in alluxio.cli.fs.command
Creates a lineage for the given input files, output files, and command line job.
CreateLineageCommand(FileSystem) - Constructor for class alluxio.cli.fs.command.CreateLineageCommand
 
CreateLineageOptions - Class in alluxio.client.lineage.options
Method options for creating a lineage.
CreateLineageTOptions - Class in alluxio.thrift
 
CreateLineageTOptions() - Constructor for class alluxio.thrift.CreateLineageTOptions
 
CreateLineageTOptions(CreateLineageTOptions) - Constructor for class alluxio.thrift.CreateLineageTOptions
Performs a deep copy on other.
CreateLineageTOptions._Fields - Enum in alluxio.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
CreateLineageTResponse - Class in alluxio.thrift
 
CreateLineageTResponse() - Constructor for class alluxio.thrift.CreateLineageTResponse
 
CreateLineageTResponse(long) - Constructor for class alluxio.thrift.CreateLineageTResponse
 
CreateLineageTResponse(CreateLineageTResponse) - Constructor for class alluxio.thrift.CreateLineageTResponse
Performs a deep copy on other.
CreateLineageTResponse._Fields - Enum in alluxio.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
createMountId() - Static method in class alluxio.util.IdUtils
 
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.
createNewResource() - Method in class alluxio.client.block.BlockMasterClientPool
 
createNewResource() - Method in class alluxio.client.file.FileSystemMasterClientPool
 
createNewResource() - Method in class alluxio.network.netty.NettyChannelPool
Creates a netty channel instance.
createNewResource() - Method in class alluxio.resource.DynamicResourcePool
Creates a new resource.
createNewResource() - Method in class alluxio.resource.ResourcePool
Creates a new resource which will be added to the resource pool after the user is done using it.
createNewResource() - Method in class alluxio.worker.block.BlockMasterClientPool
 
createNoAccess() - Static method in class alluxio.security.authorization.Mode
Creates the "no access" mode.
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.ObjectUnderFileSystem
Creates an OutputStream for object uploads.
createObject(String) - Method in class alluxio.underfs.oss.OSSUnderFileSystem
 
createObject(String) - Method in class alluxio.underfs.s3a.S3AUnderFileSystem
 
createObject(String) - Method in class alluxio.underfs.swift.SwiftUnderFileSystem
 
createObjectOrUploadPart(String, String, String, Integer, Long, InputStream) - Method in class alluxio.proxy.s3.S3RestServiceHandler
 
createOkResponse(DataBuffer) - Static method in class alluxio.network.protocol.RPCProtoMessage
Creates an OK response with data.
createOpenFilesLimitValidationTask() - Static method in class alluxio.cli.validation.UserLimitValidationTask
Creates a validation task for checking whether the user limit for number of open files is within reasonable range.
CreateOptions - Class in alluxio.client.block.policy.options
Method options for creating a BlockLocationPolicy.
CreateOptions - Class in alluxio.underfs.options
Method options for creating a file in UnderFileSystem.
createPacketReader(BlockReadRequestContext, Channel) - Method in class alluxio.worker.netty.BlockReadHandler
 
createPacketWriter(BlockWriteRequestContext, Channel) - Method in class alluxio.worker.netty.BlockWriteHandler
 
createPacketWriter(UfsFileWriteRequestContext, Channel) - Method in class alluxio.worker.netty.UfsFileWriteHandler
 
createPath(RpcContext, LockedInodePath, CreatePathOptions<?>) - Method in class alluxio.master.file.meta.InodeTree
Creates a file or directory at path.
CreatePathOptions<T> - Class in alluxio.master.file.options
Method options for creating a path.
CreatePathOptions() - Constructor for class alluxio.master.file.options.CreatePathOptions
 
createRecordReader(InputSplit, TaskAttemptContext) - Method in class alluxio.hadoop.mapreduce.KeyValueInputFormat
 
createRemoteBlockInStream(FileSystemContext, long, WorkerNetAddress, BlockInStream.BlockInStreamSource, long, Protocol.OpenUfsBlockOptions) - Static method in class alluxio.client.block.stream.BlockInStream
Creates a BlockInStream to read from a specific remote server.
createRequestContext(Protocol.ReadRequest) - Method in class alluxio.worker.netty.BlockReadHandler
 
createRequestContext(Protocol.WriteRequest) - Method in class alluxio.worker.netty.BlockWriteHandler
 
createRequestContext(Protocol.WriteRequest) - Method in class alluxio.worker.netty.UfsFileWriteHandler
 
createResponse(AlluxioStatusException) - Static method in class alluxio.network.protocol.RPCProtoMessage
Creates a response for a given AlluxioStatusException.
createResponse(Status, String, DataBuffer) - Static method in class alluxio.network.protocol.RPCProtoMessage
Creates a response for a given status, message, and data buffer.
createRpcContext() - Method in class alluxio.master.file.DefaultFileSystemMaster
 
createRpcId() - Static method in class alluxio.util.IdUtils
 
createSaslServer(String, String, String, Map<String, ?>, CallbackHandler) - Method in class alluxio.security.authentication.PlainSaslServer.Factory
Creates a SaslServer using the parameters supplied.
createSessionId() - Static method in class alluxio.util.IdUtils
 
createStorageDirPath(String) - Static method in class alluxio.util.io.FileUtils
Creates the storage directory path, including any necessary but nonexistent parent directories.
createStore(AlluxioURI) - Method in class alluxio.client.keyvalue.BaseKeyValueSystem
 
createStore(AlluxioURI) - Method in class alluxio.client.keyvalue.KeyValueMasterClient
Creates a new key-value store.
createStore(AlluxioURI) - Method in interface alluxio.client.keyvalue.KeyValueSystem
Gets a writer to create a new key-value store.
createStore(AlluxioURI) - Method in class alluxio.master.keyvalue.DefaultKeyValueMaster
 
createStore(AlluxioURI) - Method in interface alluxio.master.keyvalue.KeyValueMaster
Creates a new key-value store.
createStore(String, CreateStoreTOptions) - Method in class alluxio.master.keyvalue.KeyValueMasterClientServiceHandler
 
createStore(String, CreateStoreTOptions, AsyncMethodCallback) - Method in class alluxio.thrift.KeyValueMasterClientService.AsyncClient
 
createStore(String, CreateStoreTOptions, AsyncMethodCallback) - Method in interface alluxio.thrift.KeyValueMasterClientService.AsyncIface
 
createStore() - Constructor for class alluxio.thrift.KeyValueMasterClientService.AsyncProcessor.createStore
 
createStore(String, CreateStoreTOptions) - Method in class alluxio.thrift.KeyValueMasterClientService.Client
 
createStore(String, CreateStoreTOptions) - Method in interface alluxio.thrift.KeyValueMasterClientService.Iface
Creates a new key-value store on master.
createStore() - Constructor for class alluxio.thrift.KeyValueMasterClientService.Processor.createStore
 
createStore_args() - Constructor for class alluxio.thrift.KeyValueMasterClientService.createStore_args
 
createStore_args(String, CreateStoreTOptions) - Constructor for class alluxio.thrift.KeyValueMasterClientService.createStore_args
 
createStore_args(KeyValueMasterClientService.createStore_args) - Constructor for class alluxio.thrift.KeyValueMasterClientService.createStore_args
Performs a deep copy on other.
createStore_call(String, CreateStoreTOptions, AsyncMethodCallback, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class alluxio.thrift.KeyValueMasterClientService.AsyncClient.createStore_call
 
createStore_result() - Constructor for class alluxio.thrift.KeyValueMasterClientService.createStore_result
 
createStore_result(CreateStoreTResponse, AlluxioTException) - Constructor for class alluxio.thrift.KeyValueMasterClientService.createStore_result
 
createStore_result(KeyValueMasterClientService.createStore_result) - Constructor for class alluxio.thrift.KeyValueMasterClientService.createStore_result
Performs a deep copy on other.
CreateStoreTOptions - Class in alluxio.thrift
 
CreateStoreTOptions() - Constructor for class alluxio.thrift.CreateStoreTOptions
 
CreateStoreTOptions(CreateStoreTOptions) - Constructor for class alluxio.thrift.CreateStoreTOptions
Performs a deep copy on other.
CreateStoreTOptions._Fields - Enum in alluxio.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
CreateStoreTResponse - Class in alluxio.thrift
 
CreateStoreTResponse() - Constructor for class alluxio.thrift.CreateStoreTResponse
 
CreateStoreTResponse(CreateStoreTResponse) - Constructor for class alluxio.thrift.CreateStoreTResponse
Performs a deep copy on other.
CreateStoreTResponse._Fields - Enum in alluxio.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
createStream(long, long) - Method in class alluxio.underfs.cos.COSInputStream
 
createStream(long, long) - Method in class alluxio.underfs.MultiRangeObjectInputStream
Open 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
 
createTempBlockMeta(long, long, long) - Method in class alluxio.worker.block.meta.StorageDirView
Creates a TempBlockMeta given sessionId, blockId, and initialBlockSize.
createTempPathForChild(String) - Method in class alluxio.master.file.meta.LockedInodePath
Constructs a temporary LockedInodePath from an existing LockedInodePath, for a direct child of the existing path.
createTempPathForExistingChild(Inode<?>, InodeTree.LockMode) - Method in class alluxio.master.file.meta.LockedInodePath
Constructs a temporary LockedInodePath from an existing LockedInodePath, for a direct child of the existing path.
createThriftProtocol(TTransport, String) - Static method in class alluxio.network.thrift.ThriftUtils
 
createThriftProtocolFactory() - Static method in class alluxio.network.thrift.ThriftUtils
 
createThriftServerSocket(InetSocketAddress) - Static method in class alluxio.network.thrift.ThriftUtils
Creates a new Thrift server socket that listen on the given address.
createThriftSocket(InetSocketAddress) - Static method in class alluxio.network.thrift.ThriftUtils
Creates a new Thrift socket that will connect to the given address.
createUfsFile(long, String, CreateUfsFileTOptions, AsyncMethodCallback) - Method in class alluxio.thrift.FileSystemWorkerClientService.AsyncClient
 
createUfsFile(long, String, CreateUfsFileTOptions, AsyncMethodCallback) - Method in interface alluxio.thrift.FileSystemWorkerClientService.AsyncIface
 
createUfsFile() - Constructor for class alluxio.thrift.FileSystemWorkerClientService.AsyncProcessor.createUfsFile
 
createUfsFile(long, String, CreateUfsFileTOptions) - Method in class alluxio.thrift.FileSystemWorkerClientService.Client
 
createUfsFile(long, String, CreateUfsFileTOptions) - Method in interface alluxio.thrift.FileSystemWorkerClientService.Iface
Creates a file in the under file system.
createUfsFile() - Constructor for class alluxio.thrift.FileSystemWorkerClientService.Processor.createUfsFile
 
createUfsFile(long, String, CreateUfsFileTOptions) - Method in class alluxio.worker.file.FileSystemWorkerClientServiceHandler
 
createUfsFile_args() - Constructor for class alluxio.thrift.FileSystemWorkerClientService.createUfsFile_args
 
createUfsFile_args(long, String, CreateUfsFileTOptions) - Constructor for class alluxio.thrift.FileSystemWorkerClientService.createUfsFile_args
 
createUfsFile_args(FileSystemWorkerClientService.createUfsFile_args) - Constructor for class alluxio.thrift.FileSystemWorkerClientService.createUfsFile_args
Performs a deep copy on other.
createUfsFile_call(long, String, CreateUfsFileTOptions, AsyncMethodCallback, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class alluxio.thrift.FileSystemWorkerClientService.AsyncClient.createUfsFile_call
 
createUfsFile_result() - Constructor for class alluxio.thrift.FileSystemWorkerClientService.createUfsFile_result
 
createUfsFile_result(CreateUfsFileTResponse, AlluxioTException) - Constructor for class alluxio.thrift.FileSystemWorkerClientService.createUfsFile_result
 
createUfsFile_result(FileSystemWorkerClientService.createUfsFile_result) - Constructor for class alluxio.thrift.FileSystemWorkerClientService.createUfsFile_result
Performs a deep copy on other.
CreateUfsFileOptions - Class in alluxio.client.file.options
Options for creating a UFS file.
CreateUfsFileTOptions - Class in alluxio.thrift
 
CreateUfsFileTOptions() - Constructor for class alluxio.thrift.CreateUfsFileTOptions
 
CreateUfsFileTOptions(CreateUfsFileTOptions) - Constructor for class alluxio.thrift.CreateUfsFileTOptions
Performs a deep copy on other.
CreateUfsFileTOptions._Fields - Enum in alluxio.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
CreateUfsFileTResponse - Class in alluxio.thrift
 
CreateUfsFileTResponse() - Constructor for class alluxio.thrift.CreateUfsFileTResponse
 
CreateUfsFileTResponse(long) - Constructor for class alluxio.thrift.CreateUfsFileTResponse
 
CreateUfsFileTResponse(CreateUfsFileTResponse) - Constructor for class alluxio.thrift.CreateUfsFileTResponse
Performs a deep copy on other.
CreateUfsFileTResponse._Fields - Enum in alluxio.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
createUserProcessesLimitValidationTask() - Static method in class alluxio.cli.validation.UserLimitValidationTask
Creates a validation task for checking whether the user limit for number of user processes is within reasonable range.
createZkPrimarySelector() - Static method in class alluxio.master.PrimarySelector.Factory
 
CREATION_TIME_MS_FIELD_NUMBER - Static variable in class alluxio.proto.journal.File.InodeDirectoryEntry
 
CREATION_TIME_MS_FIELD_NUMBER - Static variable in class alluxio.proto.journal.File.InodeFileEntry
 
CREATION_TIME_MS_FIELD_NUMBER - Static variable in class alluxio.proto.journal.Lineage.LineageEntry
 
CSV_FILE_HEADER - Static variable in class alluxio.cli.ConfigurationDocGenerator
 
CsvSink - Class in alluxio.metrics.sink
A sink which creates a CSV file of the metric values.
CsvSink(Properties, MetricRegistry) - Constructor for class alluxio.metrics.sink.CsvSink
Creates a new CsvSink with a Properties and MetricRegistry.
CUR_DIR - Static variable in class alluxio.AlluxioURI
 
CustomAuthenticationProvider - Class in alluxio.security.authentication
An authentication provider implementation that allows AuthenticationProvider to be customized at configuration time.
CustomAuthenticationProvider(String) - Constructor for class alluxio.security.authentication.CustomAuthenticationProvider
Constructs a new custom authentication provider.

D

DailyMetadataBackup - Class in alluxio.master.meta
Backing up primary master metadata everyday at a fixed UTC time.
DATA_LOSS_VALUE - Static variable in enum alluxio.proto.status.Status.PStatus
DATA_LOSS = 15;
DataBuffer - Interface in alluxio.network.protocol.databuffer
This interface is a simple wrapper for the optional data that an RPCMessage may have.
DataByteArrayChannel - Class in alluxio.network.protocol.databuffer
A DataBuffer backed by a byte[].
DataByteArrayChannel(byte[], long, long) - Constructor for class alluxio.network.protocol.databuffer.DataByteArrayChannel
 
DataByteBuffer - Class in alluxio.network.protocol.databuffer
A DataBuffer with the underlying data being a ByteBuffer.
DataByteBuffer(ByteBuffer, long) - Constructor for class alluxio.network.protocol.databuffer.DataByteBuffer
 
DataFileChannel - Class in alluxio.network.protocol.databuffer
A DataBuffer with the underlying data being a FileChannel.
DataFileChannel(File, long, long) - Constructor for class alluxio.network.protocol.databuffer.DataFileChannel
 
DataLossException - Exception in alluxio.exception.status
Exception indicating unrecoverable data loss or corruption.
DataLossException(String) - Constructor for exception alluxio.exception.status.DataLossException
 
DataLossException(Throwable) - Constructor for exception alluxio.exception.status.DataLossException
 
DataLossException(String, Throwable) - Constructor for exception alluxio.exception.status.DataLossException
 
DataNettyBuffer - Class in alluxio.network.protocol.databuffer
A DataBuffer with the underlying data being a ByteBuf.
DataNettyBuffer(ByteBuf, long) - Constructor for class alluxio.network.protocol.databuffer.DataNettyBuffer
Constructor for creating a DataNettyBuffer, by passing a Netty ByteBuf.
DataNettyBufferV2 - Class in alluxio.network.protocol.databuffer
A DataBuffer with the underlying data being a ByteBuf.
DataNettyBufferV2(ByteBuf) - Constructor for class alluxio.network.protocol.databuffer.DataNettyBufferV2
Constructor for creating a DataNettyBuffer, by passing a Netty ByteBuf.
DataServer - Interface in alluxio.worker
Defines how to interact with a server running the data protocol.
DataServer.Factory - Class in alluxio.worker
Factory for DataServer.
DATASERVER_SESSION_ID - Static variable in class alluxio.Sessions
 
DAY - Static variable in class alluxio.Constants
 
DAY_MS - Static variable in class alluxio.Constants
 
DEADLINE_EXCEEDED_VALUE - Static variable in enum alluxio.proto.status.Status.PStatus
DEADLINE_EXCEEDED = 4;
DeadlineExceededException - Exception in alluxio.exception.status
Exception indicating that an operation was cancelled (typically by the caller).
DeadlineExceededException(String) - Constructor for exception alluxio.exception.status.DeadlineExceededException
 
DeadlineExceededException(Throwable) - Constructor for exception alluxio.exception.status.DeadlineExceededException
 
DeadlineExceededException(String, Throwable) - Constructor for exception alluxio.exception.status.DeadlineExceededException
 
DEBUG - Static variable in class alluxio.PropertyKey
 
DEBUG - Static variable in class alluxio.PropertyKey.Name
 
debug(String) - Method in class alluxio.util.logging.SamplingLogger
 
debug(String, Object) - Method in class alluxio.util.logging.SamplingLogger
 
debug(String, Object, Object) - Method in class alluxio.util.logging.SamplingLogger
 
debug(String, Object...) - Method in class alluxio.util.logging.SamplingLogger
 
debug(String, Throwable) - Method in class alluxio.util.logging.SamplingLogger
 
debug(Marker, String) - Method in class alluxio.util.logging.SamplingLogger
 
debug(Marker, String, Object) - Method in class alluxio.util.logging.SamplingLogger
 
debug(Marker, String, Object, Object) - Method in class alluxio.util.logging.SamplingLogger
 
debug(Marker, String, Object...) - Method in class alluxio.util.logging.SamplingLogger
 
debug(Marker, String, Throwable) - Method in class alluxio.util.logging.SamplingLogger
 
decide(LoggingEvent) - Method in class alluxio.AlluxioRemoteLogFilter
 
decode(ByteBuf) - Static method in enum alluxio.network.protocol.RPCMessage.Type
Returns the type represented by the id from the input ByteBuf.
decode(ChannelHandlerContext, ByteBuf, List<Object>) - Method in class alluxio.network.protocol.RPCMessageDecoder
 
decode(ByteBuf, ProtoMessage) - Static method in class alluxio.network.protocol.RPCProtoMessage
Decodes the message from a buffer.
decodeMessage(RPCMessage.Type, ByteBuf) - Static method in class alluxio.network.protocol.RPCMessage
Returns the message of message type 'type', decoded from the input ByteBuf.
decreaseUsageCount() - Method in class alluxio.worker.block.io.LocalFileBlockReader
decrease the file reader usage count.
deepCopy() - Method in class alluxio.thrift.AccessBlockTOptions
 
deepCopy() - Method in class alluxio.thrift.AccessBlockTResponse
 
deepCopy() - Method in class alluxio.thrift.AlluxioService.getServiceVersion_args
 
deepCopy() - Method in class alluxio.thrift.AlluxioService.getServiceVersion_result
 
deepCopy() - Method in exception alluxio.thrift.AlluxioTException
 
deepCopy() - Method in class alluxio.thrift.BackupTOptions
 
deepCopy() - Method in class alluxio.thrift.BackupTResponse
 
deepCopy() - Method in class alluxio.thrift.BlockHeartbeatTOptions
 
deepCopy() - Method in class alluxio.thrift.BlockHeartbeatTResponse
 
deepCopy() - Method in class alluxio.thrift.BlockInfo
 
deepCopy() - Method in class alluxio.thrift.BlockLocation
 
deepCopy() - Method in class alluxio.thrift.BlockMasterClientService.getBlockInfo_args
 
deepCopy() - Method in class alluxio.thrift.BlockMasterClientService.getBlockInfo_result
 
deepCopy() - Method in class alluxio.thrift.BlockMasterClientService.getBlockMasterInfo_args
 
deepCopy() - Method in class alluxio.thrift.BlockMasterClientService.getBlockMasterInfo_result
 
deepCopy() - Method in class alluxio.thrift.BlockMasterClientService.getCapacityBytes_args
 
deepCopy() - Method in class alluxio.thrift.BlockMasterClientService.getCapacityBytes_result
 
deepCopy() - Method in class alluxio.thrift.BlockMasterClientService.getUsedBytes_args
 
deepCopy() - Method in class alluxio.thrift.BlockMasterClientService.getUsedBytes_result
 
deepCopy() - Method in class alluxio.thrift.BlockMasterClientService.getWorkerInfoList_args
 
deepCopy() - Method in class alluxio.thrift.BlockMasterClientService.getWorkerInfoList_result
 
deepCopy() - Method in class alluxio.thrift.BlockMasterClientService.getWorkerReport_args
 
deepCopy() - Method in class alluxio.thrift.BlockMasterClientService.getWorkerReport_result
 
deepCopy() - Method in class alluxio.thrift.BlockMasterInfo
 
deepCopy() - Method in class alluxio.thrift.BlockMasterWorkerService.blockHeartbeat_args
 
deepCopy() - Method in class alluxio.thrift.BlockMasterWorkerService.blockHeartbeat_result
 
deepCopy() - Method in class alluxio.thrift.BlockMasterWorkerService.commitBlock_args
 
deepCopy() - Method in class alluxio.thrift.BlockMasterWorkerService.commitBlock_result
 
deepCopy() - Method in class alluxio.thrift.BlockMasterWorkerService.getWorkerId_args
 
deepCopy() - Method in class alluxio.thrift.BlockMasterWorkerService.getWorkerId_result
 
deepCopy() - Method in class alluxio.thrift.BlockMasterWorkerService.registerWorker_args
 
deepCopy() - Method in class alluxio.thrift.BlockMasterWorkerService.registerWorker_result
 
deepCopy() - Method in class alluxio.thrift.BlockWorkerClientService.accessBlock_args
 
deepCopy() - Method in class alluxio.thrift.BlockWorkerClientService.accessBlock_result
 
deepCopy() - Method in class alluxio.thrift.BlockWorkerClientService.cacheBlock_args
 
deepCopy() - Method in class alluxio.thrift.BlockWorkerClientService.cacheBlock_result
 
deepCopy() - Method in class alluxio.thrift.BlockWorkerClientService.cancelBlock_args
 
deepCopy() - Method in class alluxio.thrift.BlockWorkerClientService.cancelBlock_result
 
deepCopy() - Method in class alluxio.thrift.BlockWorkerClientService.lockBlock_args
 
deepCopy() - Method in class alluxio.thrift.BlockWorkerClientService.lockBlock_result
 
deepCopy() - Method in class alluxio.thrift.BlockWorkerClientService.promoteBlock_args
 
deepCopy() - Method in class alluxio.thrift.BlockWorkerClientService.promoteBlock_result
 
deepCopy() - Method in class alluxio.thrift.BlockWorkerClientService.removeBlock_args
 
deepCopy() - Method in class alluxio.thrift.BlockWorkerClientService.removeBlock_result
 
deepCopy() - Method in class alluxio.thrift.BlockWorkerClientService.requestBlockLocation_args
 
deepCopy() - Method in class alluxio.thrift.BlockWorkerClientService.requestBlockLocation_result
 
deepCopy() - Method in class alluxio.thrift.BlockWorkerClientService.requestSpace_args
 
deepCopy() - Method in class alluxio.thrift.BlockWorkerClientService.requestSpace_result
 
deepCopy() - Method in class alluxio.thrift.BlockWorkerClientService.sessionBlockHeartbeat_args
 
deepCopy() - Method in class alluxio.thrift.BlockWorkerClientService.sessionBlockHeartbeat_result
 
deepCopy() - Method in class alluxio.thrift.BlockWorkerClientService.unlockBlock_args
 
deepCopy() - Method in class alluxio.thrift.BlockWorkerClientService.unlockBlock_result
 
deepCopy() - Method in class alluxio.thrift.CacheBlockTOptions
 
deepCopy() - Method in class alluxio.thrift.CacheBlockTResponse
 
deepCopy() - Method in class alluxio.thrift.CancelBlockTOptions
 
deepCopy() - Method in class alluxio.thrift.CancelBlockTResponse
 
deepCopy() - Method in class alluxio.thrift.CancelUfsFileTOptions
 
deepCopy() - Method in class alluxio.thrift.CancelUfsFileTResponse
 
deepCopy() - Method in class alluxio.thrift.CheckConsistencyTOptions
 
deepCopy() - Method in class alluxio.thrift.CheckConsistencyTResponse
 
deepCopy() - Method in class alluxio.thrift.CloseUfsFileTOptions
 
deepCopy() - Method in class alluxio.thrift.CloseUfsFileTResponse
 
deepCopy() - Method in class alluxio.thrift.Command
 
deepCopy() - Method in class alluxio.thrift.CommandLineJobInfo
 
deepCopy() - Method in class alluxio.thrift.CommitBlockTOptions
 
deepCopy() - Method in class alluxio.thrift.CommitBlockTResponse
 
deepCopy() - Method in class alluxio.thrift.CompleteFileTOptions
 
deepCopy() - Method in class alluxio.thrift.CompleteFileTResponse
 
deepCopy() - Method in class alluxio.thrift.CompletePartitionTOptions
 
deepCopy() - Method in class alluxio.thrift.CompletePartitionTResponse
 
deepCopy() - Method in class alluxio.thrift.CompleteStoreTOptions
 
deepCopy() - Method in class alluxio.thrift.CompleteStoreTResponse
 
deepCopy() - Method in class alluxio.thrift.CompleteUfsFileTOptions
 
deepCopy() - Method in class alluxio.thrift.CompleteUfsFileTReponse
 
deepCopy() - Method in class alluxio.thrift.ConfigCheckReport
 
deepCopy() - Method in class alluxio.thrift.ConfigProperty
 
deepCopy() - Method in class alluxio.thrift.CreateDirectoryTOptions
 
deepCopy() - Method in class alluxio.thrift.CreateDirectoryTResponse
 
deepCopy() - Method in class alluxio.thrift.CreateFileTOptions
 
deepCopy() - Method in class alluxio.thrift.CreateFileTResponse
 
deepCopy() - Method in class alluxio.thrift.CreateLineageTOptions
 
deepCopy() - Method in class alluxio.thrift.CreateLineageTResponse
 
deepCopy() - Method in class alluxio.thrift.CreateStoreTOptions
 
deepCopy() - Method in class alluxio.thrift.CreateStoreTResponse
 
deepCopy() - Method in class alluxio.thrift.CreateUfsFileTOptions
 
deepCopy() - Method in class alluxio.thrift.CreateUfsFileTResponse
 
deepCopy() - Method in class alluxio.thrift.DeleteLineageTOptions
 
deepCopy() - Method in class alluxio.thrift.DeleteLineageTResponse
 
deepCopy() - Method in class alluxio.thrift.DeleteStoreTOptions
 
deepCopy() - Method in class alluxio.thrift.DeleteStoreTResponse
 
deepCopy() - Method in class alluxio.thrift.DeleteTOptions
 
deepCopy() - Method in class alluxio.thrift.DeleteTResponse
 
deepCopy() - Method in class alluxio.thrift.DependencyInfo
 
deepCopy() - Method in class alluxio.thrift.FileBlockInfo
 
deepCopy() - Method in class alluxio.thrift.FileInfo
 
deepCopy() - Method in class alluxio.thrift.FileSystemCommand
 
deepCopy() - Method in class alluxio.thrift.FileSystemCommandOptions
 
deepCopy() - Method in class alluxio.thrift.FileSystemHeartbeatTOptions
 
deepCopy() - Method in class alluxio.thrift.FileSystemHeartbeatTResponse
 
deepCopy() - Method in class alluxio.thrift.FileSystemMasterClientService.checkConsistency_args
 
deepCopy() - Method in class alluxio.thrift.FileSystemMasterClientService.checkConsistency_result
 
deepCopy() - Method in class alluxio.thrift.FileSystemMasterClientService.completeFile_args
 
deepCopy() - Method in class alluxio.thrift.FileSystemMasterClientService.completeFile_result
 
deepCopy() - Method in class alluxio.thrift.FileSystemMasterClientService.createDirectory_args
 
deepCopy() - Method in class alluxio.thrift.FileSystemMasterClientService.createDirectory_result
 
deepCopy() - Method in class alluxio.thrift.FileSystemMasterClientService.createFile_args
 
deepCopy() - Method in class alluxio.thrift.FileSystemMasterClientService.createFile_result
 
deepCopy() - Method in class alluxio.thrift.FileSystemMasterClientService.free_args
 
deepCopy() - Method in class alluxio.thrift.FileSystemMasterClientService.free_result
 
deepCopy() - Method in class alluxio.thrift.FileSystemMasterClientService.getFilePath_args
 
deepCopy() - Method in class alluxio.thrift.FileSystemMasterClientService.getFilePath_result
 
deepCopy() - Method in class alluxio.thrift.FileSystemMasterClientService.getMountTable_args
 
deepCopy() - Method in class alluxio.thrift.FileSystemMasterClientService.getMountTable_result
 
deepCopy() - Method in class alluxio.thrift.FileSystemMasterClientService.getNewBlockIdForFile_args
 
deepCopy() - Method in class alluxio.thrift.FileSystemMasterClientService.getNewBlockIdForFile_result
 
deepCopy() - Method in class alluxio.thrift.FileSystemMasterClientService.getStatus_args
 
deepCopy() - Method in class alluxio.thrift.FileSystemMasterClientService.getStatus_result
 
deepCopy() - Method in class alluxio.thrift.FileSystemMasterClientService.listStatus_args
 
deepCopy() - Method in class alluxio.thrift.FileSystemMasterClientService.listStatus_result
 
deepCopy() - Method in class alluxio.thrift.FileSystemMasterClientService.loadMetadata_args
 
deepCopy() - Method in class alluxio.thrift.FileSystemMasterClientService.loadMetadata_result
 
deepCopy() - Method in class alluxio.thrift.FileSystemMasterClientService.mount_args
 
deepCopy() - Method in class alluxio.thrift.FileSystemMasterClientService.mount_result
 
deepCopy() - Method in class alluxio.thrift.FileSystemMasterClientService.remove_args
 
deepCopy() - Method in class alluxio.thrift.FileSystemMasterClientService.remove_result
 
deepCopy() - Method in class alluxio.thrift.FileSystemMasterClientService.rename_args
 
deepCopy() - Method in class alluxio.thrift.FileSystemMasterClientService.rename_result
 
deepCopy() - Method in class alluxio.thrift.FileSystemMasterClientService.scheduleAsyncPersistence_args
 
deepCopy() - Method in class alluxio.thrift.FileSystemMasterClientService.scheduleAsyncPersistence_result
 
deepCopy() - Method in class alluxio.thrift.FileSystemMasterClientService.setAttribute_args
 
deepCopy() - Method in class alluxio.thrift.FileSystemMasterClientService.setAttribute_result
 
deepCopy() - Method in class alluxio.thrift.FileSystemMasterClientService.unmount_args
 
deepCopy() - Method in class alluxio.thrift.FileSystemMasterClientService.unmount_result
 
deepCopy() - Method in class alluxio.thrift.FileSystemMasterClientService.updateUfsMode_args
 
deepCopy() - Method in class alluxio.thrift.FileSystemMasterClientService.updateUfsMode_result
 
deepCopy() - Method in class alluxio.thrift.FileSystemMasterCommonTOptions
 
deepCopy() - Method in class alluxio.thrift.FileSystemMasterWorkerService.fileSystemHeartbeat_args
 
deepCopy() - Method in class alluxio.thrift.FileSystemMasterWorkerService.fileSystemHeartbeat_result
 
deepCopy() - Method in class alluxio.thrift.FileSystemMasterWorkerService.getFileInfo_args
 
deepCopy() - Method in class alluxio.thrift.FileSystemMasterWorkerService.getFileInfo_result
 
deepCopy() - Method in class alluxio.thrift.FileSystemMasterWorkerService.getPinnedFileIds_args
 
deepCopy() - Method in class alluxio.thrift.FileSystemMasterWorkerService.getPinnedFileIds_result
 
deepCopy() - Method in class alluxio.thrift.FileSystemMasterWorkerService.getUfsInfo_args
 
deepCopy() - Method in class alluxio.thrift.FileSystemMasterWorkerService.getUfsInfo_result
 
deepCopy() - Method in class alluxio.thrift.FileSystemWorkerClientService.cancelUfsFile_args
 
deepCopy() - Method in class alluxio.thrift.FileSystemWorkerClientService.cancelUfsFile_result
 
deepCopy() - Method in class alluxio.thrift.FileSystemWorkerClientService.closeUfsFile_args
 
deepCopy() - Method in class alluxio.thrift.FileSystemWorkerClientService.closeUfsFile_result
 
deepCopy() - Method in class alluxio.thrift.FileSystemWorkerClientService.completeUfsFile_args
 
deepCopy() - Method in class alluxio.thrift.FileSystemWorkerClientService.completeUfsFile_result
 
deepCopy() - Method in class alluxio.thrift.FileSystemWorkerClientService.createUfsFile_args
 
deepCopy() - Method in class alluxio.thrift.FileSystemWorkerClientService.createUfsFile_result
 
deepCopy() - Method in class alluxio.thrift.FileSystemWorkerClientService.openUfsFile_args
 
deepCopy() - Method in class alluxio.thrift.FileSystemWorkerClientService.openUfsFile_result
 
deepCopy() - Method in class alluxio.thrift.FileSystemWorkerClientService.sessionFileSystemHeartbeat_args
 
deepCopy() - Method in class alluxio.thrift.FileSystemWorkerClientService.sessionFileSystemHeartbeat_result
 
deepCopy() - Method in class alluxio.thrift.FreeTOptions
 
deepCopy() - Method in class alluxio.thrift.FreeTResponse
 
deepCopy() - Method in class alluxio.thrift.GetBlockInfoTOptions
 
deepCopy() - Method in class alluxio.thrift.GetBlockInfoTResponse
 
deepCopy() - Method in class alluxio.thrift.GetBlockMasterInfoTOptions
 
deepCopy() - Method in class alluxio.thrift.GetBlockMasterInfoTResponse
 
deepCopy() - Method in class alluxio.thrift.GetCapacityBytesTOptions
 
deepCopy() - Method in class alluxio.thrift.GetCapacityBytesTResponse
 
deepCopy() - Method in class alluxio.thrift.GetConfigReportTOptions
 
deepCopy() - Method in class alluxio.thrift.GetConfigReportTResponse
 
deepCopy() - Method in class alluxio.thrift.GetConfigurationTOptions
 
deepCopy() - Method in class alluxio.thrift.GetConfigurationTResponse
 
deepCopy() - Method in class alluxio.thrift.GetFileInfoTOptions
 
deepCopy() - Method in class alluxio.thrift.GetFileInfoTResponse
 
deepCopy() - Method in class alluxio.thrift.GetFilePathTOptions
 
deepCopy() - Method in class alluxio.thrift.GetFilePathTResponse
 
deepCopy() - Method in class alluxio.thrift.GetLineageInfoListTOptions
 
deepCopy() - Method in class alluxio.thrift.GetLineageInfoListTResponse
 
deepCopy() - Method in class alluxio.thrift.GetMasterIdTOptions
 
deepCopy() - Method in class alluxio.thrift.GetMasterIdTResponse
 
deepCopy() - Method in class alluxio.thrift.GetMasterInfoTOptions
 
deepCopy() - Method in class alluxio.thrift.GetMasterInfoTResponse
 
deepCopy() - Method in class alluxio.thrift.GetMetricsTOptions
 
deepCopy() - Method in class alluxio.thrift.GetMetricsTResponse
 
deepCopy() - Method in class alluxio.thrift.GetMountTableTResponse
 
deepCopy() - Method in class alluxio.thrift.GetNewBlockIdForFileTOptions
 
deepCopy() - Method in class alluxio.thrift.GetNewBlockIdForFileTResponse
 
deepCopy() - Method in class alluxio.thrift.GetNextKeysTOptions
 
deepCopy() - Method in class alluxio.thrift.GetNextKeysTResponse
 
deepCopy() - Method in class alluxio.thrift.GetPartitionInfoTOptions
 
deepCopy() - Method in class alluxio.thrift.GetPartitionInfoTResponse
 
deepCopy() - Method in class alluxio.thrift.GetPinnedFileIdsTOptions
 
deepCopy() - Method in class alluxio.thrift.GetPinnedFileIdsTResponse
 
deepCopy() - Method in class alluxio.thrift.GetServiceVersionTOptions
 
deepCopy() - Method in class alluxio.thrift.GetServiceVersionTResponse
 
deepCopy() - Method in class alluxio.thrift.GetSizeTOptions
 
deepCopy() - Method in class alluxio.thrift.GetSizeTResponse
 
deepCopy() - Method in class alluxio.thrift.GetStatusTOptions
 
deepCopy() - Method in class alluxio.thrift.GetStatusTResponse
 
deepCopy() - Method in class alluxio.thrift.GetTOptions
 
deepCopy() - Method in class alluxio.thrift.GetTResponse
 
deepCopy() - Method in class alluxio.thrift.GetUfsInfoTOptions
 
deepCopy() - Method in class alluxio.thrift.GetUfsInfoTResponse
 
deepCopy() - Method in class alluxio.thrift.GetUsedBytesTOptions
 
deepCopy() - Method in class alluxio.thrift.GetUsedBytesTResponse
 
deepCopy() - Method in class alluxio.thrift.GetWorkerIdTOptions
 
deepCopy() - Method in class alluxio.thrift.GetWorkerIdTResponse
 
deepCopy() - Method in class alluxio.thrift.GetWorkerInfoListTOptions
 
deepCopy() - Method in class alluxio.thrift.GetWorkerInfoListTResponse
 
deepCopy() - Method in class alluxio.thrift.GetWorkerReportTOptions
 
deepCopy() - Method in class alluxio.thrift.InconsistentProperty
 
deepCopy() - Method in class alluxio.thrift.JobConfInfo
 
deepCopy() - Method in class alluxio.thrift.KeyValueMasterClientService.completePartition_args
 
deepCopy() - Method in class alluxio.thrift.KeyValueMasterClientService.completePartition_result
 
deepCopy() - Method in class alluxio.thrift.KeyValueMasterClientService.completeStore_args
 
deepCopy() - Method in class alluxio.thrift.KeyValueMasterClientService.completeStore_result
 
deepCopy() - Method in class alluxio.thrift.KeyValueMasterClientService.createStore_args
 
deepCopy() - Method in class alluxio.thrift.KeyValueMasterClientService.createStore_result
 
deepCopy() - Method in class alluxio.thrift.KeyValueMasterClientService.deleteStore_args
 
deepCopy() - Method in class alluxio.thrift.KeyValueMasterClientService.deleteStore_result
 
deepCopy() - Method in class alluxio.thrift.KeyValueMasterClientService.getPartitionInfo_args
 
deepCopy() - Method in class alluxio.thrift.KeyValueMasterClientService.getPartitionInfo_result
 
deepCopy() - Method in class alluxio.thrift.KeyValueMasterClientService.mergeStore_args
 
deepCopy() - Method in class alluxio.thrift.KeyValueMasterClientService.mergeStore_result
 
deepCopy() - Method in class alluxio.thrift.KeyValueMasterClientService.renameStore_args
 
deepCopy() - Method in class alluxio.thrift.KeyValueMasterClientService.renameStore_result
 
deepCopy() - Method in class alluxio.thrift.KeyValueWorkerClientService.get_args
 
deepCopy() - Method in class alluxio.thrift.KeyValueWorkerClientService.get_result
 
deepCopy() - Method in class alluxio.thrift.KeyValueWorkerClientService.getNextKeys_args
 
deepCopy() - Method in class alluxio.thrift.KeyValueWorkerClientService.getNextKeys_result
 
deepCopy() - Method in class alluxio.thrift.KeyValueWorkerClientService.getSize_args
 
deepCopy() - Method in class alluxio.thrift.KeyValueWorkerClientService.getSize_result
 
deepCopy() - Method in class alluxio.thrift.LineageInfo
 
deepCopy() - Method in class alluxio.thrift.LineageMasterClientService.createLineage_args
 
deepCopy() - Method in class alluxio.thrift.LineageMasterClientService.createLineage_result
 
deepCopy() - Method in class alluxio.thrift.LineageMasterClientService.deleteLineage_args
 
deepCopy() - Method in class alluxio.thrift.LineageMasterClientService.deleteLineage_result
 
deepCopy() - Method in class alluxio.thrift.LineageMasterClientService.getLineageInfoList_args
 
deepCopy() - Method in class alluxio.thrift.LineageMasterClientService.getLineageInfoList_result
 
deepCopy() - Method in class alluxio.thrift.LineageMasterClientService.reinitializeFile_args
 
deepCopy() - Method in class alluxio.thrift.LineageMasterClientService.reinitializeFile_result
 
deepCopy() - Method in class alluxio.thrift.LineageMasterClientService.reportLostFile_args
 
deepCopy() - Method in class alluxio.thrift.LineageMasterClientService.reportLostFile_result
 
deepCopy() - Method in class alluxio.thrift.ListStatusTOptions
 
deepCopy() - Method in class alluxio.thrift.ListStatusTResponse
 
deepCopy() - Method in class alluxio.thrift.LoadMetadataTOptions
 
deepCopy() - Method in class alluxio.thrift.LoadMetadataTResponse
 
deepCopy() - Method in class alluxio.thrift.LocalityTier
 
deepCopy() - Method in class alluxio.thrift.LockBlockTOptions
 
deepCopy() - Method in class alluxio.thrift.LockBlockTResponse
 
deepCopy() - Method in class alluxio.thrift.MasterHeartbeatTOptions
 
deepCopy() - Method in class alluxio.thrift.MasterHeartbeatTResponse
 
deepCopy() - Method in class alluxio.thrift.MasterInfo
 
deepCopy() - Method in class alluxio.thrift.MasterNetAddress
 
deepCopy() - Method in class alluxio.thrift.MergeStoreTOptions
 
deepCopy() - Method in class alluxio.thrift.MergeStoreTResponse
 
deepCopy() - Method in class alluxio.thrift.MetaMasterClientService.backup_args
 
deepCopy() - Method in class alluxio.thrift.MetaMasterClientService.backup_result
 
deepCopy() - Method in class alluxio.thrift.MetaMasterClientService.getConfigReport_args
 
deepCopy() - Method in class alluxio.thrift.MetaMasterClientService.getConfigReport_result
 
deepCopy() - Method in class alluxio.thrift.MetaMasterClientService.getConfiguration_args
 
deepCopy() - Method in class alluxio.thrift.MetaMasterClientService.getConfiguration_result
 
deepCopy() - Method in class alluxio.thrift.MetaMasterClientService.getMasterInfo_args
 
deepCopy() - Method in class alluxio.thrift.MetaMasterClientService.getMasterInfo_result
 
deepCopy() - Method in class alluxio.thrift.MetaMasterClientService.getMetrics_args
 
deepCopy() - Method in class alluxio.thrift.MetaMasterClientService.getMetrics_result
 
deepCopy() - Method in class alluxio.thrift.MetaMasterMasterService.getMasterId_args
 
deepCopy() - Method in class alluxio.thrift.MetaMasterMasterService.getMasterId_result
 
deepCopy() - Method in class alluxio.thrift.MetaMasterMasterService.masterHeartbeat_args
 
deepCopy() - Method in class alluxio.thrift.MetaMasterMasterService.masterHeartbeat_result
 
deepCopy() - Method in class alluxio.thrift.MetaMasterMasterService.registerMaster_args
 
deepCopy() - Method in class alluxio.thrift.MetaMasterMasterService.registerMaster_result
 
deepCopy() - Method in class alluxio.thrift.Metric
 
deepCopy() - Method in class alluxio.thrift.MetricsHeartbeatTOptions
 
deepCopy() - Method in class alluxio.thrift.MetricsHeartbeatTResponse
 
deepCopy() - Method in class alluxio.thrift.MetricsMasterClientService.metricsHeartbeat_args
 
deepCopy() - Method in class alluxio.thrift.MetricsMasterClientService.metricsHeartbeat_result
 
deepCopy() - Method in class alluxio.thrift.MetricValue
 
deepCopy() - Method in class alluxio.thrift.MountPointInfo
 
deepCopy() - Method in class alluxio.thrift.MountTOptions
 
deepCopy() - Method in class alluxio.thrift.MountTResponse
 
deepCopy() - Method in class alluxio.thrift.OpenUfsFileTOptions
 
deepCopy() - Method in class alluxio.thrift.OpenUfsFileTResponse
 
deepCopy() - Method in class alluxio.thrift.OptionalString
 
deepCopy() - Method in class alluxio.thrift.PartitionInfo
 
deepCopy() - Method in class alluxio.thrift.PersistCommandOptions
 
deepCopy() - Method in class alluxio.thrift.PersistFile
 
deepCopy() - Method in class alluxio.thrift.PromoteBlockTOptions
 
deepCopy() - Method in class alluxio.thrift.PromoteBlockTResponse
 
deepCopy() - Method in class alluxio.thrift.RegisterMasterTOptions
 
deepCopy() - Method in class alluxio.thrift.RegisterMasterTResponse
 
deepCopy() - Method in class alluxio.thrift.RegisterWorkerTOptions
 
deepCopy() - Method in class alluxio.thrift.RegisterWorkerTResponse
 
deepCopy() - Method in class alluxio.thrift.ReinitializeFileTOptions
 
deepCopy() - Method in class alluxio.thrift.ReinitializeFileTResponse
 
deepCopy() - Method in class alluxio.thrift.RemoveBlockTOptions
 
deepCopy() - Method in class alluxio.thrift.RemoveBlockTResponse
 
deepCopy() - Method in class alluxio.thrift.RenameStoreTOptions
 
deepCopy() - Method in class alluxio.thrift.RenameStoreTResponse
 
deepCopy() - Method in class alluxio.thrift.RenameTOptions
 
deepCopy() - Method in class alluxio.thrift.RenameTResponse
 
deepCopy() - Method in class alluxio.thrift.ReportLostFileTOptions
 
deepCopy() - Method in class alluxio.thrift.ReportLostFileTResponse
 
deepCopy() - Method in class alluxio.thrift.RequestBlockLocationTOptions
 
deepCopy() - Method in class alluxio.thrift.RequestBlockLocationTResponse
 
deepCopy() - Method in class alluxio.thrift.RequestSpaceTOptions
 
deepCopy() - Method in class alluxio.thrift.RequestSpaceTResponse
 
deepCopy() - Method in class alluxio.thrift.ScheduleAsyncPersistenceTOptions
 
deepCopy() - Method in class alluxio.thrift.ScheduleAsyncPersistenceTResponse
 
deepCopy() - Method in class alluxio.thrift.SessionBlockHeartbeatTOptions
 
deepCopy() - Method in class alluxio.thrift.SessionBlockHeartbeatTResponse
 
deepCopy() - Method in class alluxio.thrift.SessionFileSystemHeartbeatTOptions
 
deepCopy() - Method in class alluxio.thrift.SessionFileSystemHeartbeatTResponse
 
deepCopy() - Method in class alluxio.thrift.SetAttributeTOptions
 
deepCopy() - Method in class alluxio.thrift.SetAttributeTResponse
 
deepCopy() - Method in class alluxio.thrift.SyncMetadataTOptions
 
deepCopy() - Method in class alluxio.thrift.SyncMetadataTResponse
 
deepCopy() - Method in class alluxio.thrift.TieredIdentity
 
deepCopy() - Method in class alluxio.thrift.UfsInfo
 
deepCopy() - Method in class alluxio.thrift.UnlockBlockTOptions
 
deepCopy() - Method in class alluxio.thrift.UnlockBlockTResponse
 
deepCopy() - Method in class alluxio.thrift.UnmountTOptions
 
deepCopy() - Method in class alluxio.thrift.UnmountTResponse
 
deepCopy() - Method in class alluxio.thrift.UpdateUfsModeTOptions
 
deepCopy() - Method in class alluxio.thrift.UpdateUfsModeTResponse
 
deepCopy() - Method in class alluxio.thrift.WorkerInfo
 
deepCopy() - Method in class alluxio.thrift.WorkerNetAddress
 
DEFAULT - Static variable in class alluxio.conf.Source
 
DEFAULT_FILE_SYSTEM_MODE - Static variable in class alluxio.Constants
 
DEFAULT_FILE_SYSTEM_UMASK - Static variable in class alluxio.Constants
 
DEFAULT_REGISTRY_GET_TIMEOUT_MS - Static variable in class alluxio.Constants
 
DefaultAsyncPersistHandler - Class in alluxio.master.file.async
The default handler for async persistence that schedules the persistence on the workers that contains all the blocks of a given file, and the handler returns the scheduled request whenever the corresponding worker polls.
DefaultAsyncPersistHandler(FileSystemMasterView) - Constructor for class alluxio.master.file.async.DefaultAsyncPersistHandler
Constructs a new instance of AsyncPersistHandler.
DefaultBlockDeletionContext - Class in alluxio.master.file
Class for tracking which blocks need to be deleted, and deleting them on close.
DefaultBlockDeletionContext(BlockDeletionContext.BlockDeletionListener...) - Constructor for class alluxio.master.file.DefaultBlockDeletionContext
 
DefaultBlockMaster - Class in alluxio.master.block
This block master manages the metadata for all the blocks and block workers in Alluxio.
DefaultBlockMaster.Metrics - Class in alluxio.master.block
Class that contains metrics related to BlockMaster.
DefaultBlockStoreMeta - Class in alluxio.worker.block
This class holds the metadata information of a block store.
DefaultBlockStoreMeta(BlockMetadataManager, boolean) - Constructor for class alluxio.worker.block.DefaultBlockStoreMeta
Creates a new instance of DefaultBlockStoreMeta.
DefaultBlockWorker - Class in alluxio.worker.block
The class is responsible for managing all top level components of the Block Worker.
DefaultBlockWorker.Metrics - Class in alluxio.worker.block
This class contains some metrics related to the block worker.
DefaultFileSystemMaster - Class in alluxio.master.file
The master that handles all file system metadata management.
DefaultFileSystemMaster.Metrics - Class in alluxio.master.file
Class that contains metrics for FileSystemMaster.
DefaultFileSystemWorker - Class in alluxio.worker.file
This class is responsible for persisting files when requested by the master and a defunct FileSystemWorkerClientServiceHandler which always returns UnsupportedOperation Exception.
DefaultInodePermissionChecker - Class in alluxio.master.file
InodePermissionChecker implementation using standard POSIX permission model.
DefaultInodePermissionChecker() - Constructor for class alluxio.master.file.DefaultInodePermissionChecker
 
defaultKeys() - Static method in class alluxio.PropertyKey
 
DefaultKeyValueMaster - Class in alluxio.master.keyvalue
This master stores key-value store information in Alluxio, including the partitions of each key-value store.
DefaultLineageMaster - Class in alluxio.master.lineage
The default lineage master stores the lineage metadata in Alluxio, and it contains the components that manage all lineage-related activities.
DefaultMetaMaster - Class in alluxio.master.meta
The default meta master.
DefaultMetricsMaster - Class in alluxio.master.metrics
Default implementation of the metrics master.
defaultOptions() - Static method in class alluxio.resource.DynamicResourcePool.Options
 
DefaultPermissionChecker - Class in alluxio.master.file
Default implementation of permission checker.
DefaultPermissionChecker(InodeTree) - Constructor for class alluxio.master.file.DefaultPermissionChecker
Constructs a PermissionChecker instance for Alluxio file system.
defaults() - Static method in class alluxio.client.block.options.GetWorkerReportOptions
 
defaults() - Static method in class alluxio.client.block.options.LockBlockOptions
 
defaults() - Static method in class alluxio.client.block.policy.options.CreateOptions
 
defaults() - Static method in class alluxio.client.block.policy.options.GetWorkerOptions
 
defaults() - Static method in class alluxio.client.file.options.CancelUfsFileOptions
 
defaults() - Static method in class alluxio.client.file.options.CheckConsistencyOptions
 
defaults() - Static method in class alluxio.client.file.options.CloseUfsFileOptions
 
defaults() - Static method in class alluxio.client.file.options.CompleteFileOptions
 
defaults() - Static method in class alluxio.client.file.options.CompleteUfsFileOptions
Creates a default CompleteUfsFileOptions with owner, group from login module and default file mode.
defaults() - Static method in class alluxio.client.file.options.CreateDirectoryOptions
 
defaults() - Static method in class alluxio.client.file.options.CreateFileOptions
 
defaults() - Static method in class alluxio.client.file.options.CreateUfsFileOptions
Creates a default CreateUfsFileOptions with owner, group from login module and default file mode.
defaults() - Static method in class alluxio.client.file.options.DeleteOptions
 
defaults() - Static method in class alluxio.client.file.options.ExistsOptions
 
defaults() - Static method in class alluxio.client.file.options.FreeOptions
 
defaults() - Static method in class alluxio.client.file.options.GetStatusOptions
 
defaults() - Static method in class alluxio.client.file.options.ListStatusOptions
 
defaults() - Static method in class alluxio.client.file.options.LoadMetadataOptions
Deprecated.
 
defaults() - Static method in class alluxio.client.file.options.MountOptions
 
defaults() - Static method in class alluxio.client.file.options.OpenFileOptions
 
defaults() - Static method in class alluxio.client.file.options.OpenUfsFileOptions
 
defaults() - Static method in class alluxio.client.file.options.OutStreamOptions
 
defaults() - Static method in class alluxio.client.file.options.RenameOptions
 
defaults() - Static method in class alluxio.client.file.options.SetAttributeOptions
 
defaults() - Static method in class alluxio.client.file.options.UnmountOptions
 
defaults() - Static method in class alluxio.client.file.options.UpdateUfsModeOptions
 
defaults() - Static method in class alluxio.client.lineage.options.CreateLineageOptions
 
defaults() - Static method in class alluxio.client.lineage.options.DeleteLineageOptions
 
defaults() - Static method in class alluxio.client.lineage.options.GetLineageInfoListOptions
 
defaults() - Static method in class alluxio.ConfigurationValueOptions
 
defaults() - Static method in class alluxio.master.file.options.CheckConsistencyOptions
 
defaults() - Static method in class alluxio.master.file.options.CompleteFileOptions
 
defaults() - Static method in class alluxio.master.file.options.CreateDirectoryOptions
 
defaults() - Static method in class alluxio.master.file.options.CreateFileOptions
 
defaults() - Static method in class alluxio.master.file.options.DeleteOptions
 
defaults() - Static method in class alluxio.master.file.options.FreeOptions
 
defaults() - Static method in class alluxio.master.file.options.GetStatusOptions
 
defaults() - Static method in class alluxio.master.file.options.ListStatusOptions
 
defaults() - Static method in class alluxio.master.file.options.LoadMetadataOptions
 
defaults() - Static method in class alluxio.master.file.options.MountOptions
 
defaults() - Static method in class alluxio.master.file.options.RenameOptions
 
defaults() - Static method in class alluxio.master.file.options.SetAttributeOptions
 
defaults() - Static method in class alluxio.master.file.options.SyncMetadataOptions
 
defaults() - Static method in class alluxio.master.file.options.WorkerHeartbeatOptions
 
defaults() - Static method in class alluxio.master.journal.options.JournalReaderOptions
 
defaults() - Static method in class alluxio.master.journal.options.JournalWriterOptions
 
defaults() - Static method in class alluxio.master.MasterClientConfig
 
defaults() - Static method in class alluxio.network.netty.NettyRPCContext
 
defaults() - Static method in class alluxio.proxy.s3.ListBucketOptions
Creates a default ListBucketOptions.
defaults() - Static method in class alluxio.security.authorization.Mode
Gets the default mode.
defaults() - Static method in class alluxio.underfs.options.CreateOptions
 
defaults() - Static method in class alluxio.underfs.options.DeleteOptions
 
defaults() - Static method in class alluxio.underfs.options.FileLocationOptions
 
defaults() - Static method in class alluxio.underfs.options.ListOptions
 
defaults() - Static method in class alluxio.underfs.options.MkdirsOptions
 
defaults() - Static method in class alluxio.underfs.options.OpenOptions
 
defaults() - Static method in class alluxio.underfs.UnderFileSystemConfiguration
 
defaults() - Static method in class alluxio.util.WaitForOptions
 
defaults() - Static method in class alluxio.wire.CommonOptions
 
defaults() - Static method in class alluxio.wire.GetConfigurationOptions
 
DefaultSafeModeManager - Class in alluxio.master
Manages safe mode state for Alluxio master.
DefaultSafeModeManager() - Constructor for class alluxio.master.DefaultSafeModeManager
Creates DefaultSafeModeManager with default clock.
DefaultSafeModeManager(Clock) - Constructor for class alluxio.master.DefaultSafeModeManager
Creates DefaultSafeModeManager with given clock.
DefaultSupplier - Class in alluxio
Supplier for a configuration property default.
DefaultSupplier(Supplier<Object>, String) - Constructor for class alluxio.DefaultSupplier
 
DelayNode(T, long) - Constructor for class alluxio.util.executor.ControllableQueue.DelayNode
Constructs a new ControllableQueue.DelayNode.
delete(AlluxioURI) - Method in class alluxio.client.file.BaseFileSystem
 
delete(AlluxioURI, DeleteOptions) - Method in class alluxio.client.file.BaseFileSystem
 
delete(AlluxioURI) - Method in interface alluxio.client.file.FileSystem
Convenience method for FileSystem.delete(AlluxioURI, DeleteOptions) with default options.
delete(AlluxioURI, DeleteOptions) - Method in interface alluxio.client.file.FileSystem
Deletes a file or a directory.
delete(AlluxioURI, DeleteOptions) - Method in interface alluxio.client.file.FileSystemMasterClient
Deletes a file or a directory.
delete(AlluxioURI, DeleteOptions) - Method in class alluxio.client.file.RetryHandlingFileSystemMasterClient
 
delete(AlluxioURI, DeleteOptions) - Method in class alluxio.master.file.DefaultFileSystemMaster
 
delete(AlluxioURI, DeleteOptions) - Method in interface alluxio.master.file.FileSystemMaster
Deletes a given path.
delete(AlluxioURI) - Method in class alluxio.master.file.meta.MountTable
Unmounts the given Alluxio path.
delete(AlluxioURI, Inode) - Method in class alluxio.master.file.NoopUfsDeleter
 
delete(AlluxioURI, Inode) - Method in class alluxio.master.file.SafeUfsDeleter
 
delete(AlluxioURI, Inode) - Method in interface alluxio.master.file.UfsDeleter
Deletes a path if not covered by a recursive delete.
DELETE - Static variable in class alluxio.proxy.PathsRestServiceHandler
 
delete(String, DeleteOptions) - Method in class alluxio.proxy.PathsRestServiceHandler
 
delete(String) - Static method in class alluxio.util.io.FileUtils
Deletes the file or directory.
DELETE_BLOCK_FIELD_NUMBER - Static variable in class alluxio.proto.journal.Journal.JournalEntry
 
DELETE_FILE_FIELD_NUMBER - Static variable in class alluxio.proto.journal.Journal.JournalEntry
 
DELETE_LINEAGE - Static variable in class alluxio.master.lineage.LineageMasterClientRestServiceHandler
Deprecated.
 
DELETE_LINEAGE_FIELD_NUMBER - Static variable in class alluxio.proto.journal.Journal.JournalEntry
 
DELETE_MOUNT_POINT_FIELD_NUMBER - Static variable in class alluxio.proto.journal.Journal.JournalEntry
 
DELETE_PATHS_OPS - Static variable in class alluxio.metrics.MasterMetrics
 
DELETE_STORE_FIELD_NUMBER - Static variable in class alluxio.proto.journal.Journal.JournalEntry
 
DELETE_VALUE - Static variable in enum alluxio.proto.journal.File.PTtlAction
DELETE = 0;
deleteAndJournal(RpcContext, LockedInodePath, DeleteOptions) - Method in class alluxio.master.file.DefaultFileSystemMaster
Deletes a given path.
deleteBucket(String) - Method in class alluxio.proxy.s3.S3RestServiceHandler
 
DeleteBuffer() - Constructor for class alluxio.underfs.ObjectUnderFileSystem.DeleteBuffer
Construct a new ObjectUnderFileSystem.DeleteBuffer instance.
deleteCompletedLogs() - Method in interface alluxio.master.journalv0.JournalWriter
Deletes all of the completed logs.
deleteCompletedLogs() - Method in class alluxio.master.journalv0.ufs.UfsJournalWriter
 
deleteDirectory(String) - Method in class alluxio.underfs.BaseUnderFileSystem
 
deleteDirectory(String, DeleteOptions) - Method in class alluxio.underfs.hdfs.HdfsUnderFileSystem
 
deleteDirectory(String, DeleteOptions) - Method in class alluxio.underfs.local.LocalUnderFileSystem
 
deleteDirectory(String, DeleteOptions) - Method in class alluxio.underfs.ObjectUnderFileSystem
 
deleteDirectory(String) - Method in interface alluxio.underfs.UnderFileSystem
Deletes a directory from the under file system with the indicated name non-recursively.
deleteDirectory(String, DeleteOptions) - Method in interface alluxio.underfs.UnderFileSystem
Deletes a directory from the under file system with the indicated name.
deleteDirectory(String) - Method in class alluxio.underfs.UnderFileSystemWithLogging
 
deleteDirectory(String, DeleteOptions) - Method in class alluxio.underfs.UnderFileSystemWithLogging
 
deleteDirIfExists(UnderFileSystem, String) - Static method in class alluxio.util.UnderFileSystemUtils
Deletes the directory at the given path if it exists.
deleteFile(String) - Method in class alluxio.underfs.hdfs.HdfsUnderFileSystem
 
deleteFile(String) - Method in class alluxio.underfs.local.LocalUnderFileSystem
 
deleteFile(String) - Method in class alluxio.underfs.ObjectUnderFileSystem
 
deleteFile(String) - Method in interface alluxio.underfs.UnderFileSystem
Deletes a file from the under file system with the indicated name.
deleteFile(String) - Method in class alluxio.underfs.UnderFileSystemWithLogging
 
deleteFileIfExists(UnderFileSystem, String) - Static method in class alluxio.util.UnderFileSystemUtils
Deletes the specified path from the specified under file system if it is a file and exists.
deleteInode(RpcContext, LockedInodePath, long, DeleteOptions) - Method in class alluxio.master.file.meta.InodeTree
Deletes a single inode from the inode tree by removing it from the parent inode.
deleteLeaf(T) - Method in class alluxio.collections.DirectedAcyclicGraph
Deletes a leaf DAG node that carries the given payload.
deleteLineage(long, DeleteLineageOptions) - Method in class alluxio.client.lineage.AbstractLineageClient
 
deleteLineage(long) - Method in class alluxio.client.lineage.AlluxioLineage
Convenience method for AbstractLineageClient.deleteLineage(long, DeleteLineageOptions) with default options.
deleteLineage(long, boolean) - Method in class alluxio.client.lineage.LineageMasterClient
Deletes a lineage.
deleteLineage(long, boolean) - Method in class alluxio.master.lineage.DefaultLineageMaster
 
deleteLineage(long, boolean) - Method in interface alluxio.master.lineage.LineageMaster
Deletes a lineage.
deleteLineage(Long, boolean) - Method in class alluxio.master.lineage.LineageMasterClientRestServiceHandler
Deprecated.
 
deleteLineage(long, boolean, DeleteLineageTOptions) - Method in class alluxio.master.lineage.LineageMasterClientServiceHandler
 
deleteLineage(long) - Method in class alluxio.master.lineage.meta.LineageStore
Deletes a lineage.
deleteLineage(long, boolean, DeleteLineageTOptions, AsyncMethodCallback) - Method in class alluxio.thrift.LineageMasterClientService.AsyncClient
 
deleteLineage(long, boolean, DeleteLineageTOptions, AsyncMethodCallback) - Method in interface alluxio.thrift.LineageMasterClientService.AsyncIface
 
deleteLineage() - Constructor for class alluxio.thrift.LineageMasterClientService.AsyncProcessor.deleteLineage
 
deleteLineage(long, boolean, DeleteLineageTOptions) - Method in class alluxio.thrift.LineageMasterClientService.Client
 
deleteLineage(long, boolean, DeleteLineageTOptions) - Method in interface alluxio.thrift.LineageMasterClientService.Iface
Deletes a lineage and returns whether the deletion succeeded.
deleteLineage() - Constructor for class alluxio.thrift.LineageMasterClientService.Processor.deleteLineage
 
deleteLineage_args() - Constructor for class alluxio.thrift.LineageMasterClientService.deleteLineage_args
 
deleteLineage_args(long, boolean, DeleteLineageTOptions) - Constructor for class alluxio.thrift.LineageMasterClientService.deleteLineage_args
 
deleteLineage_args(LineageMasterClientService.deleteLineage_args) - Constructor for class alluxio.thrift.LineageMasterClientService.deleteLineage_args
Performs a deep copy on other.
deleteLineage_call(long, boolean, DeleteLineageTOptions, AsyncMethodCallback, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class alluxio.thrift.LineageMasterClientService.AsyncClient.deleteLineage_call
 
deleteLineage_result() - Constructor for class alluxio.thrift.LineageMasterClientService.deleteLineage_result
 
deleteLineage_result(DeleteLineageTResponse, AlluxioTException) - Constructor for class alluxio.thrift.LineageMasterClientService.deleteLineage_result
 
deleteLineage_result(LineageMasterClientService.deleteLineage_result) - Constructor for class alluxio.thrift.LineageMasterClientService.deleteLineage_result
Performs a deep copy on other.
DeleteLineageCommand - Class in alluxio.cli.fs.command
Deletes a lineage by its id.
DeleteLineageCommand(FileSystem) - Constructor for class alluxio.cli.fs.command.DeleteLineageCommand
 
DeleteLineageOptions - Class in alluxio.client.lineage.options
The method option for deleting a lineage.
DeleteLineageTOptions - Class in alluxio.thrift
 
DeleteLineageTOptions() - Constructor for class alluxio.thrift.DeleteLineageTOptions
 
DeleteLineageTOptions(DeleteLineageTOptions) - Constructor for class alluxio.thrift.DeleteLineageTOptions
Performs a deep copy on other.
DeleteLineageTOptions._Fields - Enum in alluxio.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
DeleteLineageTResponse - Class in alluxio.thrift
 
DeleteLineageTResponse() - Constructor for class alluxio.thrift.DeleteLineageTResponse
 
DeleteLineageTResponse(boolean) - Constructor for class alluxio.thrift.DeleteLineageTResponse
 
DeleteLineageTResponse(DeleteLineageTResponse) - Constructor for class alluxio.thrift.DeleteLineageTResponse
Performs a deep copy on other.
DeleteLineageTResponse._Fields - Enum in alluxio.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
deleteObject(String) - Method in class alluxio.underfs.cos.COSUnderFileSystem
 
deleteObject(String) - Method in class alluxio.underfs.gcs.GCSUnderFileSystem
 
deleteObject(String) - Method in class alluxio.underfs.ObjectUnderFileSystem
Internal function to delete a key.
deleteObject(String) - Method in class alluxio.underfs.oss.OSSUnderFileSystem
 
deleteObject(String) - Method in class alluxio.underfs.s3a.S3AUnderFileSystem
 
deleteObject(String) - Method in class alluxio.underfs.swift.SwiftUnderFileSystem
 
deleteObjectOrAbortMultipartUpload(String, String, Long) - Method in class alluxio.proxy.s3.S3RestServiceHandler
 
deleteObjects(List<String>) - Method in class alluxio.underfs.ObjectUnderFileSystem
Internal function to delete a list of keys.
deleteObjects(List<String>) - Method in class alluxio.underfs.s3a.S3AUnderFileSystem
 
DeleteOptions - Class in alluxio.client.file.options
Method options for deleting a file.
DeleteOptions - Class in alluxio.master.file.options
Method options for deleting a file or a directory.
DeleteOptions(DeleteTOptions) - Constructor for class alluxio.master.file.options.DeleteOptions
 
DeleteOptions - Class in alluxio.underfs.options
Method options for deleting a directory in UnderFileSystem.
deletePathRecursively(String) - Static method in class alluxio.util.io.FileUtils
Deletes a file or a directory, recursively if it is a directory.
deleteStore(AlluxioURI) - Method in class alluxio.client.keyvalue.BaseKeyValueSystem
 
deleteStore(AlluxioURI) - Method in class alluxio.client.keyvalue.KeyValueMasterClient
Deletes a completed key-value store.
deleteStore(AlluxioURI) - Method in interface alluxio.client.keyvalue.KeyValueSystem
Deletes a completed key-value store.
deleteStore(AlluxioURI) - Method in class alluxio.master.keyvalue.DefaultKeyValueMaster
 
deleteStore(AlluxioURI) - Method in interface alluxio.master.keyvalue.KeyValueMaster
Deletes a completed key-value store.
deleteStore(String, DeleteStoreTOptions) - Method in class alluxio.master.keyvalue.KeyValueMasterClientServiceHandler
 
deleteStore(String, DeleteStoreTOptions, AsyncMethodCallback) - Method in class alluxio.thrift.KeyValueMasterClientService.AsyncClient
 
deleteStore(String, DeleteStoreTOptions, AsyncMethodCallback) - Method in interface alluxio.thrift.KeyValueMasterClientService.AsyncIface
 
deleteStore() - Constructor for class alluxio.thrift.KeyValueMasterClientService.AsyncProcessor.deleteStore
 
deleteStore(String, DeleteStoreTOptions) - Method in class alluxio.thrift.KeyValueMasterClientService.Client
 
deleteStore(String, DeleteStoreTOptions) - Method in interface alluxio.thrift.KeyValueMasterClientService.Iface
Deletes a completed key-value store.
deleteStore() - Constructor for class alluxio.thrift.KeyValueMasterClientService.Processor.deleteStore
 
deleteStore_args() - Constructor for class alluxio.thrift.KeyValueMasterClientService.deleteStore_args
 
deleteStore_args(String, DeleteStoreTOptions) - Constructor for class alluxio.thrift.KeyValueMasterClientService.deleteStore_args
 
deleteStore_args(KeyValueMasterClientService.deleteStore_args) - Constructor for class alluxio.thrift.KeyValueMasterClientService.deleteStore_args
Performs a deep copy on other.
deleteStore_call(String, DeleteStoreTOptions, AsyncMethodCallback, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class alluxio.thrift.KeyValueMasterClientService.AsyncClient.deleteStore_call
 
deleteStore_result() - Constructor for class alluxio.thrift.KeyValueMasterClientService.deleteStore_result
 
deleteStore_result(DeleteStoreTResponse, AlluxioTException) - Constructor for class alluxio.thrift.KeyValueMasterClientService.deleteStore_result
 
deleteStore_result(KeyValueMasterClientService.deleteStore_result) - Constructor for class alluxio.thrift.KeyValueMasterClientService.deleteStore_result
Performs a deep copy on other.
DeleteStoreTOptions - Class in alluxio.thrift
 
DeleteStoreTOptions() - Constructor for class alluxio.thrift.DeleteStoreTOptions
 
DeleteStoreTOptions(DeleteStoreTOptions) - Constructor for class alluxio.thrift.DeleteStoreTOptions
Performs a deep copy on other.
DeleteStoreTOptions._Fields - Enum in alluxio.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
DeleteStoreTResponse - Class in alluxio.thrift
 
DeleteStoreTResponse() - Constructor for class alluxio.thrift.DeleteStoreTResponse
 
DeleteStoreTResponse(DeleteStoreTResponse) - Constructor for class alluxio.thrift.DeleteStoreTResponse
Performs a deep copy on other.
DeleteStoreTResponse._Fields - Enum in alluxio.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
DeleteThread(List<String>) - Constructor for class alluxio.underfs.ObjectUnderFileSystem.DeleteBuffer.DeleteThread
Delete a batch of objects.
DeleteTOptions - Class in alluxio.thrift
 
DeleteTOptions() - Constructor for class alluxio.thrift.DeleteTOptions
 
DeleteTOptions(DeleteTOptions) - Constructor for class alluxio.thrift.DeleteTOptions
Performs a deep copy on other.
DeleteTOptions._Fields - Enum in alluxio.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
DeleteTResponse - Class in alluxio.thrift
 
DeleteTResponse() - Constructor for class alluxio.thrift.DeleteTResponse
 
DeleteTResponse(DeleteTResponse) - Constructor for class alluxio.thrift.DeleteTResponse
Performs a deep copy on other.
DeleteTResponse._Fields - Enum in alluxio.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
DependencyDoesNotExistException - Exception in alluxio.exception
The exception thrown when a dependency does not exist in Alluxio.
DependencyDoesNotExistException(String) - Constructor for exception alluxio.exception.DependencyDoesNotExistException
Constructs a new exception with the specified detail message.
DependencyDoesNotExistException(String, Throwable) - Constructor for exception alluxio.exception.DependencyDoesNotExistException
Constructs a new exception with the specified detail message and cause.
DependencyDoesNotExistException(ExceptionMessage, Object...) - Constructor for exception alluxio.exception.DependencyDoesNotExistException
Constructs a new exception with the specified exception message and multiple parameters.
DependencyDoesNotExistException(ExceptionMessage, Throwable, Object...) - Constructor for exception alluxio.exception.DependencyDoesNotExistException
Constructs a new exception with the specified exception message, the cause and multiple parameters.
DependencyInfo - Class in alluxio.thrift
 
DependencyInfo() - Constructor for class alluxio.thrift.DependencyInfo
 
DependencyInfo(DependencyInfo) - Constructor for class alluxio.thrift.DependencyInfo
Performs a deep copy on other.
DependencyInfo._Fields - Enum in alluxio.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
DescendantType - Enum in alluxio.master.file.options
Type of descendant level processing for filesystem inodes.
description() - Static method in class alluxio.cli.fsadmin.command.DoctorCommand
 
description() - Static method in class alluxio.cli.fsadmin.command.ReportCommand
 
deserialize(InputStream) - Method in interface alluxio.master.journalv0.JournalFormatter
Returns a JournalInputStream from the given input stream.
deserialize(InputStream) - Method in class alluxio.master.journalv0.ProtoBufJournalFormatter
 
destroy() - Method in class alluxio.multi.process.MultiProcessCluster
Destroys the cluster.
DeterministicHashPolicy - Class in alluxio.client.block.policy
This policy maps blockId to several deterministic Alluxio workers.
DeterministicHashPolicy() - Constructor for class alluxio.client.block.policy.DeterministicHashPolicy
Constructs a new DeterministicHashPolicy.
DeterministicHashPolicy(Integer) - Constructor for class alluxio.client.block.policy.DeterministicHashPolicy
Constructs a new DeterministicHashPolicy.
dir() - Method in class alluxio.worker.block.BlockStoreLocation
Gets the directory index of the location.
DIRECT_CHILDREN_LOADED_FIELD_NUMBER - Static variable in class alluxio.proto.journal.File.InodeDirectoryEntry
 
DirectedAcyclicGraph<T> - Class in alluxio.collections
A Directed Acyclic Graph (DAG).
DirectedAcyclicGraph() - Constructor for class alluxio.collections.DirectedAcyclicGraph
A Directed Acyclic Graph (DAG).
DirectedAcyclicGraphNode<T> - Class in alluxio.collections
A Directed Acyclic Graph (DAG) node.
DirectedAcyclicGraphNode(T, List<DirectedAcyclicGraphNode<T>>, List<DirectedAcyclicGraphNode<T>>) - Constructor for class alluxio.collections.DirectedAcyclicGraphNode
A Directed Acyclic Graph (DAG) node.
DirectedAcyclicGraphNode(T) - Constructor for class alluxio.collections.DirectedAcyclicGraphNode
A Directed Acyclic Graph (DAG) node.
DIRECTORIES_CREATED - Static variable in class alluxio.metrics.MasterMetrics
 
DirectoryNotEmptyException - Exception in alluxio.exception
Exception for situations where an operation fails because a directory is not empty.
DirectoryNotEmptyException(String) - Constructor for exception alluxio.exception.DirectoryNotEmptyException
Constructs a new exception with the specified detail message.
DirectoryNotEmptyException(String, Throwable) - Constructor for exception alluxio.exception.DirectoryNotEmptyException
Constructs a new exception with the specified detail message and cause.
DirectoryNotEmptyException(ExceptionMessage, Object...) - Constructor for exception alluxio.exception.DirectoryNotEmptyException
Constructs a new exception with the specified exception message and multiple parameters.
DirectoryNotEmptyException(ExceptionMessage, Throwable, Object...) - Constructor for exception alluxio.exception.DirectoryNotEmptyException
Constructs a new exception with the specified exception message, the cause and multiple parameters.
disableAutoRead(Channel) - Static method in class alluxio.util.network.NettyUtils
Disables auto read for a netty channel.
disabled() - Static method in class alluxio.master.file.StartupConsistencyCheck
 
disconnect() - Method in class alluxio.AbstractClient
Closes the connection with the Alluxio remote and does the necessary cleanup.
disconnect() - Method in interface alluxio.Client
Closes the connection with the Alluxio remote and does the necessary cleanup.
dispose() - Method in class alluxio.security.authentication.PlainSaslServer
 
DoctorCommand - Class in alluxio.cli.fsadmin.command
Shows errors or warnings that users should pay attention to.
DoctorCommand(Context) - Constructor for class alluxio.cli.fsadmin.command.DoctorCommand
 
doGet(HttpServletRequest, HttpServletResponse) - Method in class alluxio.web.WebInterfaceBrowseLogsServlet
Populates attribute fields with data from the MasterInfo associated with this servlet.
doGet(HttpServletRequest, HttpServletResponse) - Method in class alluxio.web.WebInterfaceBrowseServlet
Populates attribute fields with data from the MasterInfo associated with this servlet.
doGet(HttpServletRequest, HttpServletResponse) - Method in class alluxio.web.WebInterfaceConfigurationServlet
Populates attributes before redirecting to a jsp.
doGet(HttpServletRequest, HttpServletResponse) - Method in class alluxio.web.WebInterfaceDependencyServlet
 
doGet(HttpServletRequest, HttpServletResponse) - Method in class alluxio.web.WebInterfaceDownloadLocalServlet
Prepares for downloading a file.
doGet(HttpServletRequest, HttpServletResponse) - Method in class alluxio.web.WebInterfaceDownloadServlet
Prepares for downloading a file.
doGet(HttpServletRequest, HttpServletResponse) - Method in class alluxio.web.WebInterfaceGeneralServlet
Redirects the request to a JSP after populating attributes via populateValues.
doGet(HttpServletRequest, HttpServletResponse) - Method in class alluxio.web.WebInterfaceHeaderServlet
Populate the header with information about master.
doGet(HttpServletRequest, HttpServletResponse) - Method in class alluxio.web.WebInterfaceMasterMetricsServlet
Redirects the request to a JSP after populating attributes via populateValues.
doGet(HttpServletRequest, HttpServletResponse) - Method in class alluxio.web.WebInterfaceMemoryServlet
Populates attributes before redirecting to a jsp.
doGet(HttpServletRequest, HttpServletResponse) - Method in class alluxio.web.WebInterfaceWorkerBlockInfoServlet
Populates attributes before redirecting to a jsp.
doGet(HttpServletRequest, HttpServletResponse) - Method in class alluxio.web.WebInterfaceWorkerGeneralServlet
 
doGet(HttpServletRequest, HttpServletResponse) - Method in class alluxio.web.WebInterfaceWorkerMetricsServlet
Redirects the request to a JSP after populating attributes via populateValues.
doGet(HttpServletRequest, HttpServletResponse) - Method in class alluxio.web.WebInterfaceWorkersServlet
Populates attributes before redirecting to a jsp.
doPost(HttpServletRequest, HttpServletResponse) - Method in class alluxio.web.WebInterfaceDependencyServlet
 
doPost(HttpServletRequest, HttpServletResponse) - Method in class alluxio.web.WebInterfaceGeneralServlet
 
doPost(HttpServletRequest, HttpServletResponse) - Method in class alluxio.web.WebInterfaceMasterMetricsServlet
 
doPost(HttpServletRequest, HttpServletResponse) - Method in class alluxio.web.WebInterfaceWorkerMetricsServlet
 
downgradeLast() - Method in class alluxio.master.file.meta.InodeLockList
Downgrades the last inode that was locked, if the inode was previously WRITE locked.
downgradeLast() - Method in class alluxio.master.file.meta.LockedInodePath
Downgrades the last inode that was locked, if the inode was previously WRITE locked.
downgradeLastWithScheme(LockingScheme) - Method in class alluxio.master.file.meta.LockedInodePath
Downgrades the last inode that was locked, according to the specified LockingScheme.
dropReference() - Method in class alluxio.worker.block.ClientRWLock
Decrements the reference count.
DST_PATH_FIELD_NUMBER - Static variable in class alluxio.proto.journal.File.RenameEntry
 
DuCommand - Class in alluxio.cli.fs.command
Displays the size of a file or a directory specified by argv.
DuCommand(FileSystem) - Constructor for class alluxio.cli.fs.command.DuCommand
 
DummyFileOutputStream - Class in alluxio.client.lineage
A dummy file output stream that does nothing.
DummyFileOutputStream(AlluxioURI, OutStreamOptions) - Constructor for class alluxio.client.lineage.DummyFileOutputStream
Constructs a new dummy file output stream.
DynamicResourcePool<T> - Class in alluxio.resource
A dynamic pool that manages the resources.
DynamicResourcePool(DynamicResourcePool.Options) - Constructor for class alluxio.resource.DynamicResourcePool
Creates a dynamic pool instance.
DynamicResourcePool.Options - Class in alluxio.resource
Options to initialize a Dynamic resource pool.
DynamicResourcePool.ResourceInternal<R> - Class in alluxio.resource
A wrapper on the resource to include the last time at which it was used.

E

ElapsedTimeClock - Class in alluxio.clock
A monotonically increasing clock for calculating elapsed time.
ElapsedTimeClock() - Constructor for class alluxio.clock.ElapsedTimeClock
 
EMPTY_URI - Static variable in class alluxio.AlluxioURI
 
enableAutoRead(Channel) - Static method in class alluxio.util.network.NettyUtils
Enables auto read for a netty channel.
encode(ByteBuf) - Method in interface alluxio.network.protocol.EncodedMessage
Encodes the message to the output ByteBuf.
encode(ByteBuf) - Method in enum alluxio.network.protocol.RPCMessage.Type
 
encode(ChannelHandlerContext, RPCMessage, List<Object>) - Method in class alluxio.network.protocol.RPCMessageEncoder
 
encode(ByteBuf) - Method in class alluxio.network.protocol.RPCProtoMessage
 
EncodedMessage - Interface in alluxio.network.protocol
Represents an encoded message.
ensureFullInodePath(LockedInodePath, InodeTree.LockMode) - Method in class alluxio.master.file.meta.InodeTree
Attempts to extend an existing LockedInodePath to reach the target inode (the last inode for the full path).
EntryOutputStream(UnderFileSystem, URI, JournalFormatter, UfsJournalWriter) - Constructor for class alluxio.master.journalv0.ufs.UfsJournalWriter.EntryOutputStream
 
entrySet() - Method in class alluxio.conf.AlluxioProperties
 
enumForId(short) - Method in class alluxio.thrift.FileSystemCommandOptions
 
EOF_FIELD_NUMBER - Static variable in class alluxio.proto.dataserver.Protocol.WriteRequest
 
equalConstantByteArray(byte, int, byte[]) - Static method in class alluxio.util.io.BufferUtils
Checks if the given byte array starts with a constant sequence of bytes of the given value and length.
equalIncreasingByteArray(int, byte[]) - Static method in class alluxio.util.io.BufferUtils
Checks if the given byte array starts with an increasing sequence of bytes of the given length, starting from 0.
equalIncreasingByteArray(int, int, byte[]) - Static method in class alluxio.util.io.BufferUtils
Checks if the given byte array starts with an increasing sequence of bytes of the given length, starting from the given value.
equalIncreasingByteBuffer(int, int, ByteBuffer) - Static method in class alluxio.util.io.BufferUtils
Checks if the given ByteBuffer starts with an increasing sequence of bytes starting at the given value of length equal to or greater than the given length.
equals(Object) - Method in class alluxio.AlluxioURI
 
equals(Object) - Method in class alluxio.client.block.options.GetWorkerReportOptions
 
equals(Object) - Method in class alluxio.client.block.options.LockBlockOptions
 
equals(Object) - Method in class alluxio.client.block.policy.DeterministicHashPolicy
 
equals(Object) - Method in class alluxio.client.block.policy.options.CreateOptions
 
equals(Object) - Method in class alluxio.client.block.policy.options.GetWorkerOptions
 
equals(Object) - Method in class alluxio.client.file.options.CancelUfsFileOptions
 
equals(Object) - Method in class alluxio.client.file.options.CheckConsistencyOptions
 
equals(Object) - Method in class alluxio.client.file.options.CloseUfsFileOptions
 
equals(Object) - Method in class alluxio.client.file.options.CompleteFileOptions
 
equals(Object) - Method in class alluxio.client.file.options.CompleteUfsFileOptions
 
equals(Object) - Method in class alluxio.client.file.options.CreateDirectoryOptions
 
equals(Object) - Method in class alluxio.client.file.options.CreateFileOptions
 
equals(Object) - Method in class alluxio.client.file.options.CreateUfsFileOptions
 
equals(Object) - Method in class alluxio.client.file.options.DeleteOptions
 
equals(Object) - Method in class alluxio.client.file.options.ExistsOptions
 
equals(Object) - Method in class alluxio.client.file.options.FreeOptions
 
equals(Object) - Method in class alluxio.client.file.options.GetStatusOptions
 
equals(Object) - Method in class alluxio.client.file.options.InStreamOptions
 
equals(Object) - Method in class alluxio.client.file.options.ListStatusOptions
 
equals(Object) - Method in class alluxio.client.file.options.LoadMetadataOptions
Deprecated.
 
equals(Object) - Method in class alluxio.client.file.options.MountOptions
 
equals(Object) - Method in class alluxio.client.file.options.OpenFileOptions
 
equals(Object) - Method in class alluxio.client.file.options.OpenUfsFileOptions
 
equals(Object) - Method in class alluxio.client.file.options.OutStreamOptions
 
equals(Object) - Method in class alluxio.client.file.options.RenameOptions
 
equals(Object) - Method in class alluxio.client.file.options.SetAttributeOptions
 
equals(Object) - Method in class alluxio.client.file.options.UnmountOptions
 
equals(Object) - Method in class alluxio.client.file.options.UpdateUfsModeOptions
 
equals(Object) - Method in class alluxio.client.file.policy.LocalFirstAvoidEvictionPolicy
 
equals(Object) - Method in class alluxio.client.file.policy.LocalFirstPolicy
 
equals(Object) - Method in class alluxio.client.file.policy.MostAvailableFirstPolicy
 
equals(Object) - Method in class alluxio.client.file.policy.RoundRobinPolicy
 
equals(Object) - Method in class alluxio.client.file.policy.SpecificHostPolicy
 
equals(Object) - Method in class alluxio.client.file.URIStatus
 
equals(Object) - Method in class alluxio.client.keyvalue.KeyValuePair
Tells whether or not this key-value pair is equal to another object.
equals(Object) - Method in class alluxio.client.lineage.options.CreateLineageOptions
 
equals(Object) - Method in class alluxio.client.lineage.options.DeleteLineageOptions
 
equals(Object) - Method in class alluxio.client.lineage.options.GetLineageInfoListOptions
 
equals(Object) - Method in class alluxio.collections.Pair
 
equals(Object) - Method in class alluxio.master.block.meta.MasterBlockLocation
 
equals(Object) - Method in class alluxio.master.file.meta.Inode
 
equals(Object) - Method in class alluxio.master.file.meta.InodeTree
 
equals(Object) - Method in class alluxio.master.file.meta.options.MountInfo
 
equals(Object) - Method in class alluxio.master.file.meta.TtlBucket
Compares to a specific object.
equals(Object) - Method in class alluxio.master.file.options.CheckConsistencyOptions
 
equals(Object) - Method in class alluxio.master.file.options.CompleteFileOptions
 
equals(Object) - Method in class alluxio.master.file.options.CreateDirectoryOptions
 
equals(Object) - Method in class alluxio.master.file.options.CreateFileOptions
 
equals(Object) - Method in class alluxio.master.file.options.CreatePathOptions
 
equals(Object) - Method in class alluxio.master.file.options.DeleteOptions
 
equals(Object) - Method in class alluxio.master.file.options.FreeOptions
 
equals(Object) - Method in class alluxio.master.file.options.GetStatusOptions
 
equals(Object) - Method in class alluxio.master.file.options.ListStatusOptions
 
equals(Object) - Method in class alluxio.master.file.options.LoadMetadataOptions
 
equals(Object) - Method in class alluxio.master.file.options.MountOptions
 
equals(Object) - Method in class alluxio.master.file.options.RenameOptions
 
equals(Object) - Method in class alluxio.master.file.options.SetAttributeOptions
 
equals(Object) - Method in class alluxio.master.file.options.SyncMetadataOptions
 
equals(Object) - Method in class alluxio.master.file.options.WorkerHeartbeatOptions
 
equals(Object) - Method in class alluxio.master.journal.options.JournalReaderOptions
 
equals(Object) - Method in class alluxio.master.journal.options.JournalWriterOptions
 
equals(Object) - Method in class alluxio.master.PollingMasterInquireClient.MultiMasterConnectDetails
 
equals(Object) - Method in class alluxio.master.SingleMasterInquireClient.SingleMasterConnectDetails
 
equals(Object) - Method in class alluxio.master.ZkMasterInquireClient.ZkMasterConnectDetails
 
equals(Object) - Method in class alluxio.metrics.Metric
 
equals(Object) - Method in class alluxio.metrics.MetricsFilter
 
equals(Object) - Method in class alluxio.PropertyKey
 
equals(Object) - Method in class alluxio.proxy.s3.ListBucketOptions
 
equals(Object) - Method in class alluxio.security.authorization.Mode
 
equals(Object) - Method in class alluxio.security.User
 
equals(Object) - Method in class alluxio.SessionInfo
 
equals(Object) - Method in class alluxio.StandardURI
 
equals(Object) - Method in class alluxio.thrift.AccessBlockTOptions
 
equals(AccessBlockTOptions) - Method in class alluxio.thrift.AccessBlockTOptions
 
equals(Object) - Method in class alluxio.thrift.AccessBlockTResponse
 
equals(AccessBlockTResponse) - Method in class alluxio.thrift.AccessBlockTResponse
 
equals(Object) - Method in class alluxio.thrift.AlluxioService.getServiceVersion_args
 
equals(AlluxioService.getServiceVersion_args) - Method in class alluxio.thrift.AlluxioService.getServiceVersion_args
 
equals(Object) - Method in class alluxio.thrift.AlluxioService.getServiceVersion_result
 
equals(AlluxioService.getServiceVersion_result) - Method in class alluxio.thrift.AlluxioService.getServiceVersion_result
 
equals(Object) - Method in exception alluxio.thrift.AlluxioTException
 
equals(AlluxioTException) - Method in exception alluxio.thrift.AlluxioTException
 
equals(Object) - Method in class alluxio.thrift.BackupTOptions
 
equals(BackupTOptions) - Method in class alluxio.thrift.BackupTOptions
 
equals(Object) - Method in class alluxio.thrift.BackupTResponse
 
equals(BackupTResponse) - Method in class alluxio.thrift.BackupTResponse
 
equals(Object) - Method in class alluxio.thrift.BlockHeartbeatTOptions
 
equals(BlockHeartbeatTOptions) - Method in class alluxio.thrift.BlockHeartbeatTOptions
 
equals(Object) - Method in class alluxio.thrift.BlockHeartbeatTResponse
 
equals(BlockHeartbeatTResponse) - Method in class alluxio.thrift.BlockHeartbeatTResponse
 
equals(Object) - Method in class alluxio.thrift.BlockInfo
 
equals(BlockInfo) - Method in class alluxio.thrift.BlockInfo
 
equals(Object) - Method in class alluxio.thrift.BlockLocation
 
equals(BlockLocation) - Method in class alluxio.thrift.BlockLocation
 
equals(Object) - Method in class alluxio.thrift.BlockMasterClientService.getBlockInfo_args
 
equals(BlockMasterClientService.getBlockInfo_args) - Method in class alluxio.thrift.BlockMasterClientService.getBlockInfo_args
 
equals(Object) - Method in class alluxio.thrift.BlockMasterClientService.getBlockInfo_result
 
equals(BlockMasterClientService.getBlockInfo_result) - Method in class alluxio.thrift.BlockMasterClientService.getBlockInfo_result
 
equals(Object) - Method in class alluxio.thrift.BlockMasterClientService.getBlockMasterInfo_args
 
equals(BlockMasterClientService.getBlockMasterInfo_args) - Method in class alluxio.thrift.BlockMasterClientService.getBlockMasterInfo_args
 
equals(Object) - Method in class alluxio.thrift.BlockMasterClientService.getBlockMasterInfo_result
 
equals(BlockMasterClientService.getBlockMasterInfo_result) - Method in class alluxio.thrift.BlockMasterClientService.getBlockMasterInfo_result
 
equals(Object) - Method in class alluxio.thrift.BlockMasterClientService.getCapacityBytes_args
 
equals(BlockMasterClientService.getCapacityBytes_args) - Method in class alluxio.thrift.BlockMasterClientService.getCapacityBytes_args
 
equals(Object) - Method in class alluxio.thrift.BlockMasterClientService.getCapacityBytes_result
 
equals(BlockMasterClientService.getCapacityBytes_result) - Method in class alluxio.thrift.BlockMasterClientService.getCapacityBytes_result
 
equals(Object) - Method in class alluxio.thrift.BlockMasterClientService.getUsedBytes_args
 
equals(BlockMasterClientService.getUsedBytes_args) - Method in class alluxio.thrift.BlockMasterClientService.getUsedBytes_args
 
equals(Object) - Method in class alluxio.thrift.BlockMasterClientService.getUsedBytes_result
 
equals(BlockMasterClientService.getUsedBytes_result) - Method in class alluxio.thrift.BlockMasterClientService.getUsedBytes_result
 
equals(Object) - Method in class alluxio.thrift.BlockMasterClientService.getWorkerInfoList_args
 
equals(BlockMasterClientService.getWorkerInfoList_args) - Method in class alluxio.thrift.BlockMasterClientService.getWorkerInfoList_args
 
equals(Object) - Method in class alluxio.thrift.BlockMasterClientService.getWorkerInfoList_result
 
equals(BlockMasterClientService.getWorkerInfoList_result) - Method in class alluxio.thrift.BlockMasterClientService.getWorkerInfoList_result
 
equals(Object) - Method in class alluxio.thrift.BlockMasterClientService.getWorkerReport_args
 
equals(BlockMasterClientService.getWorkerReport_args) - Method in class alluxio.thrift.BlockMasterClientService.getWorkerReport_args
 
equals(Object) - Method in class alluxio.thrift.BlockMasterClientService.getWorkerReport_result
 
equals(BlockMasterClientService.getWorkerReport_result) - Method in class alluxio.thrift.BlockMasterClientService.getWorkerReport_result
 
equals(Object) - Method in class alluxio.thrift.BlockMasterInfo
 
equals(BlockMasterInfo) - Method in class alluxio.thrift.BlockMasterInfo
 
equals(Object) - Method in class alluxio.thrift.BlockMasterWorkerService.blockHeartbeat_args
 
equals(BlockMasterWorkerService.blockHeartbeat_args) - Method in class alluxio.thrift.BlockMasterWorkerService.blockHeartbeat_args
 
equals(Object) - Method in class alluxio.thrift.BlockMasterWorkerService.blockHeartbeat_result
 
equals(BlockMasterWorkerService.blockHeartbeat_result) - Method in class alluxio.thrift.BlockMasterWorkerService.blockHeartbeat_result
 
equals(Object) - Method in class alluxio.thrift.BlockMasterWorkerService.commitBlock_args
 
equals(BlockMasterWorkerService.commitBlock_args) - Method in class alluxio.thrift.BlockMasterWorkerService.commitBlock_args
 
equals(Object) - Method in class alluxio.thrift.BlockMasterWorkerService.commitBlock_result
 
equals(BlockMasterWorkerService.commitBlock_result) - Method in class alluxio.thrift.BlockMasterWorkerService.commitBlock_result
 
equals(Object) - Method in class alluxio.thrift.BlockMasterWorkerService.getWorkerId_args
 
equals(BlockMasterWorkerService.getWorkerId_args) - Method in class alluxio.thrift.BlockMasterWorkerService.getWorkerId_args
 
equals(Object) - Method in class alluxio.thrift.BlockMasterWorkerService.getWorkerId_result
 
equals(BlockMasterWorkerService.getWorkerId_result) - Method in class alluxio.thrift.BlockMasterWorkerService.getWorkerId_result
 
equals(Object) - Method in class alluxio.thrift.BlockMasterWorkerService.registerWorker_args
 
equals(BlockMasterWorkerService.registerWorker_args) - Method in class alluxio.thrift.BlockMasterWorkerService.registerWorker_args
 
equals(Object) - Method in class alluxio.thrift.BlockMasterWorkerService.registerWorker_result
 
equals(BlockMasterWorkerService.registerWorker_result) - Method in class alluxio.thrift.BlockMasterWorkerService.registerWorker_result
 
equals(Object) - Method in class alluxio.thrift.BlockWorkerClientService.accessBlock_args
 
equals(BlockWorkerClientService.accessBlock_args) - Method in class alluxio.thrift.BlockWorkerClientService.accessBlock_args
 
equals(Object) - Method in class alluxio.thrift.BlockWorkerClientService.accessBlock_result
 
equals(BlockWorkerClientService.accessBlock_result) - Method in class alluxio.thrift.BlockWorkerClientService.accessBlock_result
 
equals(Object) - Method in class alluxio.thrift.BlockWorkerClientService.cacheBlock_args
 
equals(BlockWorkerClientService.cacheBlock_args) - Method in class alluxio.thrift.BlockWorkerClientService.cacheBlock_args
 
equals(Object) - Method in class alluxio.thrift.BlockWorkerClientService.cacheBlock_result
 
equals(BlockWorkerClientService.cacheBlock_result) - Method in class alluxio.thrift.BlockWorkerClientService.cacheBlock_result
 
equals(Object) - Method in class alluxio.thrift.BlockWorkerClientService.cancelBlock_args
 
equals(BlockWorkerClientService.cancelBlock_args) - Method in class alluxio.thrift.BlockWorkerClientService.cancelBlock_args
 
equals(Object) - Method in class alluxio.thrift.BlockWorkerClientService.cancelBlock_result
 
equals(BlockWorkerClientService.cancelBlock_result) - Method in class alluxio.thrift.BlockWorkerClientService.cancelBlock_result
 
equals(Object) - Method in class alluxio.thrift.BlockWorkerClientService.lockBlock_args
 
equals(BlockWorkerClientService.lockBlock_args) - Method in class alluxio.thrift.BlockWorkerClientService.lockBlock_args
 
equals(Object) - Method in class alluxio.thrift.BlockWorkerClientService.lockBlock_result
 
equals(BlockWorkerClientService.lockBlock_result) - Method in class alluxio.thrift.BlockWorkerClientService.lockBlock_result
 
equals(Object) - Method in class alluxio.thrift.BlockWorkerClientService.promoteBlock_args
 
equals(BlockWorkerClientService.promoteBlock_args) - Method in class alluxio.thrift.BlockWorkerClientService.promoteBlock_args
 
equals(Object) - Method in class alluxio.thrift.BlockWorkerClientService.promoteBlock_result
 
equals(BlockWorkerClientService.promoteBlock_result) - Method in class alluxio.thrift.BlockWorkerClientService.promoteBlock_result
 
equals(Object) - Method in class alluxio.thrift.BlockWorkerClientService.removeBlock_args
 
equals(BlockWorkerClientService.removeBlock_args) - Method in class alluxio.thrift.BlockWorkerClientService.removeBlock_args
 
equals(Object) - Method in class alluxio.thrift.BlockWorkerClientService.removeBlock_result
 
equals(BlockWorkerClientService.removeBlock_result) - Method in class alluxio.thrift.BlockWorkerClientService.removeBlock_result
 
equals(Object) - Method in class alluxio.thrift.BlockWorkerClientService.requestBlockLocation_args
 
equals(BlockWorkerClientService.requestBlockLocation_args) - Method in class alluxio.thrift.BlockWorkerClientService.requestBlockLocation_args
 
equals(Object) - Method in class alluxio.thrift.BlockWorkerClientService.requestBlockLocation_result
 
equals(BlockWorkerClientService.requestBlockLocation_result) - Method in class alluxio.thrift.BlockWorkerClientService.requestBlockLocation_result
 
equals(Object) - Method in class alluxio.thrift.BlockWorkerClientService.requestSpace_args
 
equals(BlockWorkerClientService.requestSpace_args) - Method in class alluxio.thrift.BlockWorkerClientService.requestSpace_args
 
equals(Object) - Method in class alluxio.thrift.BlockWorkerClientService.requestSpace_result
 
equals(BlockWorkerClientService.requestSpace_result) - Method in class alluxio.thrift.BlockWorkerClientService.requestSpace_result
 
equals(Object) - Method in class alluxio.thrift.BlockWorkerClientService.sessionBlockHeartbeat_args
 
equals(BlockWorkerClientService.sessionBlockHeartbeat_args) - Method in class alluxio.thrift.BlockWorkerClientService.sessionBlockHeartbeat_args
 
equals(Object) - Method in class alluxio.thrift.BlockWorkerClientService.sessionBlockHeartbeat_result
 
equals(BlockWorkerClientService.sessionBlockHeartbeat_result) - Method in class alluxio.thrift.BlockWorkerClientService.sessionBlockHeartbeat_result
 
equals(Object) - Method in class alluxio.thrift.BlockWorkerClientService.unlockBlock_args
 
equals(BlockWorkerClientService.unlockBlock_args) - Method in class alluxio.thrift.BlockWorkerClientService.unlockBlock_args
 
equals(Object) - Method in class alluxio.thrift.BlockWorkerClientService.unlockBlock_result
 
equals(BlockWorkerClientService.unlockBlock_result) - Method in class alluxio.thrift.BlockWorkerClientService.unlockBlock_result
 
equals(Object) - Method in class alluxio.thrift.CacheBlockTOptions
 
equals(CacheBlockTOptions) - Method in class alluxio.thrift.CacheBlockTOptions
 
equals(Object) - Method in class alluxio.thrift.CacheBlockTResponse
 
equals(CacheBlockTResponse) - Method in class alluxio.thrift.CacheBlockTResponse
 
equals(Object) - Method in class alluxio.thrift.CancelBlockTOptions
 
equals(CancelBlockTOptions) - Method in class alluxio.thrift.CancelBlockTOptions
 
equals(Object) - Method in class alluxio.thrift.CancelBlockTResponse
 
equals(CancelBlockTResponse) - Method in class alluxio.thrift.CancelBlockTResponse
 
equals(Object) - Method in class alluxio.thrift.CancelUfsFileTOptions
 
equals(CancelUfsFileTOptions) - Method in class alluxio.thrift.CancelUfsFileTOptions
 
equals(Object) - Method in class alluxio.thrift.CancelUfsFileTResponse
 
equals(CancelUfsFileTResponse) - Method in class alluxio.thrift.CancelUfsFileTResponse
 
equals(Object) - Method in class alluxio.thrift.CheckConsistencyTOptions
 
equals(CheckConsistencyTOptions) - Method in class alluxio.thrift.CheckConsistencyTOptions
 
equals(Object) - Method in class alluxio.thrift.CheckConsistencyTResponse
 
equals(CheckConsistencyTResponse) - Method in class alluxio.thrift.CheckConsistencyTResponse
 
equals(Object) - Method in class alluxio.thrift.CloseUfsFileTOptions
 
equals(CloseUfsFileTOptions) - Method in class alluxio.thrift.CloseUfsFileTOptions
 
equals(Object) - Method in class alluxio.thrift.CloseUfsFileTResponse
 
equals(CloseUfsFileTResponse) - Method in class alluxio.thrift.CloseUfsFileTResponse
 
equals(Object) - Method in class alluxio.thrift.Command
 
equals(Command) - Method in class alluxio.thrift.Command
 
equals(Object) - Method in class alluxio.thrift.CommandLineJobInfo
 
equals(CommandLineJobInfo) - Method in class alluxio.thrift.CommandLineJobInfo
 
equals(Object) - Method in class alluxio.thrift.CommitBlockTOptions
 
equals(CommitBlockTOptions) - Method in class alluxio.thrift.CommitBlockTOptions
 
equals(Object) - Method in class alluxio.thrift.CommitBlockTResponse
 
equals(CommitBlockTResponse) - Method in class alluxio.thrift.CommitBlockTResponse
 
equals(Object) - Method in class alluxio.thrift.CompleteFileTOptions
 
equals(CompleteFileTOptions) - Method in class alluxio.thrift.CompleteFileTOptions
 
equals(Object) - Method in class alluxio.thrift.CompleteFileTResponse
 
equals(CompleteFileTResponse) - Method in class alluxio.thrift.CompleteFileTResponse
 
equals(Object) - Method in class alluxio.thrift.CompletePartitionTOptions
 
equals(CompletePartitionTOptions) - Method in class alluxio.thrift.CompletePartitionTOptions
 
equals(Object) - Method in class alluxio.thrift.CompletePartitionTResponse
 
equals(CompletePartitionTResponse) - Method in class alluxio.thrift.CompletePartitionTResponse
 
equals(Object) - Method in class alluxio.thrift.CompleteStoreTOptions
 
equals(CompleteStoreTOptions) - Method in class alluxio.thrift.CompleteStoreTOptions
 
equals(Object) - Method in class alluxio.thrift.CompleteStoreTResponse
 
equals(CompleteStoreTResponse) - Method in class alluxio.thrift.CompleteStoreTResponse
 
equals(Object) - Method in class alluxio.thrift.CompleteUfsFileTOptions
 
equals(CompleteUfsFileTOptions) - Method in class alluxio.thrift.CompleteUfsFileTOptions
 
equals(Object) - Method in class alluxio.thrift.CompleteUfsFileTReponse
 
equals(CompleteUfsFileTReponse) - Method in class alluxio.thrift.CompleteUfsFileTReponse
 
equals(Object) - Method in class alluxio.thrift.ConfigCheckReport
 
equals(ConfigCheckReport) - Method in class alluxio.thrift.ConfigCheckReport
 
equals(Object) - Method in class alluxio.thrift.ConfigProperty
 
equals(ConfigProperty) - Method in class alluxio.thrift.ConfigProperty
 
equals(Object) - Method in class alluxio.thrift.CreateDirectoryTOptions
 
equals(CreateDirectoryTOptions) - Method in class alluxio.thrift.CreateDirectoryTOptions
 
equals(Object) - Method in class alluxio.thrift.CreateDirectoryTResponse
 
equals(CreateDirectoryTResponse) - Method in class alluxio.thrift.CreateDirectoryTResponse
 
equals(Object) - Method in class alluxio.thrift.CreateFileTOptions
 
equals(CreateFileTOptions) - Method in class alluxio.thrift.CreateFileTOptions
 
equals(Object) - Method in class alluxio.thrift.CreateFileTResponse
 
equals(CreateFileTResponse) - Method in class alluxio.thrift.CreateFileTResponse
 
equals(Object) - Method in class alluxio.thrift.CreateLineageTOptions
 
equals(CreateLineageTOptions) - Method in class alluxio.thrift.CreateLineageTOptions
 
equals(Object) - Method in class alluxio.thrift.CreateLineageTResponse
 
equals(CreateLineageTResponse) - Method in class alluxio.thrift.CreateLineageTResponse
 
equals(Object) - Method in class alluxio.thrift.CreateStoreTOptions
 
equals(CreateStoreTOptions) - Method in class alluxio.thrift.CreateStoreTOptions
 
equals(Object) - Method in class alluxio.thrift.CreateStoreTResponse
 
equals(CreateStoreTResponse) - Method in class alluxio.thrift.CreateStoreTResponse
 
equals(Object) - Method in class alluxio.thrift.CreateUfsFileTOptions
 
equals(CreateUfsFileTOptions) - Method in class alluxio.thrift.CreateUfsFileTOptions
 
equals(Object) - Method in class alluxio.thrift.CreateUfsFileTResponse
 
equals(CreateUfsFileTResponse) - Method in class alluxio.thrift.CreateUfsFileTResponse
 
equals(Object) - Method in class alluxio.thrift.DeleteLineageTOptions
 
equals(DeleteLineageTOptions) - Method in class alluxio.thrift.DeleteLineageTOptions
 
equals(Object) - Method in class alluxio.thrift.DeleteLineageTResponse
 
equals(DeleteLineageTResponse) - Method in class alluxio.thrift.DeleteLineageTResponse
 
equals(Object) - Method in class alluxio.thrift.DeleteStoreTOptions
 
equals(DeleteStoreTOptions) - Method in class alluxio.thrift.DeleteStoreTOptions
 
equals(Object) - Method in class alluxio.thrift.DeleteStoreTResponse
 
equals(DeleteStoreTResponse) - Method in class alluxio.thrift.DeleteStoreTResponse
 
equals(Object) - Method in class alluxio.thrift.DeleteTOptions
 
equals(DeleteTOptions) - Method in class alluxio.thrift.DeleteTOptions
 
equals(Object) - Method in class alluxio.thrift.DeleteTResponse
 
equals(DeleteTResponse) - Method in class alluxio.thrift.DeleteTResponse
 
equals(Object) - Method in class alluxio.thrift.DependencyInfo
 
equals(DependencyInfo) - Method in class alluxio.thrift.DependencyInfo
 
equals(Object) - Method in class alluxio.thrift.FileBlockInfo
 
equals(FileBlockInfo) - Method in class alluxio.thrift.FileBlockInfo
 
equals(Object) - Method in class alluxio.thrift.FileInfo
 
equals(FileInfo) - Method in class alluxio.thrift.FileInfo
 
equals(Object) - Method in class alluxio.thrift.FileSystemCommand
 
equals(FileSystemCommand) - Method in class alluxio.thrift.FileSystemCommand
 
equals(Object) - Method in class alluxio.thrift.FileSystemCommandOptions
 
equals(FileSystemCommandOptions) - Method in class alluxio.thrift.FileSystemCommandOptions
 
equals(Object) - Method in class alluxio.thrift.FileSystemHeartbeatTOptions
 
equals(FileSystemHeartbeatTOptions) - Method in class alluxio.thrift.FileSystemHeartbeatTOptions
 
equals(Object) - Method in class alluxio.thrift.FileSystemHeartbeatTResponse
 
equals(FileSystemHeartbeatTResponse) - Method in class alluxio.thrift.FileSystemHeartbeatTResponse
 
equals(Object) - Method in class alluxio.thrift.FileSystemMasterClientService.checkConsistency_args
 
equals(FileSystemMasterClientService.checkConsistency_args) - Method in class alluxio.thrift.FileSystemMasterClientService.checkConsistency_args
 
equals(Object) - Method in class alluxio.thrift.FileSystemMasterClientService.checkConsistency_result
 
equals(FileSystemMasterClientService.checkConsistency_result) - Method in class alluxio.thrift.FileSystemMasterClientService.checkConsistency_result
 
equals(Object) - Method in class alluxio.thrift.FileSystemMasterClientService.completeFile_args
 
equals(FileSystemMasterClientService.completeFile_args) - Method in class alluxio.thrift.FileSystemMasterClientService.completeFile_args
 
equals(Object) - Method in class alluxio.thrift.FileSystemMasterClientService.completeFile_result
 
equals(FileSystemMasterClientService.completeFile_result) - Method in class alluxio.thrift.FileSystemMasterClientService.completeFile_result
 
equals(Object) - Method in class alluxio.thrift.FileSystemMasterClientService.createDirectory_args
 
equals(FileSystemMasterClientService.createDirectory_args) - Method in class alluxio.thrift.FileSystemMasterClientService.createDirectory_args
 
equals(Object) - Method in class alluxio.thrift.FileSystemMasterClientService.createDirectory_result
 
equals(FileSystemMasterClientService.createDirectory_result) - Method in class alluxio.thrift.FileSystemMasterClientService.createDirectory_result
 
equals(Object) - Method in class alluxio.thrift.FileSystemMasterClientService.createFile_args
 
equals(FileSystemMasterClientService.createFile_args) - Method in class alluxio.thrift.FileSystemMasterClientService.createFile_args
 
equals(Object) - Method in class alluxio.thrift.FileSystemMasterClientService.createFile_result
 
equals(FileSystemMasterClientService.createFile_result) - Method in class alluxio.thrift.FileSystemMasterClientService.createFile_result
 
equals(Object) - Method in class alluxio.thrift.FileSystemMasterClientService.free_args
 
equals(FileSystemMasterClientService.free_args) - Method in class alluxio.thrift.FileSystemMasterClientService.free_args
 
equals(Object) - Method in class alluxio.thrift.FileSystemMasterClientService.free_result
 
equals(FileSystemMasterClientService.free_result) - Method in class alluxio.thrift.FileSystemMasterClientService.free_result
 
equals(Object) - Method in class alluxio.thrift.FileSystemMasterClientService.getFilePath_args
 
equals(FileSystemMasterClientService.getFilePath_args) - Method in class alluxio.thrift.FileSystemMasterClientService.getFilePath_args
 
equals(Object) - Method in class alluxio.thrift.FileSystemMasterClientService.getFilePath_result
 
equals(FileSystemMasterClientService.getFilePath_result) - Method in class alluxio.thrift.FileSystemMasterClientService.getFilePath_result
 
equals(Object) - Method in class alluxio.thrift.FileSystemMasterClientService.getMountTable_args
 
equals(FileSystemMasterClientService.getMountTable_args) - Method in class alluxio.thrift.FileSystemMasterClientService.getMountTable_args
 
equals(Object) - Method in class alluxio.thrift.FileSystemMasterClientService.getMountTable_result
 
equals(FileSystemMasterClientService.getMountTable_result) - Method in class alluxio.thrift.FileSystemMasterClientService.getMountTable_result
 
equals(Object) - Method in class alluxio.thrift.FileSystemMasterClientService.getNewBlockIdForFile_args
 
equals(FileSystemMasterClientService.getNewBlockIdForFile_args) - Method in class alluxio.thrift.FileSystemMasterClientService.getNewBlockIdForFile_args
 
equals(Object) - Method in class alluxio.thrift.FileSystemMasterClientService.getNewBlockIdForFile_result
 
equals(FileSystemMasterClientService.getNewBlockIdForFile_result) - Method in class alluxio.thrift.FileSystemMasterClientService.getNewBlockIdForFile_result
 
equals(Object) - Method in class alluxio.thrift.FileSystemMasterClientService.getStatus_args
 
equals(FileSystemMasterClientService.getStatus_args) - Method in class alluxio.thrift.FileSystemMasterClientService.getStatus_args
 
equals(Object) - Method in class alluxio.thrift.FileSystemMasterClientService.getStatus_result
 
equals(FileSystemMasterClientService.getStatus_result) - Method in class alluxio.thrift.FileSystemMasterClientService.getStatus_result
 
equals(Object) - Method in class alluxio.thrift.FileSystemMasterClientService.listStatus_args
 
equals(FileSystemMasterClientService.listStatus_args) - Method in class alluxio.thrift.FileSystemMasterClientService.listStatus_args
 
equals(Object) - Method in class alluxio.thrift.FileSystemMasterClientService.listStatus_result
 
equals(FileSystemMasterClientService.listStatus_result) - Method in class alluxio.thrift.FileSystemMasterClientService.listStatus_result
 
equals(Object) - Method in class alluxio.thrift.FileSystemMasterClientService.loadMetadata_args
 
equals(FileSystemMasterClientService.loadMetadata_args) - Method in class alluxio.thrift.FileSystemMasterClientService.loadMetadata_args
 
equals(Object) - Method in class alluxio.thrift.FileSystemMasterClientService.loadMetadata_result
 
equals(FileSystemMasterClientService.loadMetadata_result) - Method in class alluxio.thrift.FileSystemMasterClientService.loadMetadata_result
 
equals(Object) - Method in class alluxio.thrift.FileSystemMasterClientService.mount_args
 
equals(FileSystemMasterClientService.mount_args) - Method in class alluxio.thrift.FileSystemMasterClientService.mount_args
 
equals(Object) - Method in class alluxio.thrift.FileSystemMasterClientService.mount_result
 
equals(FileSystemMasterClientService.mount_result) - Method in class alluxio.thrift.FileSystemMasterClientService.mount_result
 
equals(Object) - Method in class alluxio.thrift.FileSystemMasterClientService.remove_args
 
equals(FileSystemMasterClientService.remove_args) - Method in class alluxio.thrift.FileSystemMasterClientService.remove_args
 
equals(Object) - Method in class alluxio.thrift.FileSystemMasterClientService.remove_result
 
equals(FileSystemMasterClientService.remove_result) - Method in class alluxio.thrift.FileSystemMasterClientService.remove_result
 
equals(Object) - Method in class alluxio.thrift.FileSystemMasterClientService.rename_args
 
equals(FileSystemMasterClientService.rename_args) - Method in class alluxio.thrift.FileSystemMasterClientService.rename_args
 
equals(Object) - Method in class alluxio.thrift.FileSystemMasterClientService.rename_result
 
equals(FileSystemMasterClientService.rename_result) - Method in class alluxio.thrift.FileSystemMasterClientService.rename_result
 
equals(Object) - Method in class alluxio.thrift.FileSystemMasterClientService.scheduleAsyncPersistence_args
 
equals(FileSystemMasterClientService.scheduleAsyncPersistence_args) - Method in class alluxio.thrift.FileSystemMasterClientService.scheduleAsyncPersistence_args
 
equals(Object) - Method in class alluxio.thrift.FileSystemMasterClientService.scheduleAsyncPersistence_result
 
equals(FileSystemMasterClientService.scheduleAsyncPersistence_result) - Method in class alluxio.thrift.FileSystemMasterClientService.scheduleAsyncPersistence_result
 
equals(Object) - Method in class alluxio.thrift.FileSystemMasterClientService.setAttribute_args
 
equals(FileSystemMasterClientService.setAttribute_args) - Method in class alluxio.thrift.FileSystemMasterClientService.setAttribute_args
 
equals(Object) - Method in class alluxio.thrift.FileSystemMasterClientService.setAttribute_result
 
equals(FileSystemMasterClientService.setAttribute_result) - Method in class alluxio.thrift.FileSystemMasterClientService.setAttribute_result
 
equals(Object) - Method in class alluxio.thrift.FileSystemMasterClientService.unmount_args
 
equals(FileSystemMasterClientService.unmount_args) - Method in class alluxio.thrift.FileSystemMasterClientService.unmount_args
 
equals(Object) - Method in class alluxio.thrift.FileSystemMasterClientService.unmount_result
 
equals(FileSystemMasterClientService.unmount_result) - Method in class alluxio.thrift.FileSystemMasterClientService.unmount_result
 
equals(Object) - Method in class alluxio.thrift.FileSystemMasterClientService.updateUfsMode_args
 
equals(FileSystemMasterClientService.updateUfsMode_args) - Method in class alluxio.thrift.FileSystemMasterClientService.updateUfsMode_args
 
equals(Object) - Method in class alluxio.thrift.FileSystemMasterClientService.updateUfsMode_result
 
equals(FileSystemMasterClientService.updateUfsMode_result) - Method in class alluxio.thrift.FileSystemMasterClientService.updateUfsMode_result
 
equals(Object) - Method in class alluxio.thrift.FileSystemMasterCommonTOptions
 
equals(FileSystemMasterCommonTOptions) - Method in class alluxio.thrift.FileSystemMasterCommonTOptions
 
equals(Object) - Method in class alluxio.thrift.FileSystemMasterWorkerService.fileSystemHeartbeat_args
 
equals(FileSystemMasterWorkerService.fileSystemHeartbeat_args) - Method in class alluxio.thrift.FileSystemMasterWorkerService.fileSystemHeartbeat_args
 
equals(Object) - Method in class alluxio.thrift.FileSystemMasterWorkerService.fileSystemHeartbeat_result
 
equals(FileSystemMasterWorkerService.fileSystemHeartbeat_result) - Method in class alluxio.thrift.FileSystemMasterWorkerService.fileSystemHeartbeat_result
 
equals(Object) - Method in class alluxio.thrift.FileSystemMasterWorkerService.getFileInfo_args
 
equals(FileSystemMasterWorkerService.getFileInfo_args) - Method in class alluxio.thrift.FileSystemMasterWorkerService.getFileInfo_args
 
equals(Object) - Method in class alluxio.thrift.FileSystemMasterWorkerService.getFileInfo_result
 
equals(FileSystemMasterWorkerService.getFileInfo_result) - Method in class alluxio.thrift.FileSystemMasterWorkerService.getFileInfo_result
 
equals(Object) - Method in class alluxio.thrift.FileSystemMasterWorkerService.getPinnedFileIds_args
 
equals(FileSystemMasterWorkerService.getPinnedFileIds_args) - Method in class alluxio.thrift.FileSystemMasterWorkerService.getPinnedFileIds_args
 
equals(Object) - Method in class alluxio.thrift.FileSystemMasterWorkerService.getPinnedFileIds_result
 
equals(FileSystemMasterWorkerService.getPinnedFileIds_result) - Method in class alluxio.thrift.FileSystemMasterWorkerService.getPinnedFileIds_result
 
equals(Object) - Method in class alluxio.thrift.FileSystemMasterWorkerService.getUfsInfo_args
 
equals(FileSystemMasterWorkerService.getUfsInfo_args) - Method in class alluxio.thrift.FileSystemMasterWorkerService.getUfsInfo_args
 
equals(Object) - Method in class alluxio.thrift.FileSystemMasterWorkerService.getUfsInfo_result
 
equals(FileSystemMasterWorkerService.getUfsInfo_result) - Method in class alluxio.thrift.FileSystemMasterWorkerService.getUfsInfo_result
 
equals(Object) - Method in class alluxio.thrift.FileSystemWorkerClientService.cancelUfsFile_args
 
equals(FileSystemWorkerClientService.cancelUfsFile_args) - Method in class alluxio.thrift.FileSystemWorkerClientService.cancelUfsFile_args
 
equals(Object) - Method in class alluxio.thrift.FileSystemWorkerClientService.cancelUfsFile_result
 
equals(FileSystemWorkerClientService.cancelUfsFile_result) - Method in class alluxio.thrift.FileSystemWorkerClientService.cancelUfsFile_result
 
equals(Object) - Method in class alluxio.thrift.FileSystemWorkerClientService.closeUfsFile_args
 
equals(FileSystemWorkerClientService.closeUfsFile_args) - Method in class alluxio.thrift.FileSystemWorkerClientService.closeUfsFile_args
 
equals(Object) - Method in class alluxio.thrift.FileSystemWorkerClientService.closeUfsFile_result
 
equals(FileSystemWorkerClientService.closeUfsFile_result) - Method in class alluxio.thrift.FileSystemWorkerClientService.closeUfsFile_result
 
equals(Object) - Method in class alluxio.thrift.FileSystemWorkerClientService.completeUfsFile_args
 
equals(FileSystemWorkerClientService.completeUfsFile_args) - Method in class alluxio.thrift.FileSystemWorkerClientService.completeUfsFile_args
 
equals(Object) - Method in class alluxio.thrift.FileSystemWorkerClientService.completeUfsFile_result
 
equals(FileSystemWorkerClientService.completeUfsFile_result) - Method in class alluxio.thrift.FileSystemWorkerClientService.completeUfsFile_result
 
equals(Object) - Method in class alluxio.thrift.FileSystemWorkerClientService.createUfsFile_args
 
equals(FileSystemWorkerClientService.createUfsFile_args) - Method in class alluxio.thrift.FileSystemWorkerClientService.createUfsFile_args
 
equals(Object) - Method in class alluxio.thrift.FileSystemWorkerClientService.createUfsFile_result
 
equals(FileSystemWorkerClientService.createUfsFile_result) - Method in class alluxio.thrift.FileSystemWorkerClientService.createUfsFile_result
 
equals(Object) - Method in class alluxio.thrift.FileSystemWorkerClientService.openUfsFile_args
 
equals(FileSystemWorkerClientService.openUfsFile_args) - Method in class alluxio.thrift.FileSystemWorkerClientService.openUfsFile_args
 
equals(Object) - Method in class alluxio.thrift.FileSystemWorkerClientService.openUfsFile_result
 
equals(FileSystemWorkerClientService.openUfsFile_result) - Method in class alluxio.thrift.FileSystemWorkerClientService.openUfsFile_result
 
equals(Object) - Method in class alluxio.thrift.FileSystemWorkerClientService.sessionFileSystemHeartbeat_args
 
equals(FileSystemWorkerClientService.sessionFileSystemHeartbeat_args) - Method in class alluxio.thrift.FileSystemWorkerClientService.sessionFileSystemHeartbeat_args
 
equals(Object) - Method in class alluxio.thrift.FileSystemWorkerClientService.sessionFileSystemHeartbeat_result
 
equals(FileSystemWorkerClientService.sessionFileSystemHeartbeat_result) - Method in class alluxio.thrift.FileSystemWorkerClientService.sessionFileSystemHeartbeat_result
 
equals(Object) - Method in class alluxio.thrift.FreeTOptions
 
equals(FreeTOptions) - Method in class alluxio.thrift.FreeTOptions
 
equals(Object) - Method in class alluxio.thrift.FreeTResponse
 
equals(FreeTResponse) - Method in class alluxio.thrift.FreeTResponse
 
equals(Object) - Method in class alluxio.thrift.GetBlockInfoTOptions
 
equals(GetBlockInfoTOptions) - Method in class alluxio.thrift.GetBlockInfoTOptions
 
equals(Object) - Method in class alluxio.thrift.GetBlockInfoTResponse
 
equals(GetBlockInfoTResponse) - Method in class alluxio.thrift.GetBlockInfoTResponse
 
equals(Object) - Method in class alluxio.thrift.GetBlockMasterInfoTOptions
 
equals(GetBlockMasterInfoTOptions) - Method in class alluxio.thrift.GetBlockMasterInfoTOptions
 
equals(Object) - Method in class alluxio.thrift.GetBlockMasterInfoTResponse
 
equals(GetBlockMasterInfoTResponse) - Method in class alluxio.thrift.GetBlockMasterInfoTResponse
 
equals(Object) - Method in class alluxio.thrift.GetCapacityBytesTOptions
 
equals(GetCapacityBytesTOptions) - Method in class alluxio.thrift.GetCapacityBytesTOptions
 
equals(Object) - Method in class alluxio.thrift.GetCapacityBytesTResponse
 
equals(GetCapacityBytesTResponse) - Method in class alluxio.thrift.GetCapacityBytesTResponse
 
equals(Object) - Method in class alluxio.thrift.GetConfigReportTOptions
 
equals(GetConfigReportTOptions) - Method in class alluxio.thrift.GetConfigReportTOptions
 
equals(Object) - Method in class alluxio.thrift.GetConfigReportTResponse
 
equals(GetConfigReportTResponse) - Method in class alluxio.thrift.GetConfigReportTResponse
 
equals(Object) - Method in class alluxio.thrift.GetConfigurationTOptions
 
equals(GetConfigurationTOptions) - Method in class alluxio.thrift.GetConfigurationTOptions
 
equals(Object) - Method in class alluxio.thrift.GetConfigurationTResponse
 
equals(GetConfigurationTResponse) - Method in class alluxio.thrift.GetConfigurationTResponse
 
equals(Object) - Method in class alluxio.thrift.GetFileInfoTOptions
 
equals(GetFileInfoTOptions) - Method in class alluxio.thrift.GetFileInfoTOptions
 
equals(Object) - Method in class alluxio.thrift.GetFileInfoTResponse
 
equals(GetFileInfoTResponse) - Method in class alluxio.thrift.GetFileInfoTResponse
 
equals(Object) - Method in class alluxio.thrift.GetFilePathTOptions
 
equals(GetFilePathTOptions) - Method in class alluxio.thrift.GetFilePathTOptions
 
equals(Object) - Method in class alluxio.thrift.GetFilePathTResponse
 
equals(GetFilePathTResponse) - Method in class alluxio.thrift.GetFilePathTResponse
 
equals(Object) - Method in class alluxio.thrift.GetLineageInfoListTOptions
 
equals(GetLineageInfoListTOptions) - Method in class alluxio.thrift.GetLineageInfoListTOptions
 
equals(Object) - Method in class alluxio.thrift.GetLineageInfoListTResponse
 
equals(GetLineageInfoListTResponse) - Method in class alluxio.thrift.GetLineageInfoListTResponse
 
equals(Object) - Method in class alluxio.thrift.GetMasterIdTOptions
 
equals(GetMasterIdTOptions) - Method in class alluxio.thrift.GetMasterIdTOptions
 
equals(Object) - Method in class alluxio.thrift.GetMasterIdTResponse
 
equals(GetMasterIdTResponse) - Method in class alluxio.thrift.GetMasterIdTResponse
 
equals(Object) - Method in class alluxio.thrift.GetMasterInfoTOptions
 
equals(GetMasterInfoTOptions) - Method in class alluxio.thrift.GetMasterInfoTOptions
 
equals(Object) - Method in class alluxio.thrift.GetMasterInfoTResponse
 
equals(GetMasterInfoTResponse) - Method in class alluxio.thrift.GetMasterInfoTResponse
 
equals(Object) - Method in class alluxio.thrift.GetMetricsTOptions
 
equals(GetMetricsTOptions) - Method in class alluxio.thrift.GetMetricsTOptions
 
equals(Object) - Method in class alluxio.thrift.GetMetricsTResponse
 
equals(GetMetricsTResponse) - Method in class alluxio.thrift.GetMetricsTResponse
 
equals(Object) - Method in class alluxio.thrift.GetMountTableTResponse
 
equals(GetMountTableTResponse) - Method in class alluxio.thrift.GetMountTableTResponse
 
equals(Object) - Method in class alluxio.thrift.GetNewBlockIdForFileTOptions
 
equals(GetNewBlockIdForFileTOptions) - Method in class alluxio.thrift.GetNewBlockIdForFileTOptions
 
equals(Object) - Method in class alluxio.thrift.GetNewBlockIdForFileTResponse
 
equals(GetNewBlockIdForFileTResponse) - Method in class alluxio.thrift.GetNewBlockIdForFileTResponse
 
equals(Object) - Method in class alluxio.thrift.GetNextKeysTOptions
 
equals(GetNextKeysTOptions) - Method in class alluxio.thrift.GetNextKeysTOptions
 
equals(Object) - Method in class alluxio.thrift.GetNextKeysTResponse
 
equals(GetNextKeysTResponse) - Method in class alluxio.thrift.GetNextKeysTResponse
 
equals(Object) - Method in class alluxio.thrift.GetPartitionInfoTOptions
 
equals(GetPartitionInfoTOptions) - Method in class alluxio.thrift.GetPartitionInfoTOptions
 
equals(Object) - Method in class alluxio.thrift.GetPartitionInfoTResponse
 
equals(GetPartitionInfoTResponse) - Method in class alluxio.thrift.GetPartitionInfoTResponse
 
equals(Object) - Method in class alluxio.thrift.GetPinnedFileIdsTOptions
 
equals(GetPinnedFileIdsTOptions) - Method in class alluxio.thrift.GetPinnedFileIdsTOptions
 
equals(Object) - Method in class alluxio.thrift.GetPinnedFileIdsTResponse
 
equals(GetPinnedFileIdsTResponse) - Method in class alluxio.thrift.GetPinnedFileIdsTResponse
 
equals(Object) - Method in class alluxio.thrift.GetServiceVersionTOptions
 
equals(GetServiceVersionTOptions) - Method in class alluxio.thrift.GetServiceVersionTOptions
 
equals(Object) - Method in class alluxio.thrift.GetServiceVersionTResponse
 
equals(GetServiceVersionTResponse) - Method in class alluxio.thrift.GetServiceVersionTResponse
 
equals(Object) - Method in class alluxio.thrift.GetSizeTOptions
 
equals(GetSizeTOptions) - Method in class alluxio.thrift.GetSizeTOptions
 
equals(Object) - Method in class alluxio.thrift.GetSizeTResponse
 
equals(GetSizeTResponse) - Method in class alluxio.thrift.GetSizeTResponse
 
equals(Object) - Method in class alluxio.thrift.GetStatusTOptions
 
equals(GetStatusTOptions) - Method in class alluxio.thrift.GetStatusTOptions
 
equals(Object) - Method in class alluxio.thrift.GetStatusTResponse
 
equals(GetStatusTResponse) - Method in class alluxio.thrift.GetStatusTResponse
 
equals(Object) - Method in class alluxio.thrift.GetTOptions
 
equals(GetTOptions) - Method in class alluxio.thrift.GetTOptions
 
equals(Object) - Method in class alluxio.thrift.GetTResponse
 
equals(GetTResponse) - Method in class alluxio.thrift.GetTResponse
 
equals(Object) - Method in class alluxio.thrift.GetUfsInfoTOptions
 
equals(GetUfsInfoTOptions) - Method in class alluxio.thrift.GetUfsInfoTOptions
 
equals(Object) - Method in class alluxio.thrift.GetUfsInfoTResponse
 
equals(GetUfsInfoTResponse) - Method in class alluxio.thrift.GetUfsInfoTResponse
 
equals(Object) - Method in class alluxio.thrift.GetUsedBytesTOptions
 
equals(GetUsedBytesTOptions) - Method in class alluxio.thrift.GetUsedBytesTOptions
 
equals(Object) - Method in class alluxio.thrift.GetUsedBytesTResponse
 
equals(GetUsedBytesTResponse) - Method in class alluxio.thrift.GetUsedBytesTResponse
 
equals(Object) - Method in class alluxio.thrift.GetWorkerIdTOptions
 
equals(GetWorkerIdTOptions) - Method in class alluxio.thrift.GetWorkerIdTOptions
 
equals(Object) - Method in class alluxio.thrift.GetWorkerIdTResponse
 
equals(GetWorkerIdTResponse) - Method in class alluxio.thrift.GetWorkerIdTResponse
 
equals(Object) - Method in class alluxio.thrift.GetWorkerInfoListTOptions
 
equals(GetWorkerInfoListTOptions) - Method in class alluxio.thrift.GetWorkerInfoListTOptions
 
equals(Object) - Method in class alluxio.thrift.GetWorkerInfoListTResponse
 
equals(GetWorkerInfoListTResponse) - Method in class alluxio.thrift.GetWorkerInfoListTResponse
 
equals(Object) - Method in class alluxio.thrift.GetWorkerReportTOptions
 
equals(GetWorkerReportTOptions) - Method in class alluxio.thrift.GetWorkerReportTOptions
 
equals(Object) - Method in class alluxio.thrift.InconsistentProperty
 
equals(InconsistentProperty) - Method in class alluxio.thrift.InconsistentProperty
 
equals(Object) - Method in class alluxio.thrift.JobConfInfo
 
equals(JobConfInfo) - Method in class alluxio.thrift.JobConfInfo
 
equals(Object) - Method in class alluxio.thrift.KeyValueMasterClientService.completePartition_args
 
equals(KeyValueMasterClientService.completePartition_args) - Method in class alluxio.thrift.KeyValueMasterClientService.completePartition_args
 
equals(Object) - Method in class alluxio.thrift.KeyValueMasterClientService.completePartition_result
 
equals(KeyValueMasterClientService.completePartition_result) - Method in class alluxio.thrift.KeyValueMasterClientService.completePartition_result
 
equals(Object) - Method in class alluxio.thrift.KeyValueMasterClientService.completeStore_args
 
equals(KeyValueMasterClientService.completeStore_args) - Method in class alluxio.thrift.KeyValueMasterClientService.completeStore_args
 
equals(Object) - Method in class alluxio.thrift.KeyValueMasterClientService.completeStore_result
 
equals(KeyValueMasterClientService.completeStore_result) - Method in class alluxio.thrift.KeyValueMasterClientService.completeStore_result
 
equals(Object) - Method in class alluxio.thrift.KeyValueMasterClientService.createStore_args
 
equals(KeyValueMasterClientService.createStore_args) - Method in class alluxio.thrift.KeyValueMasterClientService.createStore_args
 
equals(Object) - Method in class alluxio.thrift.KeyValueMasterClientService.createStore_result
 
equals(KeyValueMasterClientService.createStore_result) - Method in class alluxio.thrift.KeyValueMasterClientService.createStore_result
 
equals(Object) - Method in class alluxio.thrift.KeyValueMasterClientService.deleteStore_args
 
equals(KeyValueMasterClientService.deleteStore_args) - Method in class alluxio.thrift.KeyValueMasterClientService.deleteStore_args
 
equals(Object) - Method in class alluxio.thrift.KeyValueMasterClientService.deleteStore_result
 
equals(KeyValueMasterClientService.deleteStore_result) - Method in class alluxio.thrift.KeyValueMasterClientService.deleteStore_result
 
equals(Object) - Method in class alluxio.thrift.KeyValueMasterClientService.getPartitionInfo_args
 
equals(KeyValueMasterClientService.getPartitionInfo_args) - Method in class alluxio.thrift.KeyValueMasterClientService.getPartitionInfo_args
 
equals(Object) - Method in class alluxio.thrift.KeyValueMasterClientService.getPartitionInfo_result
 
equals(KeyValueMasterClientService.getPartitionInfo_result) - Method in class alluxio.thrift.KeyValueMasterClientService.getPartitionInfo_result
 
equals(Object) - Method in class alluxio.thrift.KeyValueMasterClientService.mergeStore_args
 
equals(KeyValueMasterClientService.mergeStore_args) - Method in class alluxio.thrift.KeyValueMasterClientService.mergeStore_args
 
equals(Object) - Method in class alluxio.thrift.KeyValueMasterClientService.mergeStore_result
 
equals(KeyValueMasterClientService.mergeStore_result) - Method in class alluxio.thrift.KeyValueMasterClientService.mergeStore_result
 
equals(Object) - Method in class alluxio.thrift.KeyValueMasterClientService.renameStore_args
 
equals(KeyValueMasterClientService.renameStore_args) - Method in class alluxio.thrift.KeyValueMasterClientService.renameStore_args
 
equals(Object) - Method in class alluxio.thrift.KeyValueMasterClientService.renameStore_result
 
equals(KeyValueMasterClientService.renameStore_result) - Method in class alluxio.thrift.KeyValueMasterClientService.renameStore_result
 
equals(Object) - Method in class alluxio.thrift.KeyValueWorkerClientService.get_args
 
equals(KeyValueWorkerClientService.get_args) - Method in class alluxio.thrift.KeyValueWorkerClientService.get_args
 
equals(Object) - Method in class alluxio.thrift.KeyValueWorkerClientService.get_result
 
equals(KeyValueWorkerClientService.get_result) - Method in class alluxio.thrift.KeyValueWorkerClientService.get_result
 
equals(Object) - Method in class alluxio.thrift.KeyValueWorkerClientService.getNextKeys_args
 
equals(KeyValueWorkerClientService.getNextKeys_args) - Method in class alluxio.thrift.KeyValueWorkerClientService.getNextKeys_args
 
equals(Object) - Method in class alluxio.thrift.KeyValueWorkerClientService.getNextKeys_result
 
equals(KeyValueWorkerClientService.getNextKeys_result) - Method in class alluxio.thrift.KeyValueWorkerClientService.getNextKeys_result
 
equals(Object) - Method in class alluxio.thrift.KeyValueWorkerClientService.getSize_args
 
equals(KeyValueWorkerClientService.getSize_args) - Method in class alluxio.thrift.KeyValueWorkerClientService.getSize_args
 
equals(Object) - Method in class alluxio.thrift.KeyValueWorkerClientService.getSize_result
 
equals(KeyValueWorkerClientService.getSize_result) - Method in class alluxio.thrift.KeyValueWorkerClientService.getSize_result
 
equals(Object) - Method in class alluxio.thrift.LineageInfo
 
equals(LineageInfo) - Method in class alluxio.thrift.LineageInfo
 
equals(Object) - Method in class alluxio.thrift.LineageMasterClientService.createLineage_args
 
equals(LineageMasterClientService.createLineage_args) - Method in class alluxio.thrift.LineageMasterClientService.createLineage_args
 
equals(Object) - Method in class alluxio.thrift.LineageMasterClientService.createLineage_result
 
equals(LineageMasterClientService.createLineage_result) - Method in class alluxio.thrift.LineageMasterClientService.createLineage_result
 
equals(Object) - Method in class alluxio.thrift.LineageMasterClientService.deleteLineage_args
 
equals(LineageMasterClientService.deleteLineage_args) - Method in class alluxio.thrift.LineageMasterClientService.deleteLineage_args
 
equals(Object) - Method in class alluxio.thrift.LineageMasterClientService.deleteLineage_result
 
equals(LineageMasterClientService.deleteLineage_result) - Method in class alluxio.thrift.LineageMasterClientService.deleteLineage_result
 
equals(Object) - Method in class alluxio.thrift.LineageMasterClientService.getLineageInfoList_args
 
equals(LineageMasterClientService.getLineageInfoList_args) - Method in class alluxio.thrift.LineageMasterClientService.getLineageInfoList_args
 
equals(Object) - Method in class alluxio.thrift.LineageMasterClientService.getLineageInfoList_result
 
equals(LineageMasterClientService.getLineageInfoList_result) - Method in class alluxio.thrift.LineageMasterClientService.getLineageInfoList_result
 
equals(Object) - Method in class alluxio.thrift.LineageMasterClientService.reinitializeFile_args
 
equals(LineageMasterClientService.reinitializeFile_args) - Method in class alluxio.thrift.LineageMasterClientService.reinitializeFile_args
 
equals(Object) - Method in class alluxio.thrift.LineageMasterClientService.reinitializeFile_result
 
equals(LineageMasterClientService.reinitializeFile_result) - Method in class alluxio.thrift.LineageMasterClientService.reinitializeFile_result
 
equals(Object) - Method in class alluxio.thrift.LineageMasterClientService.reportLostFile_args
 
equals(LineageMasterClientService.reportLostFile_args) - Method in class alluxio.thrift.LineageMasterClientService.reportLostFile_args
 
equals(Object) - Method in class alluxio.thrift.LineageMasterClientService.reportLostFile_result
 
equals(LineageMasterClientService.reportLostFile_result) - Method in class alluxio.thrift.LineageMasterClientService.reportLostFile_result
 
equals(Object) - Method in class alluxio.thrift.ListStatusTOptions
 
equals(ListStatusTOptions) - Method in class alluxio.thrift.ListStatusTOptions
 
equals(Object) - Method in class alluxio.thrift.ListStatusTResponse
 
equals(ListStatusTResponse) - Method in class alluxio.thrift.ListStatusTResponse
 
equals(Object) - Method in class alluxio.thrift.LoadMetadataTOptions
 
equals(LoadMetadataTOptions) - Method in class alluxio.thrift.LoadMetadataTOptions
 
equals(Object) - Method in class alluxio.thrift.LoadMetadataTResponse
 
equals(LoadMetadataTResponse) - Method in class alluxio.thrift.LoadMetadataTResponse
 
equals(Object) - Method in class alluxio.thrift.LocalityTier
 
equals(LocalityTier) - Method in class alluxio.thrift.LocalityTier
 
equals(Object) - Method in class alluxio.thrift.LockBlockTOptions
 
equals(LockBlockTOptions) - Method in class alluxio.thrift.LockBlockTOptions
 
equals(Object) - Method in class alluxio.thrift.LockBlockTResponse
 
equals(LockBlockTResponse) - Method in class alluxio.thrift.LockBlockTResponse
 
equals(Object) - Method in class alluxio.thrift.MasterHeartbeatTOptions
 
equals(MasterHeartbeatTOptions) - Method in class alluxio.thrift.MasterHeartbeatTOptions
 
equals(Object) - Method in class alluxio.thrift.MasterHeartbeatTResponse
 
equals(MasterHeartbeatTResponse) - Method in class alluxio.thrift.MasterHeartbeatTResponse
 
equals(Object) - Method in class alluxio.thrift.MasterInfo
 
equals(MasterInfo) - Method in class alluxio.thrift.MasterInfo
 
equals(Object) - Method in class alluxio.thrift.MasterNetAddress
 
equals(MasterNetAddress) - Method in class alluxio.thrift.MasterNetAddress
 
equals(Object) - Method in class alluxio.thrift.MergeStoreTOptions
 
equals(MergeStoreTOptions) - Method in class alluxio.thrift.MergeStoreTOptions
 
equals(Object) - Method in class alluxio.thrift.MergeStoreTResponse
 
equals(MergeStoreTResponse) - Method in class alluxio.thrift.MergeStoreTResponse
 
equals(Object) - Method in class alluxio.thrift.MetaMasterClientService.backup_args
 
equals(MetaMasterClientService.backup_args) - Method in class alluxio.thrift.MetaMasterClientService.backup_args
 
equals(Object) - Method in class alluxio.thrift.MetaMasterClientService.backup_result
 
equals(MetaMasterClientService.backup_result) - Method in class alluxio.thrift.MetaMasterClientService.backup_result
 
equals(Object) - Method in class alluxio.thrift.MetaMasterClientService.getConfigReport_args
 
equals(MetaMasterClientService.getConfigReport_args) - Method in class alluxio.thrift.MetaMasterClientService.getConfigReport_args
 
equals(Object) - Method in class alluxio.thrift.MetaMasterClientService.getConfigReport_result
 
equals(MetaMasterClientService.getConfigReport_result) - Method in class alluxio.thrift.MetaMasterClientService.getConfigReport_result
 
equals(Object) - Method in class alluxio.thrift.MetaMasterClientService.getConfiguration_args
 
equals(MetaMasterClientService.getConfiguration_args) - Method in class alluxio.thrift.MetaMasterClientService.getConfiguration_args
 
equals(Object) - Method in class alluxio.thrift.MetaMasterClientService.getConfiguration_result
 
equals(MetaMasterClientService.getConfiguration_result) - Method in class alluxio.thrift.MetaMasterClientService.getConfiguration_result
 
equals(Object) - Method in class alluxio.thrift.MetaMasterClientService.getMasterInfo_args
 
equals(MetaMasterClientService.getMasterInfo_args) - Method in class alluxio.thrift.MetaMasterClientService.getMasterInfo_args
 
equals(Object) - Method in class alluxio.thrift.MetaMasterClientService.getMasterInfo_result
 
equals(MetaMasterClientService.getMasterInfo_result) - Method in class alluxio.thrift.MetaMasterClientService.getMasterInfo_result
 
equals(Object) - Method in class alluxio.thrift.MetaMasterClientService.getMetrics_args
 
equals(MetaMasterClientService.getMetrics_args) - Method in class alluxio.thrift.MetaMasterClientService.getMetrics_args
 
equals(Object) - Method in class alluxio.thrift.MetaMasterClientService.getMetrics_result
 
equals(MetaMasterClientService.getMetrics_result) - Method in class alluxio.thrift.MetaMasterClientService.getMetrics_result
 
equals(Object) - Method in class alluxio.thrift.MetaMasterMasterService.getMasterId_args
 
equals(MetaMasterMasterService.getMasterId_args) - Method in class alluxio.thrift.MetaMasterMasterService.getMasterId_args
 
equals(Object) - Method in class alluxio.thrift.MetaMasterMasterService.getMasterId_result
 
equals(MetaMasterMasterService.getMasterId_result) - Method in class alluxio.thrift.MetaMasterMasterService.getMasterId_result
 
equals(Object) - Method in class alluxio.thrift.MetaMasterMasterService.masterHeartbeat_args
 
equals(MetaMasterMasterService.masterHeartbeat_args) - Method in class alluxio.thrift.MetaMasterMasterService.masterHeartbeat_args
 
equals(Object) - Method in class alluxio.thrift.MetaMasterMasterService.masterHeartbeat_result
 
equals(MetaMasterMasterService.masterHeartbeat_result) - Method in class alluxio.thrift.MetaMasterMasterService.masterHeartbeat_result
 
equals(Object) - Method in class alluxio.thrift.MetaMasterMasterService.registerMaster_args
 
equals(MetaMasterMasterService.registerMaster_args) - Method in class alluxio.thrift.MetaMasterMasterService.registerMaster_args
 
equals(Object) - Method in class alluxio.thrift.MetaMasterMasterService.registerMaster_result
 
equals(MetaMasterMasterService.registerMaster_result) - Method in class alluxio.thrift.MetaMasterMasterService.registerMaster_result
 
equals(Object) - Method in class alluxio.thrift.Metric
 
equals(Metric) - Method in class alluxio.thrift.Metric
 
equals(Object) - Method in class alluxio.thrift.MetricsHeartbeatTOptions
 
equals(MetricsHeartbeatTOptions) - Method in class alluxio.thrift.MetricsHeartbeatTOptions
 
equals(Object) - Method in class alluxio.thrift.MetricsHeartbeatTResponse
 
equals(MetricsHeartbeatTResponse) - Method in class alluxio.thrift.MetricsHeartbeatTResponse
 
equals(Object) - Method in class alluxio.thrift.MetricsMasterClientService.metricsHeartbeat_args
 
equals(MetricsMasterClientService.metricsHeartbeat_args) - Method in class alluxio.thrift.MetricsMasterClientService.metricsHeartbeat_args
 
equals(Object) - Method in class alluxio.thrift.MetricsMasterClientService.metricsHeartbeat_result
 
equals(MetricsMasterClientService.metricsHeartbeat_result) - Method in class alluxio.thrift.MetricsMasterClientService.metricsHeartbeat_result
 
equals(Object) - Method in class alluxio.thrift.MetricValue
 
equals(MetricValue) - Method in class alluxio.thrift.MetricValue
 
equals(Object) - Method in class alluxio.thrift.MountPointInfo
 
equals(MountPointInfo) - Method in class alluxio.thrift.MountPointInfo
 
equals(Object) - Method in class alluxio.thrift.MountTOptions
 
equals(MountTOptions) - Method in class alluxio.thrift.MountTOptions
 
equals(Object) - Method in class alluxio.thrift.MountTResponse
 
equals(MountTResponse) - Method in class alluxio.thrift.MountTResponse
 
equals(Object) - Method in class alluxio.thrift.OpenUfsFileTOptions
 
equals(OpenUfsFileTOptions) - Method in class alluxio.thrift.OpenUfsFileTOptions
 
equals(Object) - Method in class alluxio.thrift.OpenUfsFileTResponse
 
equals(OpenUfsFileTResponse) - Method in class alluxio.thrift.OpenUfsFileTResponse
 
equals(Object) - Method in class alluxio.thrift.OptionalString
 
equals(OptionalString) - Method in class alluxio.thrift.OptionalString
 
equals(Object) - Method in class alluxio.thrift.PartitionInfo
 
equals(PartitionInfo) - Method in class alluxio.thrift.PartitionInfo
 
equals(Object) - Method in class alluxio.thrift.PersistCommandOptions
 
equals(PersistCommandOptions) - Method in class alluxio.thrift.PersistCommandOptions
 
equals(Object) - Method in class alluxio.thrift.PersistFile
 
equals(PersistFile) - Method in class alluxio.thrift.PersistFile
 
equals(Object) - Method in class alluxio.thrift.PromoteBlockTOptions
 
equals(PromoteBlockTOptions) - Method in class alluxio.thrift.PromoteBlockTOptions
 
equals(Object) - Method in class alluxio.thrift.PromoteBlockTResponse
 
equals(PromoteBlockTResponse) - Method in class alluxio.thrift.PromoteBlockTResponse
 
equals(Object) - Method in class alluxio.thrift.RegisterMasterTOptions
 
equals(RegisterMasterTOptions) - Method in class alluxio.thrift.RegisterMasterTOptions
 
equals(Object) - Method in class alluxio.thrift.RegisterMasterTResponse
 
equals(RegisterMasterTResponse) - Method in class alluxio.thrift.RegisterMasterTResponse
 
equals(Object) - Method in class alluxio.thrift.RegisterWorkerTOptions
 
equals(RegisterWorkerTOptions) - Method in class alluxio.thrift.RegisterWorkerTOptions
 
equals(Object) - Method in class alluxio.thrift.RegisterWorkerTResponse
 
equals(RegisterWorkerTResponse) - Method in class alluxio.thrift.RegisterWorkerTResponse
 
equals(Object) - Method in class alluxio.thrift.ReinitializeFileTOptions
 
equals(ReinitializeFileTOptions) - Method in class alluxio.thrift.ReinitializeFileTOptions
 
equals(Object) - Method in class alluxio.thrift.ReinitializeFileTResponse
 
equals(ReinitializeFileTResponse) - Method in class alluxio.thrift.ReinitializeFileTResponse
 
equals(Object) - Method in class alluxio.thrift.RemoveBlockTOptions
 
equals(RemoveBlockTOptions) - Method in class alluxio.thrift.RemoveBlockTOptions
 
equals(Object) - Method in class alluxio.thrift.RemoveBlockTResponse
 
equals(RemoveBlockTResponse) - Method in class alluxio.thrift.RemoveBlockTResponse
 
equals(Object) - Method in class alluxio.thrift.RenameStoreTOptions
 
equals(RenameStoreTOptions) - Method in class alluxio.thrift.RenameStoreTOptions
 
equals(Object) - Method in class alluxio.thrift.RenameStoreTResponse
 
equals(RenameStoreTResponse) - Method in class alluxio.thrift.RenameStoreTResponse
 
equals(Object) - Method in class alluxio.thrift.RenameTOptions
 
equals(RenameTOptions) - Method in class alluxio.thrift.RenameTOptions
 
equals(Object) - Method in class alluxio.thrift.RenameTResponse
 
equals(RenameTResponse) - Method in class alluxio.thrift.RenameTResponse
 
equals(Object) - Method in class alluxio.thrift.ReportLostFileTOptions
 
equals(ReportLostFileTOptions) - Method in class alluxio.thrift.ReportLostFileTOptions
 
equals(Object) - Method in class alluxio.thrift.ReportLostFileTResponse
 
equals(ReportLostFileTResponse) - Method in class alluxio.thrift.ReportLostFileTResponse
 
equals(Object) - Method in class alluxio.thrift.RequestBlockLocationTOptions
 
equals(RequestBlockLocationTOptions) - Method in class alluxio.thrift.RequestBlockLocationTOptions
 
equals(Object) - Method in class alluxio.thrift.RequestBlockLocationTResponse
 
equals(RequestBlockLocationTResponse) - Method in class alluxio.thrift.RequestBlockLocationTResponse
 
equals(Object) - Method in class alluxio.thrift.RequestSpaceTOptions
 
equals(RequestSpaceTOptions) - Method in class alluxio.thrift.RequestSpaceTOptions
 
equals(Object) - Method in class alluxio.thrift.RequestSpaceTResponse
 
equals(RequestSpaceTResponse) - Method in class alluxio.thrift.RequestSpaceTResponse
 
equals(Object) - Method in class alluxio.thrift.ScheduleAsyncPersistenceTOptions
 
equals(ScheduleAsyncPersistenceTOptions) - Method in class alluxio.thrift.ScheduleAsyncPersistenceTOptions
 
equals(Object) - Method in class alluxio.thrift.ScheduleAsyncPersistenceTResponse
 
equals(ScheduleAsyncPersistenceTResponse) - Method in class alluxio.thrift.ScheduleAsyncPersistenceTResponse
 
equals(Object) - Method in class alluxio.thrift.SessionBlockHeartbeatTOptions
 
equals(SessionBlockHeartbeatTOptions) - Method in class alluxio.thrift.SessionBlockHeartbeatTOptions
 
equals(Object) - Method in class alluxio.thrift.SessionBlockHeartbeatTResponse
 
equals(SessionBlockHeartbeatTResponse) - Method in class alluxio.thrift.SessionBlockHeartbeatTResponse
 
equals(Object) - Method in class alluxio.thrift.SessionFileSystemHeartbeatTOptions
 
equals(SessionFileSystemHeartbeatTOptions) - Method in class alluxio.thrift.SessionFileSystemHeartbeatTOptions
 
equals(Object) - Method in class alluxio.thrift.SessionFileSystemHeartbeatTResponse
 
equals(SessionFileSystemHeartbeatTResponse) - Method in class alluxio.thrift.SessionFileSystemHeartbeatTResponse
 
equals(Object) - Method in class alluxio.thrift.SetAttributeTOptions
 
equals(SetAttributeTOptions) - Method in class alluxio.thrift.SetAttributeTOptions
 
equals(Object) - Method in class alluxio.thrift.SetAttributeTResponse
 
equals(SetAttributeTResponse) - Method in class alluxio.thrift.SetAttributeTResponse
 
equals(Object) - Method in class alluxio.thrift.SyncMetadataTOptions
 
equals(SyncMetadataTOptions) - Method in class alluxio.thrift.SyncMetadataTOptions
 
equals(Object) - Method in class alluxio.thrift.SyncMetadataTResponse
 
equals(SyncMetadataTResponse) - Method in class alluxio.thrift.SyncMetadataTResponse
 
equals(Object) - Method in class alluxio.thrift.TieredIdentity
 
equals(TieredIdentity) - Method in class alluxio.thrift.TieredIdentity
 
equals(Object) - Method in class alluxio.thrift.UfsInfo
 
equals(UfsInfo) - Method in class alluxio.thrift.UfsInfo
 
equals(Object) - Method in class alluxio.thrift.UnlockBlockTOptions
 
equals(UnlockBlockTOptions) - Method in class alluxio.thrift.UnlockBlockTOptions
 
equals(Object) - Method in class alluxio.thrift.UnlockBlockTResponse
 
equals(UnlockBlockTResponse) - Method in class alluxio.thrift.UnlockBlockTResponse
 
equals(Object) - Method in class alluxio.thrift.UnmountTOptions
 
equals(UnmountTOptions) - Method in class alluxio.thrift.UnmountTOptions
 
equals(Object) - Method in class alluxio.thrift.UnmountTResponse
 
equals(UnmountTResponse) - Method in class alluxio.thrift.UnmountTResponse
 
equals(Object) - Method in class alluxio.thrift.UpdateUfsModeTOptions
 
equals(UpdateUfsModeTOptions) - Method in class alluxio.thrift.UpdateUfsModeTOptions
 
equals(Object) - Method in class alluxio.thrift.UpdateUfsModeTResponse
 
equals(UpdateUfsModeTResponse) - Method in class alluxio.thrift.UpdateUfsModeTResponse
 
equals(Object) - Method in class alluxio.thrift.WorkerInfo
 
equals(WorkerInfo) - Method in class alluxio.thrift.WorkerInfo
 
equals(Object) - Method in class alluxio.thrift.WorkerNetAddress
 
equals(WorkerNetAddress) - Method in class alluxio.thrift.WorkerNetAddress
 
equals(Object) - Method in class alluxio.underfs.AbstractUfsManager.Key
 
equals(Object) - Method in class alluxio.underfs.options.CreateOptions
 
equals(Object) - Method in class alluxio.underfs.options.DeleteOptions
 
equals(Object) - Method in class alluxio.underfs.options.FileLocationOptions
 
equals(Object) - Method in class alluxio.underfs.options.ListOptions
 
equals(Object) - Method in class alluxio.underfs.options.MkdirsOptions
 
equals(Object) - Method in class alluxio.underfs.options.OpenOptions
 
equals(Object) - Method in class alluxio.underfs.UfsStatus
 
equals(Object) - Method in class alluxio.util.UnixMountInfo
 
equals(Object) - Method in class alluxio.util.UnixMountInfo.Options
 
equals(Object) - Method in class alluxio.util.WaitForOptions
 
equals(Object) - Method in class alluxio.web.WebInterfaceWorkersServlet.NodeInfo
 
equals(Object) - Method in class alluxio.wire.Address
 
equals(Object) - Method in class alluxio.wire.AlluxioMasterInfo
 
equals(Object) - Method in class alluxio.wire.AlluxioProxyInfo
 
equals(Object) - Method in class alluxio.wire.AlluxioWorkerInfo
 
equals(Object) - Method in class alluxio.wire.BlockInfo
 
equals(Object) - Method in class alluxio.wire.BlockLocation
 
equals(Object) - Method in class alluxio.wire.BlockMasterInfo
 
equals(Object) - Method in class alluxio.wire.Capacity
 
equals(Object) - Method in class alluxio.wire.CommandLineJobInfo
 
equals(Object) - Method in class alluxio.wire.CommonOptions
 
equals(Object) - Method in class alluxio.wire.ConfigProperty
 
equals(Object) - Method in class alluxio.wire.FileBlockInfo
 
equals(Object) - Method in class alluxio.wire.FileInfo
 
equals(Object) - Method in class alluxio.wire.GetConfigurationOptions
 
equals(Object) - Method in class alluxio.wire.InconsistentProperty
 
equals(Object) - Method in class alluxio.wire.JobConfInfo
 
equals(Object) - Method in class alluxio.wire.LineageInfo
 
equals(Object) - Method in class alluxio.wire.MasterInfo
 
equals(Object) - Method in class alluxio.wire.MountPointInfo
 
equals(Object) - Method in class alluxio.wire.StartupConsistencyCheck
 
equals(Object) - Method in class alluxio.wire.TieredIdentity
 
equals(Object) - Method in class alluxio.wire.TieredIdentity.LocalityTier
 
equals(Object) - Method in class alluxio.wire.WorkerInfo
 
equals(Object) - Method in class alluxio.wire.WorkerNetAddress
 
equals(Object) - Method in class alluxio.worker.block.BlockStoreLocation
Compares to a specific object.
error(String) - Method in class alluxio.util.logging.SamplingLogger
 
error(String, Object) - Method in class alluxio.util.logging.SamplingLogger
 
error(String, Object, Object) - Method in class alluxio.util.logging.SamplingLogger
 
error(String, Object...) - Method in class alluxio.util.logging.SamplingLogger
 
error(String, Throwable) - Method in class alluxio.util.logging.SamplingLogger
 
error(Marker, String) - Method in class alluxio.util.logging.SamplingLogger
 
error(Marker, String, Object) - Method in class alluxio.util.logging.SamplingLogger
 
error(Marker, String, Object, Object) - Method in class alluxio.util.logging.SamplingLogger
 
error(Marker, String, Object...) - Method in class alluxio.util.logging.SamplingLogger
 
error(Marker, String, Throwable) - Method in class alluxio.util.logging.SamplingLogger
 
ErrorResponse(Status, String) - Constructor for class alluxio.RestUtils.ErrorResponse
escape(AlluxioURI) - Static method in class alluxio.metrics.MetricsSystem
Escapes a URI, replacing "/" and "." with "_" so that when the URI is used in a metric name, the "/" and "." won't be interpreted as path separators.
evaluateResponse(byte[]) - Method in class alluxio.security.authentication.PlainSaslServer
 
EvictionPlan - Class in alluxio.worker.block.evictor
This class provides information about the blocks that need to be moved when evicting.
EvictionPlan(List<BlockTransferInfo>, List<Pair<Long, BlockStoreLocation>>) - Constructor for class alluxio.worker.block.evictor.EvictionPlan
Creates a new instance of EvictionPlan.
Evictor - Interface in alluxio.worker.block.evictor
Interface for the eviction policy in Alluxio.
Evictor.Factory - Class in alluxio.worker.block.evictor
Factory for Evictor.
Evictor.Mode - Enum in alluxio.worker.block.evictor
The eviction mode.
EvictorUtils - Class in alluxio.worker.block.evictor
Utility functions for the evictor package.
exceptionCaught(ChannelHandlerContext, Throwable) - Method in class alluxio.network.netty.NettyRPC.RPCHandler
 
exceptionCaught(ChannelHandlerContext, Throwable) - Method in class alluxio.network.protocol.RPCMessageDecoder
 
exceptionCaught(Throwable) - Method in interface alluxio.RpcUtils.NettyRpcCallable
Handles exception.
ExceptionMessage - Enum in alluxio.exception
Exception messages used across Alluxio.
execCommand(String...) - Static method in class alluxio.util.ShellUtils
Static method to execute a shell command.
execute(String) - Static method in class alluxio.heartbeat.HeartbeatScheduler
Convenience method for executing a heartbeat and waiting for it to complete.
execute(Runnable) - Method in class alluxio.util.executor.ControllableScheduler
 
ExecutorServiceFactories - Class in alluxio.util.executor
Convenience methods for constructing instances of ExecutorServiceFactory.
ExecutorServiceFactory - Interface in alluxio.util.executor
Interface for a factory which constructs executor services.
exists(AlluxioURI) - Method in class alluxio.client.file.BaseFileSystem
 
exists(AlluxioURI, ExistsOptions) - Method in class alluxio.client.file.BaseFileSystem
 
exists(AlluxioURI) - Method in interface alluxio.client.file.FileSystem
Convenience method for FileSystem.exists(AlluxioURI, ExistsOptions) with default options.
exists(AlluxioURI, ExistsOptions) - Method in interface alluxio.client.file.FileSystem
Checks whether a path exists in Alluxio space.
EXISTS - Static variable in class alluxio.proxy.PathsRestServiceHandler
 
exists(String, ExistsOptions) - Method in class alluxio.proxy.PathsRestServiceHandler
 
exists(String) - Method in class alluxio.underfs.BaseUnderFileSystem
 
exists(String) - Method in class alluxio.underfs.hdfs.HdfsUnderFileSystem
 
exists(String) - Method in class alluxio.underfs.local.LocalUnderFileSystem
 
exists(String) - Method in interface alluxio.underfs.UnderFileSystem
Checks if a file or directory exists in under file system.
exists(String) - Method in class alluxio.underfs.UnderFileSystemWithLogging
 
exists(String) - Static method in class alluxio.util.io.FileUtils
Checks if a path exists.
ExistsOptions - Class in alluxio.client.file.options
Method options for checking the existence of a path.
ExitCodeException(int, String) - Constructor for exception alluxio.util.ShellUtils.ExitCodeException
Constructs an ExitCodeException.
ExponentialBackoffRetry - Class in alluxio.retry
Each retry will cause a sleep to happen.
ExponentialBackoffRetry(int, int, int) - Constructor for class alluxio.retry.ExponentialBackoffRetry
Constructs a new retry facility which sleeps for an exponentially increasing amount of time between retries.
ExponentialTimeBoundedRetry - Class in alluxio.retry
A retry policy which uses exponential backoff and a maximum duration time bound.
ExponentialTimeBoundedRetry.Builder - Class in alluxio.retry
Builder for time bounded exponential retry mechanisms.
EXTENSION_JAR - Static variable in class alluxio.Constants
 
ExtensionFactory<T,S> - Interface in alluxio.extensions
A factory class for creating instance of T based on configuration S.
ExtensionFactoryRegistry<T extends ExtensionFactory<?,S>,S> - Class in alluxio.extensions
An extension registry that uses the ServiceLoader mechanism to automatically discover available factories and provides a central place for obtaining actual extension instances.
ExtensionFactoryRegistry(Class<T>, String) - Constructor for class alluxio.extensions.ExtensionFactoryRegistry
Constructs a registry for loading extension of a particular type.
EXTENSIONS_DIR - Static variable in class alluxio.PropertyKey
 
EXTENSIONS_DIR - Static variable in class alluxio.PropertyKey.Name
 
ExtensionsClassLoader - Class in alluxio.extensions
An isolated ClassLoader for loading extensions to core Alluxio.
ExtensionsClassLoader(URL[], ClassLoader) - Constructor for class alluxio.extensions.ExtensionsClassLoader
 
ExtensionsShell - Class in alluxio.cli.extensions
Utility for managing Alluxio extensions.
ExtensionsShellUtils - Class in alluxio.cli.extensions
Class for convenience methods used by instances of ExtensionsShell.
ExtensionUtils - Class in alluxio.util
Utility functions for working with extensions.
ExternalProcess - Class in alluxio.multi.process
Class for launching another class in a new processes.
ExternalProcess(Map<PropertyKey, String>, Class<?>, File) - Constructor for class alluxio.multi.process.ExternalProcess
 
extractGroupBits(short) - Static method in class alluxio.security.authorization.Mode
 
extractOtherBits(short) - Static method in class alluxio.security.authorization.Mode
 
extractOwnerBits(short) - Static method in class alluxio.security.authorization.Mode
 

F

Factory(FileSystemContext, WorkerNetAddress, long, long, InStreamOptions) - Constructor for class alluxio.client.block.stream.LocalFilePacketReader.Factory
Creates an instance of LocalFilePacketReader.Factory.
Factory(FileSystemContext, WorkerNetAddress, Protocol.ReadRequest) - Constructor for class alluxio.client.block.stream.NettyPacketReader.Factory
Creates an instance of NettyPacketReader.Factory for block reads.
Factory(URI) - Constructor for class alluxio.master.journalv0.Journal.Factory
Creates a read-only journal factory with the specified base location.
Factory(URI) - Constructor for class alluxio.master.journalv0.MutableJournal.Factory
Creates a read-write journal factory with the specified base location.
Factory(TTransportFactory) - Constructor for class alluxio.network.thrift.BootstrapServerTransport.Factory
 
Factory() - Constructor for class alluxio.security.authentication.PlainSaslServer.Factory
Constructs a new PlainSaslServer.Factory for the PlainSaslServer.
Factory(TAsyncClientManager, TProtocolFactory) - Constructor for class alluxio.thrift.AlluxioService.AsyncClient.Factory
 
Factory() - Constructor for class alluxio.thrift.AlluxioService.Client.Factory
 
Factory(TAsyncClientManager, TProtocolFactory) - Constructor for class alluxio.thrift.BlockMasterClientService.AsyncClient.Factory
 
Factory() - Constructor for class alluxio.thrift.BlockMasterClientService.Client.Factory
 
Factory(TAsyncClientManager, TProtocolFactory) - Constructor for class alluxio.thrift.BlockMasterWorkerService.AsyncClient.Factory
 
Factory() - Constructor for class alluxio.thrift.BlockMasterWorkerService.Client.Factory
 
Factory(TAsyncClientManager, TProtocolFactory) - Constructor for class alluxio.thrift.BlockWorkerClientService.AsyncClient.Factory
 
Factory() - Constructor for class alluxio.thrift.BlockWorkerClientService.Client.Factory
 
Factory(TAsyncClientManager, TProtocolFactory) - Constructor for class alluxio.thrift.FileSystemMasterClientService.AsyncClient.Factory
 
Factory() - Constructor for class alluxio.thrift.FileSystemMasterClientService.Client.Factory
 
Factory(TAsyncClientManager, TProtocolFactory) - Constructor for class alluxio.thrift.FileSystemMasterWorkerService.AsyncClient.Factory
 
Factory() - Constructor for class alluxio.thrift.FileSystemMasterWorkerService.Client.Factory
 
Factory(TAsyncClientManager, TProtocolFactory) - Constructor for class alluxio.thrift.FileSystemWorkerClientService.AsyncClient.Factory
 
Factory() - Constructor for class alluxio.thrift.FileSystemWorkerClientService.Client.Factory
 
Factory(TAsyncClientManager, TProtocolFactory) - Constructor for class alluxio.thrift.KeyValueMasterClientService.AsyncClient.Factory
 
Factory() - Constructor for class alluxio.thrift.KeyValueMasterClientService.Client.Factory
 
Factory(TAsyncClientManager, TProtocolFactory) - Constructor for class alluxio.thrift.KeyValueWorkerClientService.AsyncClient.Factory
 
Factory() - Constructor for class alluxio.thrift.KeyValueWorkerClientService.Client.Factory
 
Factory(TAsyncClientManager, TProtocolFactory) - Constructor for class alluxio.thrift.LineageMasterClientService.AsyncClient.Factory
 
Factory() - Constructor for class alluxio.thrift.LineageMasterClientService.Client.Factory
 
Factory(TAsyncClientManager, TProtocolFactory) - Constructor for class alluxio.thrift.MetaMasterClientService.AsyncClient.Factory
 
Factory() - Constructor for class alluxio.thrift.MetaMasterClientService.Client.Factory
 
Factory(TAsyncClientManager, TProtocolFactory) - Constructor for class alluxio.thrift.MetaMasterMasterService.AsyncClient.Factory
 
Factory() - Constructor for class alluxio.thrift.MetaMasterMasterService.Client.Factory
 
Factory(TAsyncClientManager, TProtocolFactory) - Constructor for class alluxio.thrift.MetricsMasterClientService.AsyncClient.Factory
 
Factory() - Constructor for class alluxio.thrift.MetricsMasterClientService.Client.Factory
 
failed() - Static method in class alluxio.master.file.StartupConsistencyCheck
 
FAILED_PRECONDITION_VALUE - Static variable in enum alluxio.proto.status.Status.PStatus
FAILED_PRECONDITION = 9;
FailedPreconditionException - Exception in alluxio.exception.status
Exception indicating that operation was rejected because the system is not in a state required for the operation's execution.
FailedPreconditionException(String) - Constructor for exception alluxio.exception.status.FailedPreconditionException
 
FailedPreconditionException(Throwable) - Constructor for exception alluxio.exception.status.FailedPreconditionException
 
FailedPreconditionException(String, Throwable) - Constructor for exception alluxio.exception.status.FailedPreconditionException
 
FailedToCheckpointException - Exception in alluxio.exception
The exception thrown when Alluxio failed to create a checkpoint.
FailedToCheckpointException(String) - Constructor for exception alluxio.exception.FailedToCheckpointException
Constructs a new exception with the specified detail message.
FailedToCheckpointException(String, Throwable) - Constructor for exception alluxio.exception.FailedToCheckpointException
Constructs a new exception with the specified detail message and cause.
FailedToCheckpointException(ExceptionMessage, Object...) - Constructor for exception alluxio.exception.FailedToCheckpointException
Constructs a new exception with the specified exception message and multiple parameters.
FailedToCheckpointException(ExceptionMessage, Throwable, Object...) - Constructor for exception alluxio.exception.FailedToCheckpointException
Constructs a new exception with the specified exception message, the cause and multiple parameters.
fastCopy(ReadableByteChannel, WritableByteChannel) - Static method in class alluxio.util.io.BufferUtils
An efficient copy between two channels with a fixed-size buffer.
fatalError(Logger, String, Object...) - Static method in class alluxio.ProcessUtils
Logs a fatal error and then exits the system.
fatalError(Logger, Throwable, String, Object...) - Static method in class alluxio.ProcessUtils
Logs a fatal error and then exits the system.
FaultTolerantFileSystem - Class in alluxio.hadoop
Deprecated.
as of 1.6.0. Use AlluxioFileSystem instead and configure the fault tolerant options appropriately (alluxio.zookeeper.*). An Alluxio client API compatible with Apache Hadoop FileSystem interface. Any program working with Hadoop HDFS can work with Alluxio transparently. Note that the performance of using this fault tolerant API may not be as efficient as the performance of using the Alluxio native API defined in FileSystem, which the API is built on top of.

Unlike FileSystem, this class enables Zookeeper.

FaultTolerantFileSystem() - Constructor for class alluxio.hadoop.FaultTolerantFileSystem
Deprecated.
Constructs a new FaultTolerantFileSystem.
FaultTolerantFileSystem(FileSystem) - Constructor for class alluxio.hadoop.FaultTolerantFileSystem
Deprecated.
Constructs a new FaultTolerantFileSystem instance with a specified FileSystem handler for tests.
fieldForId(int) - Method in class alluxio.thrift.AccessBlockTOptions
 
fieldForId(int) - Method in class alluxio.thrift.AccessBlockTResponse
 
fieldForId(int) - Method in class alluxio.thrift.AlluxioService.getServiceVersion_args
 
fieldForId(int) - Method in class alluxio.thrift.AlluxioService.getServiceVersion_result
 
fieldForId(int) - Method in exception alluxio.thrift.AlluxioTException
 
fieldForId(int) - Method in class alluxio.thrift.BackupTOptions
 
fieldForId(int) - Method in class alluxio.thrift.BackupTResponse
 
fieldForId(int) - Method in class alluxio.thrift.BlockHeartbeatTOptions
 
fieldForId(int) - Method in class alluxio.thrift.BlockHeartbeatTResponse
 
fieldForId(int) - Method in class alluxio.thrift.BlockInfo
 
fieldForId(int) - Method in class alluxio.thrift.BlockLocation
 
fieldForId(int) - Method in class alluxio.thrift.BlockMasterClientService.getBlockInfo_args
 
fieldForId(int) - Method in class alluxio.thrift.BlockMasterClientService.getBlockInfo_result
 
fieldForId(int) - Method in class alluxio.thrift.BlockMasterClientService.getBlockMasterInfo_args
 
fieldForId(int) - Method in class alluxio.thrift.BlockMasterClientService.getBlockMasterInfo_result
 
fieldForId(int) - Method in class alluxio.thrift.BlockMasterClientService.getCapacityBytes_args
 
fieldForId(int) - Method in class alluxio.thrift.BlockMasterClientService.getCapacityBytes_result
 
fieldForId(int) - Method in class alluxio.thrift.BlockMasterClientService.getUsedBytes_args
 
fieldForId(int) - Method in class alluxio.thrift.BlockMasterClientService.getUsedBytes_result
 
fieldForId(int) - Method in class alluxio.thrift.BlockMasterClientService.getWorkerInfoList_args
 
fieldForId(int) - Method in class alluxio.thrift.BlockMasterClientService.getWorkerInfoList_result
 
fieldForId(int) - Method in class alluxio.thrift.BlockMasterClientService.getWorkerReport_args
 
fieldForId(int) - Method in class alluxio.thrift.BlockMasterClientService.getWorkerReport_result
 
fieldForId(int) - Method in class alluxio.thrift.BlockMasterInfo
 
fieldForId(int) - Method in class alluxio.thrift.BlockMasterWorkerService.blockHeartbeat_args
 
fieldForId(int) - Method in class alluxio.thrift.BlockMasterWorkerService.blockHeartbeat_result
 
fieldForId(int) - Method in class alluxio.thrift.BlockMasterWorkerService.commitBlock_args
 
fieldForId(int) - Method in class alluxio.thrift.BlockMasterWorkerService.commitBlock_result
 
fieldForId(int) - Method in class alluxio.thrift.BlockMasterWorkerService.getWorkerId_args
 
fieldForId(int) - Method in class alluxio.thrift.BlockMasterWorkerService.getWorkerId_result
 
fieldForId(int) - Method in class alluxio.thrift.BlockMasterWorkerService.registerWorker_args
 
fieldForId(int) - Method in class alluxio.thrift.BlockMasterWorkerService.registerWorker_result
 
fieldForId(int) - Method in class alluxio.thrift.BlockWorkerClientService.accessBlock_args
 
fieldForId(int) - Method in class alluxio.thrift.BlockWorkerClientService.accessBlock_result
 
fieldForId(int) - Method in class alluxio.thrift.BlockWorkerClientService.cacheBlock_args
 
fieldForId(int) - Method in class alluxio.thrift.BlockWorkerClientService.cacheBlock_result
 
fieldForId(int) - Method in class alluxio.thrift.BlockWorkerClientService.cancelBlock_args
 
fieldForId(int) - Method in class alluxio.thrift.BlockWorkerClientService.cancelBlock_result
 
fieldForId(int) - Method in class alluxio.thrift.BlockWorkerClientService.lockBlock_args
 
fieldForId(int) - Method in class alluxio.thrift.BlockWorkerClientService.lockBlock_result
 
fieldForId(int) - Method in class alluxio.thrift.BlockWorkerClientService.promoteBlock_args
 
fieldForId(int) - Method in class alluxio.thrift.BlockWorkerClientService.promoteBlock_result
 
fieldForId(int) - Method in class alluxio.thrift.BlockWorkerClientService.removeBlock_args
 
fieldForId(int) - Method in class alluxio.thrift.BlockWorkerClientService.removeBlock_result
 
fieldForId(int) - Method in class alluxio.thrift.BlockWorkerClientService.requestBlockLocation_args
 
fieldForId(int) - Method in class alluxio.thrift.BlockWorkerClientService.requestBlockLocation_result
 
fieldForId(int) - Method in class alluxio.thrift.BlockWorkerClientService.requestSpace_args
 
fieldForId(int) - Method in class alluxio.thrift.BlockWorkerClientService.requestSpace_result
 
fieldForId(int) - Method in class alluxio.thrift.BlockWorkerClientService.sessionBlockHeartbeat_args
 
fieldForId(int) - Method in class alluxio.thrift.BlockWorkerClientService.sessionBlockHeartbeat_result
 
fieldForId(int) - Method in class alluxio.thrift.BlockWorkerClientService.unlockBlock_args
 
fieldForId(int) - Method in class alluxio.thrift.BlockWorkerClientService.unlockBlock_result
 
fieldForId(int) - Method in class alluxio.thrift.CacheBlockTOptions
 
fieldForId(int) - Method in class alluxio.thrift.CacheBlockTResponse
 
fieldForId(int) - Method in class alluxio.thrift.CancelBlockTOptions
 
fieldForId(int) - Method in class alluxio.thrift.CancelBlockTResponse
 
fieldForId(int) - Method in class alluxio.thrift.CancelUfsFileTOptions
 
fieldForId(int) - Method in class alluxio.thrift.CancelUfsFileTResponse
 
fieldForId(int) - Method in class alluxio.thrift.CheckConsistencyTOptions
 
fieldForId(int) - Method in class alluxio.thrift.CheckConsistencyTResponse
 
fieldForId(int) - Method in class alluxio.thrift.CloseUfsFileTOptions
 
fieldForId(int) - Method in class alluxio.thrift.CloseUfsFileTResponse
 
fieldForId(int) - Method in class alluxio.thrift.Command
 
fieldForId(int) - Method in class alluxio.thrift.CommandLineJobInfo
 
fieldForId(int) - Method in class alluxio.thrift.CommitBlockTOptions
 
fieldForId(int) - Method in class alluxio.thrift.CommitBlockTResponse
 
fieldForId(int) - Method in class alluxio.thrift.CompleteFileTOptions
 
fieldForId(int) - Method in class alluxio.thrift.CompleteFileTResponse
 
fieldForId(int) - Method in class alluxio.thrift.CompletePartitionTOptions
 
fieldForId(int) - Method in class alluxio.thrift.CompletePartitionTResponse
 
fieldForId(int) - Method in class alluxio.thrift.CompleteStoreTOptions
 
fieldForId(int) - Method in class alluxio.thrift.CompleteStoreTResponse
 
fieldForId(int) - Method in class alluxio.thrift.CompleteUfsFileTOptions
 
fieldForId(int) - Method in class alluxio.thrift.CompleteUfsFileTReponse
 
fieldForId(int) - Method in class alluxio.thrift.ConfigCheckReport
 
fieldForId(int) - Method in class alluxio.thrift.ConfigProperty
 
fieldForId(int) - Method in class alluxio.thrift.CreateDirectoryTOptions
 
fieldForId(int) - Method in class alluxio.thrift.CreateDirectoryTResponse
 
fieldForId(int) - Method in class alluxio.thrift.CreateFileTOptions
 
fieldForId(int) - Method in class alluxio.thrift.CreateFileTResponse
 
fieldForId(int) - Method in class alluxio.thrift.CreateLineageTOptions
 
fieldForId(int) - Method in class alluxio.thrift.CreateLineageTResponse
 
fieldForId(int) - Method in class alluxio.thrift.CreateStoreTOptions
 
fieldForId(int) - Method in class alluxio.thrift.CreateStoreTResponse
 
fieldForId(int) - Method in class alluxio.thrift.CreateUfsFileTOptions
 
fieldForId(int) - Method in class alluxio.thrift.CreateUfsFileTResponse
 
fieldForId(int) - Method in class alluxio.thrift.DeleteLineageTOptions
 
fieldForId(int) - Method in class alluxio.thrift.DeleteLineageTResponse
 
fieldForId(int) - Method in class alluxio.thrift.DeleteStoreTOptions
 
fieldForId(int) - Method in class alluxio.thrift.DeleteStoreTResponse
 
fieldForId(int) - Method in class alluxio.thrift.DeleteTOptions
 
fieldForId(int) - Method in class alluxio.thrift.DeleteTResponse
 
fieldForId(int) - Method in class alluxio.thrift.DependencyInfo
 
fieldForId(int) - Method in class alluxio.thrift.FileBlockInfo
 
fieldForId(int) - Method in class alluxio.thrift.FileInfo
 
fieldForId(int) - Method in class alluxio.thrift.FileSystemCommand
 
fieldForId(int) - Method in class alluxio.thrift.FileSystemCommandOptions
 
fieldForId(int) - Method in class alluxio.thrift.FileSystemHeartbeatTOptions
 
fieldForId(int) - Method in class alluxio.thrift.FileSystemHeartbeatTResponse
 
fieldForId(int) - Method in class alluxio.thrift.FileSystemMasterClientService.checkConsistency_args
 
fieldForId(int) - Method in class alluxio.thrift.FileSystemMasterClientService.checkConsistency_result
 
fieldForId(int) - Method in class alluxio.thrift.FileSystemMasterClientService.completeFile_args
 
fieldForId(int) - Method in class alluxio.thrift.FileSystemMasterClientService.completeFile_result
 
fieldForId(int) - Method in class alluxio.thrift.FileSystemMasterClientService.createDirectory_args
 
fieldForId(int) - Method in class alluxio.thrift.FileSystemMasterClientService.createDirectory_result
 
fieldForId(int) - Method in class alluxio.thrift.FileSystemMasterClientService.createFile_args
 
fieldForId(int) - Method in class alluxio.thrift.FileSystemMasterClientService.createFile_result
 
fieldForId(int) - Method in class alluxio.thrift.FileSystemMasterClientService.free_args
 
fieldForId(int) - Method in class alluxio.thrift.FileSystemMasterClientService.free_result
 
fieldForId(int) - Method in class alluxio.thrift.FileSystemMasterClientService.getFilePath_args
 
fieldForId(int) - Method in class alluxio.thrift.FileSystemMasterClientService.getFilePath_result
 
fieldForId(int) - Method in class alluxio.thrift.FileSystemMasterClientService.getMountTable_args
 
fieldForId(int) - Method in class alluxio.thrift.FileSystemMasterClientService.getMountTable_result
 
fieldForId(int) - Method in class alluxio.thrift.FileSystemMasterClientService.getNewBlockIdForFile_args
 
fieldForId(int) - Method in class alluxio.thrift.FileSystemMasterClientService.getNewBlockIdForFile_result
 
fieldForId(int) - Method in class alluxio.thrift.FileSystemMasterClientService.getStatus_args
 
fieldForId(int) - Method in class alluxio.thrift.FileSystemMasterClientService.getStatus_result
 
fieldForId(int) - Method in class alluxio.thrift.FileSystemMasterClientService.listStatus_args
 
fieldForId(int) - Method in class alluxio.thrift.FileSystemMasterClientService.listStatus_result
 
fieldForId(int) - Method in class alluxio.thrift.FileSystemMasterClientService.loadMetadata_args
 
fieldForId(int) - Method in class alluxio.thrift.FileSystemMasterClientService.loadMetadata_result
 
fieldForId(int) - Method in class alluxio.thrift.FileSystemMasterClientService.mount_args
 
fieldForId(int) - Method in class alluxio.thrift.FileSystemMasterClientService.mount_result
 
fieldForId(int) - Method in class alluxio.thrift.FileSystemMasterClientService.remove_args
 
fieldForId(int) - Method in class alluxio.thrift.FileSystemMasterClientService.remove_result
 
fieldForId(int) - Method in class alluxio.thrift.FileSystemMasterClientService.rename_args
 
fieldForId(int) - Method in class alluxio.thrift.FileSystemMasterClientService.rename_result
 
fieldForId(int) - Method in class alluxio.thrift.FileSystemMasterClientService.scheduleAsyncPersistence_args
 
fieldForId(int) - Method in class alluxio.thrift.FileSystemMasterClientService.scheduleAsyncPersistence_result
 
fieldForId(int) - Method in class alluxio.thrift.FileSystemMasterClientService.setAttribute_args
 
fieldForId(int) - Method in class alluxio.thrift.FileSystemMasterClientService.setAttribute_result
 
fieldForId(int) - Method in class alluxio.thrift.FileSystemMasterClientService.unmount_args
 
fieldForId(int) - Method in class alluxio.thrift.FileSystemMasterClientService.unmount_result
 
fieldForId(int) - Method in class alluxio.thrift.FileSystemMasterClientService.updateUfsMode_args
 
fieldForId(int) - Method in class alluxio.thrift.FileSystemMasterClientService.updateUfsMode_result
 
fieldForId(int) - Method in class alluxio.thrift.FileSystemMasterCommonTOptions
 
fieldForId(int) - Method in class alluxio.thrift.FileSystemMasterWorkerService.fileSystemHeartbeat_args
 
fieldForId(int) - Method in class alluxio.thrift.FileSystemMasterWorkerService.fileSystemHeartbeat_result
 
fieldForId(int) - Method in class alluxio.thrift.FileSystemMasterWorkerService.getFileInfo_args
 
fieldForId(int) - Method in class alluxio.thrift.FileSystemMasterWorkerService.getFileInfo_result
 
fieldForId(int) - Method in class alluxio.thrift.FileSystemMasterWorkerService.getPinnedFileIds_args
 
fieldForId(int) - Method in class alluxio.thrift.FileSystemMasterWorkerService.getPinnedFileIds_result
 
fieldForId(int) - Method in class alluxio.thrift.FileSystemMasterWorkerService.getUfsInfo_args
 
fieldForId(int) - Method in class alluxio.thrift.FileSystemMasterWorkerService.getUfsInfo_result
 
fieldForId(int) - Method in class alluxio.thrift.FileSystemWorkerClientService.cancelUfsFile_args
 
fieldForId(int) - Method in class alluxio.thrift.FileSystemWorkerClientService.cancelUfsFile_result
 
fieldForId(int) - Method in class alluxio.thrift.FileSystemWorkerClientService.closeUfsFile_args
 
fieldForId(int) - Method in class alluxio.thrift.FileSystemWorkerClientService.closeUfsFile_result
 
fieldForId(int) - Method in class alluxio.thrift.FileSystemWorkerClientService.completeUfsFile_args
 
fieldForId(int) - Method in class alluxio.thrift.FileSystemWorkerClientService.completeUfsFile_result
 
fieldForId(int) - Method in class alluxio.thrift.FileSystemWorkerClientService.createUfsFile_args
 
fieldForId(int) - Method in class alluxio.thrift.FileSystemWorkerClientService.createUfsFile_result
 
fieldForId(int) - Method in class alluxio.thrift.FileSystemWorkerClientService.openUfsFile_args
 
fieldForId(int) - Method in class alluxio.thrift.FileSystemWorkerClientService.openUfsFile_result
 
fieldForId(int) - Method in class alluxio.thrift.FileSystemWorkerClientService.sessionFileSystemHeartbeat_args
 
fieldForId(int) - Method in class alluxio.thrift.FileSystemWorkerClientService.sessionFileSystemHeartbeat_result
 
fieldForId(int) - Method in class alluxio.thrift.FreeTOptions
 
fieldForId(int) - Method in class alluxio.thrift.FreeTResponse
 
fieldForId(int) - Method in class alluxio.thrift.GetBlockInfoTOptions
 
fieldForId(int) - Method in class alluxio.thrift.GetBlockInfoTResponse
 
fieldForId(int) - Method in class alluxio.thrift.GetBlockMasterInfoTOptions
 
fieldForId(int) - Method in class alluxio.thrift.GetBlockMasterInfoTResponse
 
fieldForId(int) - Method in class alluxio.thrift.GetCapacityBytesTOptions
 
fieldForId(int) - Method in class alluxio.thrift.GetCapacityBytesTResponse
 
fieldForId(int) - Method in class alluxio.thrift.GetConfigReportTOptions
 
fieldForId(int) - Method in class alluxio.thrift.GetConfigReportTResponse
 
fieldForId(int) - Method in class alluxio.thrift.GetConfigurationTOptions
 
fieldForId(int) - Method in class alluxio.thrift.GetConfigurationTResponse
 
fieldForId(int) - Method in class alluxio.thrift.GetFileInfoTOptions
 
fieldForId(int) - Method in class alluxio.thrift.GetFileInfoTResponse
 
fieldForId(int) - Method in class alluxio.thrift.GetFilePathTOptions
 
fieldForId(int) - Method in class alluxio.thrift.GetFilePathTResponse
 
fieldForId(int) - Method in class alluxio.thrift.GetLineageInfoListTOptions
 
fieldForId(int) - Method in class alluxio.thrift.GetLineageInfoListTResponse
 
fieldForId(int) - Method in class alluxio.thrift.GetMasterIdTOptions
 
fieldForId(int) - Method in class alluxio.thrift.GetMasterIdTResponse
 
fieldForId(int) - Method in class alluxio.thrift.GetMasterInfoTOptions
 
fieldForId(int) - Method in class alluxio.thrift.GetMasterInfoTResponse
 
fieldForId(int) - Method in class alluxio.thrift.GetMetricsTOptions
 
fieldForId(int) - Method in class alluxio.thrift.GetMetricsTResponse
 
fieldForId(int) - Method in class alluxio.thrift.GetMountTableTResponse
 
fieldForId(int) - Method in class alluxio.thrift.GetNewBlockIdForFileTOptions
 
fieldForId(int) - Method in class alluxio.thrift.GetNewBlockIdForFileTResponse
 
fieldForId(int) - Method in class alluxio.thrift.GetNextKeysTOptions
 
fieldForId(int) - Method in class alluxio.thrift.GetNextKeysTResponse
 
fieldForId(int) - Method in class alluxio.thrift.GetPartitionInfoTOptions
 
fieldForId(int) - Method in class alluxio.thrift.GetPartitionInfoTResponse
 
fieldForId(int) - Method in class alluxio.thrift.GetPinnedFileIdsTOptions
 
fieldForId(int) - Method in class alluxio.thrift.GetPinnedFileIdsTResponse
 
fieldForId(int) - Method in class alluxio.thrift.GetServiceVersionTOptions
 
fieldForId(int) - Method in class alluxio.thrift.GetServiceVersionTResponse
 
fieldForId(int) - Method in class alluxio.thrift.GetSizeTOptions
 
fieldForId(int) - Method in class alluxio.thrift.GetSizeTResponse
 
fieldForId(int) - Method in class alluxio.thrift.GetStatusTOptions
 
fieldForId(int) - Method in class alluxio.thrift.GetStatusTResponse
 
fieldForId(int) - Method in class alluxio.thrift.GetTOptions
 
fieldForId(int) - Method in class alluxio.thrift.GetTResponse
 
fieldForId(int) - Method in class alluxio.thrift.GetUfsInfoTOptions
 
fieldForId(int) - Method in class alluxio.thrift.GetUfsInfoTResponse
 
fieldForId(int) - Method in class alluxio.thrift.GetUsedBytesTOptions
 
fieldForId(int) - Method in class alluxio.thrift.GetUsedBytesTResponse
 
fieldForId(int) - Method in class alluxio.thrift.GetWorkerIdTOptions
 
fieldForId(int) - Method in class alluxio.thrift.GetWorkerIdTResponse
 
fieldForId(int) - Method in class alluxio.thrift.GetWorkerInfoListTOptions
 
fieldForId(int) - Method in class alluxio.thrift.GetWorkerInfoListTResponse
 
fieldForId(int) - Method in class alluxio.thrift.GetWorkerReportTOptions
 
fieldForId(int) - Method in class alluxio.thrift.InconsistentProperty
 
fieldForId(int) - Method in class alluxio.thrift.JobConfInfo
 
fieldForId(int) - Method in class alluxio.thrift.KeyValueMasterClientService.completePartition_args
 
fieldForId(int) - Method in class alluxio.thrift.KeyValueMasterClientService.completePartition_result
 
fieldForId(int) - Method in class alluxio.thrift.KeyValueMasterClientService.completeStore_args
 
fieldForId(int) - Method in class alluxio.thrift.KeyValueMasterClientService.completeStore_result
 
fieldForId(int) - Method in class alluxio.thrift.KeyValueMasterClientService.createStore_args
 
fieldForId(int) - Method in class alluxio.thrift.KeyValueMasterClientService.createStore_result
 
fieldForId(int) - Method in class alluxio.thrift.KeyValueMasterClientService.deleteStore_args
 
fieldForId(int) - Method in class alluxio.thrift.KeyValueMasterClientService.deleteStore_result
 
fieldForId(int) - Method in class alluxio.thrift.KeyValueMasterClientService.getPartitionInfo_args
 
fieldForId(int) - Method in class alluxio.thrift.KeyValueMasterClientService.getPartitionInfo_result
 
fieldForId(int) - Method in class alluxio.thrift.KeyValueMasterClientService.mergeStore_args
 
fieldForId(int) - Method in class alluxio.thrift.KeyValueMasterClientService.mergeStore_result
 
fieldForId(int) - Method in class alluxio.thrift.KeyValueMasterClientService.renameStore_args
 
fieldForId(int) - Method in class alluxio.thrift.KeyValueMasterClientService.renameStore_result
 
fieldForId(int) - Method in class alluxio.thrift.KeyValueWorkerClientService.get_args
 
fieldForId(int) - Method in class alluxio.thrift.KeyValueWorkerClientService.get_result
 
fieldForId(int) - Method in class alluxio.thrift.KeyValueWorkerClientService.getNextKeys_args
 
fieldForId(int) - Method in class alluxio.thrift.KeyValueWorkerClientService.getNextKeys_result
 
fieldForId(int) - Method in class alluxio.thrift.KeyValueWorkerClientService.getSize_args
 
fieldForId(int) - Method in class alluxio.thrift.KeyValueWorkerClientService.getSize_result
 
fieldForId(int) - Method in class alluxio.thrift.LineageInfo
 
fieldForId(int) - Method in class alluxio.thrift.LineageMasterClientService.createLineage_args
 
fieldForId(int) - Method in class alluxio.thrift.LineageMasterClientService.createLineage_result
 
fieldForId(int) - Method in class alluxio.thrift.LineageMasterClientService.deleteLineage_args
 
fieldForId(int) - Method in class alluxio.thrift.LineageMasterClientService.deleteLineage_result
 
fieldForId(int) - Method in class alluxio.thrift.LineageMasterClientService.getLineageInfoList_args
 
fieldForId(int) - Method in class alluxio.thrift.LineageMasterClientService.getLineageInfoList_result
 
fieldForId(int) - Method in class alluxio.thrift.LineageMasterClientService.reinitializeFile_args
 
fieldForId(int) - Method in class alluxio.thrift.LineageMasterClientService.reinitializeFile_result
 
fieldForId(int) - Method in class alluxio.thrift.LineageMasterClientService.reportLostFile_args
 
fieldForId(int) - Method in class alluxio.thrift.LineageMasterClientService.reportLostFile_result
 
fieldForId(int) - Method in class alluxio.thrift.ListStatusTOptions
 
fieldForId(int) - Method in class alluxio.thrift.ListStatusTResponse
 
fieldForId(int) - Method in class alluxio.thrift.LoadMetadataTOptions
 
fieldForId(int) - Method in class alluxio.thrift.LoadMetadataTResponse
 
fieldForId(int) - Method in class alluxio.thrift.LocalityTier
 
fieldForId(int) - Method in class alluxio.thrift.LockBlockTOptions
 
fieldForId(int) - Method in class alluxio.thrift.LockBlockTResponse
 
fieldForId(int) - Method in class alluxio.thrift.MasterHeartbeatTOptions
 
fieldForId(int) - Method in class alluxio.thrift.MasterHeartbeatTResponse
 
fieldForId(int) - Method in class alluxio.thrift.MasterInfo
 
fieldForId(int) - Method in class alluxio.thrift.MasterNetAddress
 
fieldForId(int) - Method in class alluxio.thrift.MergeStoreTOptions
 
fieldForId(int) - Method in class alluxio.thrift.MergeStoreTResponse
 
fieldForId(int) - Method in class alluxio.thrift.MetaMasterClientService.backup_args
 
fieldForId(int) - Method in class alluxio.thrift.MetaMasterClientService.backup_result
 
fieldForId(int) - Method in class alluxio.thrift.MetaMasterClientService.getConfigReport_args
 
fieldForId(int) - Method in class alluxio.thrift.MetaMasterClientService.getConfigReport_result
 
fieldForId(int) - Method in class alluxio.thrift.MetaMasterClientService.getConfiguration_args
 
fieldForId(int) - Method in class alluxio.thrift.MetaMasterClientService.getConfiguration_result
 
fieldForId(int) - Method in class alluxio.thrift.MetaMasterClientService.getMasterInfo_args
 
fieldForId(int) - Method in class alluxio.thrift.MetaMasterClientService.getMasterInfo_result
 
fieldForId(int) - Method in class alluxio.thrift.MetaMasterClientService.getMetrics_args
 
fieldForId(int) - Method in class alluxio.thrift.MetaMasterClientService.getMetrics_result
 
fieldForId(int) - Method in class alluxio.thrift.MetaMasterMasterService.getMasterId_args
 
fieldForId(int) - Method in class alluxio.thrift.MetaMasterMasterService.getMasterId_result
 
fieldForId(int) - Method in class alluxio.thrift.MetaMasterMasterService.masterHeartbeat_args
 
fieldForId(int) - Method in class alluxio.thrift.MetaMasterMasterService.masterHeartbeat_result
 
fieldForId(int) - Method in class alluxio.thrift.MetaMasterMasterService.registerMaster_args
 
fieldForId(int) - Method in class alluxio.thrift.MetaMasterMasterService.registerMaster_result
 
fieldForId(int) - Method in class alluxio.thrift.Metric
 
fieldForId(int) - Method in class alluxio.thrift.MetricsHeartbeatTOptions
 
fieldForId(int) - Method in class alluxio.thrift.MetricsHeartbeatTResponse
 
fieldForId(int) - Method in class alluxio.thrift.MetricsMasterClientService.metricsHeartbeat_args
 
fieldForId(int) - Method in class alluxio.thrift.MetricsMasterClientService.metricsHeartbeat_result
 
fieldForId(int) - Method in class alluxio.thrift.MetricValue
 
fieldForId(int) - Method in class alluxio.thrift.MountPointInfo
 
fieldForId(int) - Method in class alluxio.thrift.MountTOptions
 
fieldForId(int) - Method in class alluxio.thrift.MountTResponse
 
fieldForId(int) - Method in class alluxio.thrift.OpenUfsFileTOptions
 
fieldForId(int) - Method in class alluxio.thrift.OpenUfsFileTResponse
 
fieldForId(int) - Method in class alluxio.thrift.OptionalString
 
fieldForId(int) - Method in class alluxio.thrift.PartitionInfo
 
fieldForId(int) - Method in class alluxio.thrift.PersistCommandOptions
 
fieldForId(int) - Method in class alluxio.thrift.PersistFile
 
fieldForId(int) - Method in class alluxio.thrift.PromoteBlockTOptions
 
fieldForId(int) - Method in class alluxio.thrift.PromoteBlockTResponse
 
fieldForId(int) - Method in class alluxio.thrift.RegisterMasterTOptions
 
fieldForId(int) - Method in class alluxio.thrift.RegisterMasterTResponse
 
fieldForId(int) - Method in class alluxio.thrift.RegisterWorkerTOptions
 
fieldForId(int) - Method in class alluxio.thrift.RegisterWorkerTResponse
 
fieldForId(int) - Method in class alluxio.thrift.ReinitializeFileTOptions
 
fieldForId(int) - Method in class alluxio.thrift.ReinitializeFileTResponse
 
fieldForId(int) - Method in class alluxio.thrift.RemoveBlockTOptions
 
fieldForId(int) - Method in class alluxio.thrift.RemoveBlockTResponse
 
fieldForId(int) - Method in class alluxio.thrift.RenameStoreTOptions
 
fieldForId(int) - Method in class alluxio.thrift.RenameStoreTResponse
 
fieldForId(int) - Method in class alluxio.thrift.RenameTOptions
 
fieldForId(int) - Method in class alluxio.thrift.RenameTResponse
 
fieldForId(int) - Method in class alluxio.thrift.ReportLostFileTOptions
 
fieldForId(int) - Method in class alluxio.thrift.ReportLostFileTResponse
 
fieldForId(int) - Method in class alluxio.thrift.RequestBlockLocationTOptions
 
fieldForId(int) - Method in class alluxio.thrift.RequestBlockLocationTResponse
 
fieldForId(int) - Method in class alluxio.thrift.RequestSpaceTOptions
 
fieldForId(int) - Method in class alluxio.thrift.RequestSpaceTResponse
 
fieldForId(int) - Method in class alluxio.thrift.ScheduleAsyncPersistenceTOptions
 
fieldForId(int) - Method in class alluxio.thrift.ScheduleAsyncPersistenceTResponse
 
fieldForId(int) - Method in class alluxio.thrift.SessionBlockHeartbeatTOptions
 
fieldForId(int) - Method in class alluxio.thrift.SessionBlockHeartbeatTResponse
 
fieldForId(int) - Method in class alluxio.thrift.SessionFileSystemHeartbeatTOptions
 
fieldForId(int) - Method in class alluxio.thrift.SessionFileSystemHeartbeatTResponse
 
fieldForId(int) - Method in class alluxio.thrift.SetAttributeTOptions
 
fieldForId(int) - Method in class alluxio.thrift.SetAttributeTResponse
 
fieldForId(int) - Method in class alluxio.thrift.SyncMetadataTOptions
 
fieldForId(int) - Method in class alluxio.thrift.SyncMetadataTResponse
 
fieldForId(int) - Method in class alluxio.thrift.TieredIdentity
 
fieldForId(int) - Method in class alluxio.thrift.UfsInfo
 
fieldForId(int) - Method in class alluxio.thrift.UnlockBlockTOptions
 
fieldForId(int) - Method in class alluxio.thrift.UnlockBlockTResponse
 
fieldForId(int) - Method in class alluxio.thrift.UnmountTOptions
 
fieldForId(int) - Method in class alluxio.thrift.UnmountTResponse
 
fieldForId(int) - Method in class alluxio.thrift.UpdateUfsModeTOptions
 
fieldForId(int) - Method in class alluxio.thrift.UpdateUfsModeTResponse
 
fieldForId(int) - Method in class alluxio.thrift.WorkerInfo
 
fieldForId(int) - Method in class alluxio.thrift.WorkerNetAddress
 
FieldIndex<T> - Interface in alluxio.collections
An interface representing an index for IndexedSet, each index for this set must implement the interface to define how to get the value of the field chosen as the index.
File - Class in alluxio.proto.journal
 
File.AddMountPointEntry - Class in alluxio.proto.journal
Protobuf type alluxio.proto.journal.AddMountPointEntry
File.AddMountPointEntry.Builder - Class in alluxio.proto.journal
Protobuf type alluxio.proto.journal.AddMountPointEntry
File.AddMountPointEntryOrBuilder - Interface in alluxio.proto.journal
 
File.AsyncPersistRequestEntry - Class in alluxio.proto.journal
Protobuf type alluxio.proto.journal.AsyncPersistRequestEntry
File.AsyncPersistRequestEntry.Builder - Class in alluxio.proto.journal
Protobuf type alluxio.proto.journal.AsyncPersistRequestEntry
File.AsyncPersistRequestEntryOrBuilder - Interface in alluxio.proto.journal
 
File.CompleteFileEntry - Class in alluxio.proto.journal
Protobuf type alluxio.proto.journal.CompleteFileEntry
File.CompleteFileEntry.Builder - Class in alluxio.proto.journal
Protobuf type alluxio.proto.journal.CompleteFileEntry
File.CompleteFileEntryOrBuilder - Interface in alluxio.proto.journal
 
File.DeleteFileEntry - Class in alluxio.proto.journal
Protobuf type alluxio.proto.journal.DeleteFileEntry
File.DeleteFileEntry.Builder - Class in alluxio.proto.journal
Protobuf type alluxio.proto.journal.DeleteFileEntry
File.DeleteFileEntryOrBuilder - Interface in alluxio.proto.journal
 
File.DeleteMountPointEntry - Class in alluxio.proto.journal
Protobuf type alluxio.proto.journal.DeleteMountPointEntry
File.DeleteMountPointEntry.Builder - Class in alluxio.proto.journal
Protobuf type alluxio.proto.journal.DeleteMountPointEntry
File.DeleteMountPointEntryOrBuilder - Interface in alluxio.proto.journal
 
File.InodeDirectoryEntry - Class in alluxio.proto.journal
Protobuf type alluxio.proto.journal.InodeDirectoryEntry
File.InodeDirectoryEntry.Builder - Class in alluxio.proto.journal
Protobuf type alluxio.proto.journal.InodeDirectoryEntry
File.InodeDirectoryEntryOrBuilder - Interface in alluxio.proto.journal
 
File.InodeDirectoryIdGeneratorEntry - Class in alluxio.proto.journal
Protobuf type alluxio.proto.journal.InodeDirectoryIdGeneratorEntry
File.InodeDirectoryIdGeneratorEntry.Builder - Class in alluxio.proto.journal
Protobuf type alluxio.proto.journal.InodeDirectoryIdGeneratorEntry
File.InodeDirectoryIdGeneratorEntryOrBuilder - Interface in alluxio.proto.journal
 
File.InodeFileEntry - Class in alluxio.proto.journal
Protobuf type alluxio.proto.journal.InodeFileEntry
File.InodeFileEntry.Builder - Class in alluxio.proto.journal
Protobuf type alluxio.proto.journal.InodeFileEntry
File.InodeFileEntryOrBuilder - Interface in alluxio.proto.journal
 
File.InodeLastModificationTimeEntry - Class in alluxio.proto.journal
Protobuf type alluxio.proto.journal.InodeLastModificationTimeEntry
File.InodeLastModificationTimeEntry.Builder - Class in alluxio.proto.journal
Protobuf type alluxio.proto.journal.InodeLastModificationTimeEntry
File.InodeLastModificationTimeEntryOrBuilder - Interface in alluxio.proto.journal
 
File.PersistDirectoryEntry - Class in alluxio.proto.journal
Protobuf type alluxio.proto.journal.PersistDirectoryEntry
File.PersistDirectoryEntry.Builder - Class in alluxio.proto.journal
Protobuf type alluxio.proto.journal.PersistDirectoryEntry
File.PersistDirectoryEntryOrBuilder - Interface in alluxio.proto.journal
 
File.PersistFileEntry - Class in alluxio.proto.journal
Protobuf type alluxio.proto.journal.PersistFileEntry
File.PersistFileEntry.Builder - Class in alluxio.proto.journal
Protobuf type alluxio.proto.journal.PersistFileEntry
File.PersistFileEntryOrBuilder - Interface in alluxio.proto.journal
 
File.PTtlAction - Enum in alluxio.proto.journal
Protobuf enum alluxio.proto.journal.PTtlAction
File.ReinitializeFileEntry - Class in alluxio.proto.journal
Protobuf type alluxio.proto.journal.ReinitializeFileEntry
File.ReinitializeFileEntry.Builder - Class in alluxio.proto.journal
Protobuf type alluxio.proto.journal.ReinitializeFileEntry
File.ReinitializeFileEntryOrBuilder - Interface in alluxio.proto.journal
 
File.RenameEntry - Class in alluxio.proto.journal
Protobuf type alluxio.proto.journal.RenameEntry
File.RenameEntry.Builder - Class in alluxio.proto.journal
Protobuf type alluxio.proto.journal.RenameEntry
File.RenameEntryOrBuilder - Interface in alluxio.proto.journal
 
File.SetAttributeEntry - Class in alluxio.proto.journal
Protobuf type alluxio.proto.journal.SetAttributeEntry
File.SetAttributeEntry.Builder - Class in alluxio.proto.journal
Protobuf type alluxio.proto.journal.SetAttributeEntry
File.SetAttributeEntryOrBuilder - Interface in alluxio.proto.journal
 
File.StringPairEntry - Class in alluxio.proto.journal
Protobuf type alluxio.proto.journal.StringPairEntry
File.StringPairEntry.Builder - Class in alluxio.proto.journal
Protobuf type alluxio.proto.journal.StringPairEntry
File.StringPairEntryOrBuilder - Interface in alluxio.proto.journal
 
File.UfsMode - Enum in alluxio.proto.journal
Protobuf enum alluxio.proto.journal.UfsMode
File.UpdateUfsModeEntry - Class in alluxio.proto.journal
Protobuf type alluxio.proto.journal.UpdateUfsModeEntry
File.UpdateUfsModeEntry.Builder - Class in alluxio.proto.journal
Protobuf type alluxio.proto.journal.UpdateUfsModeEntry
File.UpdateUfsModeEntryOrBuilder - Interface in alluxio.proto.journal
 
FILE_BLOCK_INFOS_GOT - Static variable in class alluxio.metrics.MasterMetrics
 
FILE_DIR_PERMISSION_DIFF - Static variable in class alluxio.Constants
 
FILE_ID_FIELD_NUMBER - Static variable in class alluxio.proto.journal.File.AsyncPersistRequestEntry
 
FILE_INFOS_GOT - Static variable in class alluxio.metrics.MasterMetrics
 
FILE_SYSTEM_MASTER_CLIENT_SERVICE_NAME - Static variable in class alluxio.Constants
 
FILE_SYSTEM_MASTER_CLIENT_SERVICE_VERSION - Static variable in class alluxio.Constants
 
FILE_SYSTEM_MASTER_NAME - Static variable in class alluxio.Constants
 
FILE_SYSTEM_MASTER_WORKER_SERVICE_NAME - Static variable in class alluxio.Constants
 
FILE_SYSTEM_MASTER_WORKER_SERVICE_VERSION - Static variable in class alluxio.Constants
 
FILE_SYSTEM_SERVLET_RESOURCE_KEY - Static variable in class alluxio.web.ProxyWebServer
 
FILE_SYSTEM_WORKER_CLIENT_SERVICE_NAME - Static variable in class alluxio.Constants
 
FILE_SYSTEM_WORKER_CLIENT_SERVICE_VERSION - Static variable in class alluxio.Constants
 
FILE_SYSTEM_WORKER_NAME - Static variable in class alluxio.Constants
 
FileAlreadyCompletedException - Exception in alluxio.exception
The exception thrown when a file is already completed in Alluxio.
FileAlreadyCompletedException(String) - Constructor for exception alluxio.exception.FileAlreadyCompletedException
Constructs a new exception with the specified detail message.
FileAlreadyCompletedException(String, Throwable) - Constructor for exception alluxio.exception.FileAlreadyCompletedException
Constructs a new exception with the specified detail message and cause.
FileAlreadyCompletedException(ExceptionMessage, Object...) - Constructor for exception alluxio.exception.FileAlreadyCompletedException
Constructs a new exception with the specified exception message and multiple parameters.
FileAlreadyCompletedException(ExceptionMessage, Throwable, Object...) - Constructor for exception alluxio.exception.FileAlreadyCompletedException
Constructs a new exception with the specified exception message, the cause and multiple parameters.
FileAlreadyExistsException - Exception in alluxio.exception
The exception thrown when a file already exists in Alluxio.
FileAlreadyExistsException(String) - Constructor for exception alluxio.exception.FileAlreadyExistsException
Constructs a new exception with the specified detail message.
FileAlreadyExistsException(String, Throwable) - Constructor for exception alluxio.exception.FileAlreadyExistsException
Constructs a new exception with the specified detail message and cause.
FileAlreadyExistsException(ExceptionMessage, Object...) - Constructor for exception alluxio.exception.FileAlreadyExistsException
Constructs a new exception with the specified exception message and multiple parameters.
FileAlreadyExistsException(ExceptionMessage, Throwable, Object...) - Constructor for exception alluxio.exception.FileAlreadyExistsException
Constructs a new exception with the specified exception message, the cause and multiple parameters.
FileAlreadyExistsException(AlluxioURI) - Constructor for exception alluxio.exception.FileAlreadyExistsException
Constructs a new exception reporting that the given path already exists.
FileBlockInfo - Class in alluxio.thrift
 
FileBlockInfo() - Constructor for class alluxio.thrift.FileBlockInfo
 
FileBlockInfo(BlockInfo, long, List<WorkerNetAddress>, List<String>) - Constructor for class alluxio.thrift.FileBlockInfo
 
FileBlockInfo(FileBlockInfo) - Constructor for class alluxio.thrift.FileBlockInfo
Performs a deep copy on other.
FileBlockInfo - Class in alluxio.wire
The file block information.
FileBlockInfo() - Constructor for class alluxio.wire.FileBlockInfo
Creates a new instance of FileBlockInfo.
FileBlockInfo._Fields - Enum in alluxio.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
FileDataManager - Class in alluxio.worker.file
Responsible for storing files into under file system.
FileDataManager(BlockWorker, RateLimiter, UfsManager) - Constructor for class alluxio.worker.file.FileDataManager
Creates a new instance of FileDataManager.
FileDataManager.PersistedFilesInfo - Class in alluxio.worker.file
Information about persisted files.
FileDoesNotExistException - Exception in alluxio.exception
The exception thrown when a path does not exist in Alluxio.
FileDoesNotExistException(String) - Constructor for exception alluxio.exception.FileDoesNotExistException
Constructs a new exception with the specified detail message.
FileDoesNotExistException(String, Throwable) - Constructor for exception alluxio.exception.FileDoesNotExistException
Constructs a new exception with the specified detail message and cause.
FileDoesNotExistException(ExceptionMessage, Object...) - Constructor for exception alluxio.exception.FileDoesNotExistException
Constructs a new exception with the specified exception message and multiple parameters.
FileDoesNotExistException(ExceptionMessage, Throwable, Object...) - Constructor for exception alluxio.exception.FileDoesNotExistException
Constructs a new exception with the specified exception message, the cause and multiple parameters.
FileDoesNotExistException(AlluxioURI) - Constructor for exception alluxio.exception.FileDoesNotExistException
Constructs a new exception stating that the given path does not exist.
fileIdFromBlockId(long) - Static method in class alluxio.util.IdUtils
Creates a file ID from a block ID.
FileInfo - Class in alluxio.thrift
 
FileInfo() - Constructor for class alluxio.thrift.FileInfo
 
FileInfo(long, String, String, String, long, long, long, boolean, boolean, boolean, boolean, boolean, List<Long>, int, long, long, String, String, int, String, boolean, List<FileBlockInfo>, TTtlAction, long, int, String) - Constructor for class alluxio.thrift.FileInfo
 
FileInfo(FileInfo) - Constructor for class alluxio.thrift.FileInfo
Performs a deep copy on other.
FileInfo - Class in alluxio.wire
The file information.
FileInfo() - Constructor for class alluxio.wire.FileInfo
Creates a new instance of FileInfo.
FileInfo._Fields - Enum in alluxio.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
FileInfoCommand - Class in alluxio.cli.fs.command
Deprecated.
since version 1.5
FileInfoCommand(FileSystem) - Constructor for class alluxio.cli.fs.command.FileInfoCommand
Deprecated.
 
FileInStream - Class in alluxio.client.file
A streaming API to read a file.
FileInStream(URIStatus, InStreamOptions, FileSystemContext) - Constructor for class alluxio.client.file.FileInStream
 
FileLocationOptions - Class in alluxio.underfs.options
Method options for file locations in UnderFileSystem.
FileOutStream - Class in alluxio.client.file
Provides a streaming API to write a file.
FileOutStream(AlluxioURI, OutStreamOptions, FileSystemContext) - Constructor for class alluxio.client.file.FileOutStream
Creates a new file output stream.
FILES_COMPLETED - Static variable in class alluxio.metrics.MasterMetrics
 
FILES_CREATED - Static variable in class alluxio.metrics.MasterMetrics
 
FILES_FREED - Static variable in class alluxio.metrics.MasterMetrics
 
FILES_PERSISTED - Static variable in class alluxio.metrics.MasterMetrics
 
FILES_PINNED - Static variable in class alluxio.metrics.MasterMetrics
 
FileSystem - Interface in alluxio.client.file
Basic file system interface supporting metadata operations and data operations.
FileSystem - Class in alluxio.hadoop
An Alluxio client API compatible with Apache Hadoop FileSystem interface.
FileSystem() - Constructor for class alluxio.hadoop.FileSystem
Constructs a new FileSystem.
FileSystem(FileSystem) - Constructor for class alluxio.hadoop.FileSystem
Constructs a new FileSystem instance with a specified FileSystem handler for tests.
FileSystem.Factory - Class in alluxio.client.file
Factory for FileSystem.
FileSystemAdminShell - Class in alluxio.cli.fsadmin
Shell for admin to manage file system.
FileSystemAdminShell() - Constructor for class alluxio.cli.fsadmin.FileSystemAdminShell
Construct a new instance of FileSystemAdminShell.
FileSystemAdminShellUtils - Class in alluxio.cli.fsadmin
Class for convenience methods used by FileSystemAdminShell.
FileSystemCommand - Class in alluxio.thrift
 
FileSystemCommand() - Constructor for class alluxio.thrift.FileSystemCommand
 
FileSystemCommand(CommandType, FileSystemCommandOptions) - Constructor for class alluxio.thrift.FileSystemCommand
 
FileSystemCommand(FileSystemCommand) - Constructor for class alluxio.thrift.FileSystemCommand
Performs a deep copy on other.
FileSystemCommand._Fields - Enum in alluxio.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
FileSystemCommandOptions - Class in alluxio.thrift
 
FileSystemCommandOptions() - Constructor for class alluxio.thrift.FileSystemCommandOptions
 
FileSystemCommandOptions(FileSystemCommandOptions._Fields, Object) - Constructor for class alluxio.thrift.FileSystemCommandOptions
 
FileSystemCommandOptions(FileSystemCommandOptions) - Constructor for class alluxio.thrift.FileSystemCommandOptions
 
FileSystemCommandOptions._Fields - Enum in alluxio.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
FileSystemCommandUtils - Class in alluxio.cli.fs.command
Common util methods for executing commands.
FileSystemContext - Class in alluxio.client.file
A shared context that isolates all operations within a FileSystem.
fileSystemHeartbeat(long, List<Long>, FileSystemHeartbeatTOptions) - Method in class alluxio.master.file.FileSystemMasterWorkerServiceHandler
 
fileSystemHeartbeat(long, List<Long>, FileSystemHeartbeatTOptions, AsyncMethodCallback) - Method in class alluxio.thrift.FileSystemMasterWorkerService.AsyncClient
 
fileSystemHeartbeat(long, List<Long>, FileSystemHeartbeatTOptions, AsyncMethodCallback) - Method in interface alluxio.thrift.FileSystemMasterWorkerService.AsyncIface
 
fileSystemHeartbeat() - Constructor for class alluxio.thrift.FileSystemMasterWorkerService.AsyncProcessor.fileSystemHeartbeat
 
fileSystemHeartbeat(long, List<Long>, FileSystemHeartbeatTOptions) - Method in class alluxio.thrift.FileSystemMasterWorkerService.Client
 
fileSystemHeartbeat(long, List<Long>, FileSystemHeartbeatTOptions) - Method in interface alluxio.thrift.FileSystemMasterWorkerService.Iface
Periodic file system worker heartbeat.
fileSystemHeartbeat() - Constructor for class alluxio.thrift.FileSystemMasterWorkerService.Processor.fileSystemHeartbeat
 
fileSystemHeartbeat_args() - Constructor for class alluxio.thrift.FileSystemMasterWorkerService.fileSystemHeartbeat_args
 
fileSystemHeartbeat_args(long, List<Long>, FileSystemHeartbeatTOptions) - Constructor for class alluxio.thrift.FileSystemMasterWorkerService.fileSystemHeartbeat_args
 
fileSystemHeartbeat_args(FileSystemMasterWorkerService.fileSystemHeartbeat_args) - Constructor for class alluxio.thrift.FileSystemMasterWorkerService.fileSystemHeartbeat_args
Performs a deep copy on other.
fileSystemHeartbeat_call(long, List<Long>, FileSystemHeartbeatTOptions, AsyncMethodCallback, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class alluxio.thrift.FileSystemMasterWorkerService.AsyncClient.fileSystemHeartbeat_call
 
fileSystemHeartbeat_result() - Constructor for class alluxio.thrift.FileSystemMasterWorkerService.fileSystemHeartbeat_result
 
fileSystemHeartbeat_result(FileSystemHeartbeatTResponse, AlluxioTException) - Constructor for class alluxio.thrift.FileSystemMasterWorkerService.fileSystemHeartbeat_result
 
fileSystemHeartbeat_result(FileSystemMasterWorkerService.fileSystemHeartbeat_result) - Constructor for class alluxio.thrift.FileSystemMasterWorkerService.fileSystemHeartbeat_result
Performs a deep copy on other.
FileSystemHeartbeatTOptions - Class in alluxio.thrift
 
FileSystemHeartbeatTOptions() - Constructor for class alluxio.thrift.FileSystemHeartbeatTOptions
 
FileSystemHeartbeatTOptions(FileSystemHeartbeatTOptions) - Constructor for class alluxio.thrift.FileSystemHeartbeatTOptions
Performs a deep copy on other.
FileSystemHeartbeatTOptions._Fields - Enum in alluxio.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
FileSystemHeartbeatTResponse - Class in alluxio.thrift
 
FileSystemHeartbeatTResponse() - Constructor for class alluxio.thrift.FileSystemHeartbeatTResponse
 
FileSystemHeartbeatTResponse(FileSystemCommand) - Constructor for class alluxio.thrift.FileSystemHeartbeatTResponse
 
FileSystemHeartbeatTResponse(FileSystemHeartbeatTResponse) - Constructor for class alluxio.thrift.FileSystemHeartbeatTResponse
Performs a deep copy on other.
FileSystemHeartbeatTResponse._Fields - Enum in alluxio.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
FileSystemMaster - Interface in alluxio.master.file
The interface of file system master.
FileSystemMasterAuditContext - Class in alluxio.master.file
An audit context for file system master.
FileSystemMasterAuditContext(AsyncUserAccessAuditLogWriter) - Constructor for class alluxio.master.file.FileSystemMasterAuditContext
FileSystemMasterClient - Interface in alluxio.client.file
A client to use for interacting with a file system master.
FileSystemMasterClient - Class in alluxio.worker.file
A wrapper for the thrift client to interact with the file system master, used by Alluxio worker.
FileSystemMasterClient(MasterClientConfig) - Constructor for class alluxio.worker.file.FileSystemMasterClient
Creates a instance of FileSystemMasterClient.
FileSystemMasterClient.Factory - Class in alluxio.client.file
FileSystemMasterClientPool - Class in alluxio.client.file
A fixed pool of FileSystemMasterClient instances.
FileSystemMasterClientPool(Subject, MasterInquireClient) - Constructor for class alluxio.client.file.FileSystemMasterClientPool
Creates a new file system master client pool.
FileSystemMasterClientPool(Subject, MasterInquireClient, int) - Constructor for class alluxio.client.file.FileSystemMasterClientPool
Creates a new file system master client pool.
FileSystemMasterClientRestServiceHandler - Class in alluxio.master.file
Deprecated.
since version 1.4 and will be removed in version 2.0
FileSystemMasterClientRestServiceHandler(ServletContext) - Constructor for class alluxio.master.file.FileSystemMasterClientRestServiceHandler
Deprecated.
FileSystemMasterClientService - Class in alluxio.thrift
 
FileSystemMasterClientService() - Constructor for class alluxio.thrift.FileSystemMasterClientService
 
FileSystemMasterClientService.AsyncClient - Class in alluxio.thrift
 
FileSystemMasterClientService.AsyncClient.checkConsistency_call - Class in alluxio.thrift
 
FileSystemMasterClientService.AsyncClient.completeFile_call - Class in alluxio.thrift
 
FileSystemMasterClientService.AsyncClient.createDirectory_call - Class in alluxio.thrift
 
FileSystemMasterClientService.AsyncClient.createFile_call - Class in alluxio.thrift
 
FileSystemMasterClientService.AsyncClient.Factory - Class in alluxio.thrift
 
FileSystemMasterClientService.AsyncClient.free_call - Class in alluxio.thrift
 
FileSystemMasterClientService.AsyncClient.getFilePath_call - Class in alluxio.thrift
 
FileSystemMasterClientService.AsyncClient.getMountTable_call - Class in alluxio.thrift
 
FileSystemMasterClientService.AsyncClient.getNewBlockIdForFile_call - Class in alluxio.thrift
 
FileSystemMasterClientService.AsyncClient.getStatus_call - Class in alluxio.thrift
 
FileSystemMasterClientService.AsyncClient.listStatus_call - Class in alluxio.thrift
 
FileSystemMasterClientService.AsyncClient.loadMetadata_call - Class in alluxio.thrift
 
FileSystemMasterClientService.AsyncClient.mount_call - Class in alluxio.thrift
 
FileSystemMasterClientService.AsyncClient.remove_call - Class in alluxio.thrift
 
FileSystemMasterClientService.AsyncClient.rename_call - Class in alluxio.thrift
 
FileSystemMasterClientService.AsyncClient.scheduleAsyncPersistence_call - Class in alluxio.thrift
 
FileSystemMasterClientService.AsyncClient.setAttribute_call - Class in alluxio.thrift
 
FileSystemMasterClientService.AsyncClient.unmount_call - Class in alluxio.thrift
 
FileSystemMasterClientService.AsyncClient.updateUfsMode_call - Class in alluxio.thrift
 
FileSystemMasterClientService.AsyncIface - Interface in alluxio.thrift
 
FileSystemMasterClientService.AsyncProcessor<I extends FileSystemMasterClientService.AsyncIface> - Class in alluxio.thrift
 
FileSystemMasterClientService.AsyncProcessor.checkConsistency<I extends FileSystemMasterClientService.AsyncIface> - Class in alluxio.thrift
 
FileSystemMasterClientService.AsyncProcessor.completeFile<I extends FileSystemMasterClientService.AsyncIface> - Class in alluxio.thrift
 
FileSystemMasterClientService.AsyncProcessor.createDirectory<I extends FileSystemMasterClientService.AsyncIface> - Class in alluxio.thrift
 
FileSystemMasterClientService.AsyncProcessor.createFile<I extends FileSystemMasterClientService.AsyncIface> - Class in alluxio.thrift
 
FileSystemMasterClientService.AsyncProcessor.free<I extends FileSystemMasterClientService.AsyncIface> - Class in alluxio.thrift
 
FileSystemMasterClientService.AsyncProcessor.getFilePath<I extends FileSystemMasterClientService.AsyncIface> - Class in alluxio.thrift
 
FileSystemMasterClientService.AsyncProcessor.getMountTable<I extends FileSystemMasterClientService.AsyncIface> - Class in alluxio.thrift
 
FileSystemMasterClientService.AsyncProcessor.getNewBlockIdForFile<I extends FileSystemMasterClientService.AsyncIface> - Class in alluxio.thrift
 
FileSystemMasterClientService.AsyncProcessor.getStatus<I extends FileSystemMasterClientService.AsyncIface> - Class in alluxio.thrift
 
FileSystemMasterClientService.AsyncProcessor.listStatus<I extends FileSystemMasterClientService.AsyncIface> - Class in alluxio.thrift
 
FileSystemMasterClientService.AsyncProcessor.loadMetadata<I extends FileSystemMasterClientService.AsyncIface> - Class in alluxio.thrift
 
FileSystemMasterClientService.AsyncProcessor.mount<I extends FileSystemMasterClientService.AsyncIface> - Class in alluxio.thrift
 
FileSystemMasterClientService.AsyncProcessor.remove<I extends FileSystemMasterClientService.AsyncIface> - Class in alluxio.thrift
 
FileSystemMasterClientService.AsyncProcessor.rename<I extends FileSystemMasterClientService.AsyncIface> - Class in alluxio.thrift
 
FileSystemMasterClientService.AsyncProcessor.scheduleAsyncPersistence<I extends FileSystemMasterClientService.AsyncIface> - Class in alluxio.thrift
 
FileSystemMasterClientService.AsyncProcessor.setAttribute<I extends FileSystemMasterClientService.AsyncIface> - Class in alluxio.thrift
 
FileSystemMasterClientService.AsyncProcessor.unmount<I extends FileSystemMasterClientService.AsyncIface> - Class in alluxio.thrift
 
FileSystemMasterClientService.AsyncProcessor.updateUfsMode<I extends FileSystemMasterClientService.AsyncIface> - Class in alluxio.thrift
 
FileSystemMasterClientService.checkConsistency_args - Class in alluxio.thrift
 
FileSystemMasterClientService.checkConsistency_args._Fields - Enum in alluxio.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
FileSystemMasterClientService.checkConsistency_result - Class in alluxio.thrift
 
FileSystemMasterClientService.checkConsistency_result._Fields - Enum in alluxio.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
FileSystemMasterClientService.Client - Class in alluxio.thrift
 
FileSystemMasterClientService.Client.Factory - Class in alluxio.thrift
 
FileSystemMasterClientService.completeFile_args - Class in alluxio.thrift
 
FileSystemMasterClientService.completeFile_args._Fields - Enum in alluxio.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
FileSystemMasterClientService.completeFile_result - Class in alluxio.thrift
 
FileSystemMasterClientService.completeFile_result._Fields - Enum in alluxio.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
FileSystemMasterClientService.createDirectory_args - Class in alluxio.thrift
 
FileSystemMasterClientService.createDirectory_args._Fields - Enum in alluxio.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
FileSystemMasterClientService.createDirectory_result - Class in alluxio.thrift
 
FileSystemMasterClientService.createDirectory_result._Fields - Enum in alluxio.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
FileSystemMasterClientService.createFile_args - Class in alluxio.thrift
 
FileSystemMasterClientService.createFile_args._Fields - Enum in alluxio.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
FileSystemMasterClientService.createFile_result - Class in alluxio.thrift
 
FileSystemMasterClientService.createFile_result._Fields - Enum in alluxio.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
FileSystemMasterClientService.free_args - Class in alluxio.thrift
 
FileSystemMasterClientService.free_args._Fields - Enum in alluxio.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
FileSystemMasterClientService.free_result - Class in alluxio.thrift
 
FileSystemMasterClientService.free_result._Fields - Enum in alluxio.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
FileSystemMasterClientService.getFilePath_args - Class in alluxio.thrift
 
FileSystemMasterClientService.getFilePath_args._Fields - Enum in alluxio.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
FileSystemMasterClientService.getFilePath_result - Class in alluxio.thrift
 
FileSystemMasterClientService.getFilePath_result._Fields - Enum in alluxio.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
FileSystemMasterClientService.getMountTable_args - Class in alluxio.thrift
 
FileSystemMasterClientService.getMountTable_args._Fields - Enum in alluxio.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
FileSystemMasterClientService.getMountTable_result - Class in alluxio.thrift
 
FileSystemMasterClientService.getMountTable_result._Fields - Enum in alluxio.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
FileSystemMasterClientService.getNewBlockIdForFile_args - Class in alluxio.thrift
 
FileSystemMasterClientService.getNewBlockIdForFile_args._Fields - Enum in alluxio.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
FileSystemMasterClientService.getNewBlockIdForFile_result - Class in alluxio.thrift
 
FileSystemMasterClientService.getNewBlockIdForFile_result._Fields - Enum in alluxio.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
FileSystemMasterClientService.getStatus_args - Class in alluxio.thrift
 
FileSystemMasterClientService.getStatus_args._Fields - Enum in alluxio.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
FileSystemMasterClientService.getStatus_result - Class in alluxio.thrift
 
FileSystemMasterClientService.getStatus_result._Fields - Enum in alluxio.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
FileSystemMasterClientService.Iface - Interface in alluxio.thrift
This interface contains file system master service endpoints for Alluxio clients.
FileSystemMasterClientService.listStatus_args - Class in alluxio.thrift
 
FileSystemMasterClientService.listStatus_args._Fields - Enum in alluxio.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
FileSystemMasterClientService.listStatus_result - Class in alluxio.thrift
 
FileSystemMasterClientService.listStatus_result._Fields - Enum in alluxio.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
FileSystemMasterClientService.loadMetadata_args - Class in alluxio.thrift
 
FileSystemMasterClientService.loadMetadata_args._Fields - Enum in alluxio.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
FileSystemMasterClientService.loadMetadata_result - Class in alluxio.thrift
 
FileSystemMasterClientService.loadMetadata_result._Fields - Enum in alluxio.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
FileSystemMasterClientService.mount_args - Class in alluxio.thrift
 
FileSystemMasterClientService.mount_args._Fields - Enum in alluxio.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
FileSystemMasterClientService.mount_result - Class in alluxio.thrift
 
FileSystemMasterClientService.mount_result._Fields - Enum in alluxio.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
FileSystemMasterClientService.Processor<I extends FileSystemMasterClientService.Iface> - Class in alluxio.thrift
 
FileSystemMasterClientService.Processor.checkConsistency<I extends FileSystemMasterClientService.Iface> - Class in alluxio.thrift
 
FileSystemMasterClientService.Processor.completeFile<I extends FileSystemMasterClientService.Iface> - Class in alluxio.thrift
 
FileSystemMasterClientService.Processor.createDirectory<I extends FileSystemMasterClientService.Iface> - Class in alluxio.thrift
 
FileSystemMasterClientService.Processor.createFile<I extends FileSystemMasterClientService.Iface> - Class in alluxio.thrift
 
FileSystemMasterClientService.Processor.free<I extends FileSystemMasterClientService.Iface> - Class in alluxio.thrift
 
FileSystemMasterClientService.Processor.getFilePath<I extends FileSystemMasterClientService.Iface> - Class in alluxio.thrift
 
FileSystemMasterClientService.Processor.getMountTable<I extends FileSystemMasterClientService.Iface> - Class in alluxio.thrift
 
FileSystemMasterClientService.Processor.getNewBlockIdForFile<I extends FileSystemMasterClientService.Iface> - Class in alluxio.thrift
 
FileSystemMasterClientService.Processor.getStatus<I extends FileSystemMasterClientService.Iface> - Class in alluxio.thrift
 
FileSystemMasterClientService.Processor.listStatus<I extends FileSystemMasterClientService.Iface> - Class in alluxio.thrift
 
FileSystemMasterClientService.Processor.loadMetadata<I extends FileSystemMasterClientService.Iface> - Class in alluxio.thrift
 
FileSystemMasterClientService.Processor.mount<I extends FileSystemMasterClientService.Iface> - Class in alluxio.thrift
 
FileSystemMasterClientService.Processor.remove<I extends FileSystemMasterClientService.Iface> - Class in alluxio.thrift
 
FileSystemMasterClientService.Processor.rename<I extends FileSystemMasterClientService.Iface> - Class in alluxio.thrift
 
FileSystemMasterClientService.Processor.scheduleAsyncPersistence<I extends FileSystemMasterClientService.Iface> - Class in alluxio.thrift
 
FileSystemMasterClientService.Processor.setAttribute<I extends FileSystemMasterClientService.Iface> - Class in alluxio.thrift
 
FileSystemMasterClientService.Processor.unmount<I extends FileSystemMasterClientService.Iface> - Class in alluxio.thrift
 
FileSystemMasterClientService.Processor.updateUfsMode<I extends FileSystemMasterClientService.Iface> - Class in alluxio.thrift
 
FileSystemMasterClientService.remove_args - Class in alluxio.thrift
 
FileSystemMasterClientService.remove_args._Fields - Enum in alluxio.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
FileSystemMasterClientService.remove_result - Class in alluxio.thrift
 
FileSystemMasterClientService.remove_result._Fields - Enum in alluxio.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
FileSystemMasterClientService.rename_args - Class in alluxio.thrift
 
FileSystemMasterClientService.rename_args._Fields - Enum in alluxio.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
FileSystemMasterClientService.rename_result - Class in alluxio.thrift
 
FileSystemMasterClientService.rename_result._Fields - Enum in alluxio.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
FileSystemMasterClientService.scheduleAsyncPersistence_args - Class in alluxio.thrift
 
FileSystemMasterClientService.scheduleAsyncPersistence_args._Fields - Enum in alluxio.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
FileSystemMasterClientService.scheduleAsyncPersistence_result - Class in alluxio.thrift
 
FileSystemMasterClientService.scheduleAsyncPersistence_result._Fields - Enum in alluxio.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
FileSystemMasterClientService.setAttribute_args - Class in alluxio.thrift
 
FileSystemMasterClientService.setAttribute_args._Fields - Enum in alluxio.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
FileSystemMasterClientService.setAttribute_result - Class in alluxio.thrift
 
FileSystemMasterClientService.setAttribute_result._Fields - Enum in alluxio.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
FileSystemMasterClientService.unmount_args - Class in alluxio.thrift
 
FileSystemMasterClientService.unmount_args._Fields - Enum in alluxio.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
FileSystemMasterClientService.unmount_result - Class in alluxio.thrift
 
FileSystemMasterClientService.unmount_result._Fields - Enum in alluxio.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
FileSystemMasterClientService.updateUfsMode_args - Class in alluxio.thrift
 
FileSystemMasterClientService.updateUfsMode_args._Fields - Enum in alluxio.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
FileSystemMasterClientService.updateUfsMode_result - Class in alluxio.thrift
 
FileSystemMasterClientService.updateUfsMode_result._Fields - Enum in alluxio.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
FileSystemMasterClientServiceHandler - Class in alluxio.master.file
This class is a Thrift handler for file system master RPCs invoked by an Alluxio client.
FileSystemMasterClientServiceProcessor - Class in alluxio.master.file
Alluxio customized Thrift processor to handle RPC and track client IP.
FileSystemMasterClientServiceProcessor(FileSystemMasterClientService.Iface) - Constructor for class alluxio.master.file.FileSystemMasterClientServiceProcessor
FileSystemMasterCommonTOptions - Class in alluxio.thrift
 
FileSystemMasterCommonTOptions() - Constructor for class alluxio.thrift.FileSystemMasterCommonTOptions
 
FileSystemMasterCommonTOptions(FileSystemMasterCommonTOptions) - Constructor for class alluxio.thrift.FileSystemMasterCommonTOptions
Performs a deep copy on other.
FileSystemMasterCommonTOptions._Fields - Enum in alluxio.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
FileSystemMasterFactory - Class in alluxio.master.file
Factory to create a FileSystemMaster instance.
FileSystemMasterFactory() - Constructor for class alluxio.master.file.FileSystemMasterFactory
Constructs a new FileSystemMasterFactory.
FileSystemMasterView - Class in alluxio.master.file.meta
This class exposes a read-only view of FileSystemMaster.
FileSystemMasterView(FileSystemMaster) - Constructor for class alluxio.master.file.meta.FileSystemMasterView
Constructs a view of the FileSystemMaster.
FileSystemMasterWorkerService - Class in alluxio.thrift
 
FileSystemMasterWorkerService() - Constructor for class alluxio.thrift.FileSystemMasterWorkerService
 
FileSystemMasterWorkerService.AsyncClient - Class in alluxio.thrift
 
FileSystemMasterWorkerService.AsyncClient.Factory - Class in alluxio.thrift
 
FileSystemMasterWorkerService.AsyncClient.fileSystemHeartbeat_call - Class in alluxio.thrift
 
FileSystemMasterWorkerService.AsyncClient.getFileInfo_call - Class in alluxio.thrift
 
FileSystemMasterWorkerService.AsyncClient.getPinnedFileIds_call - Class in alluxio.thrift
 
FileSystemMasterWorkerService.AsyncClient.getUfsInfo_call - Class in alluxio.thrift
 
FileSystemMasterWorkerService.AsyncIface - Interface in alluxio.thrift
 
FileSystemMasterWorkerService.AsyncProcessor<I extends FileSystemMasterWorkerService.AsyncIface> - Class in alluxio.thrift
 
FileSystemMasterWorkerService.AsyncProcessor.fileSystemHeartbeat<I extends FileSystemMasterWorkerService.AsyncIface> - Class in alluxio.thrift
 
FileSystemMasterWorkerService.AsyncProcessor.getFileInfo<I extends FileSystemMasterWorkerService.AsyncIface> - Class in alluxio.thrift
 
FileSystemMasterWorkerService.AsyncProcessor.getPinnedFileIds<I extends FileSystemMasterWorkerService.AsyncIface> - Class in alluxio.thrift
 
FileSystemMasterWorkerService.AsyncProcessor.getUfsInfo<I extends FileSystemMasterWorkerService.AsyncIface> - Class in alluxio.thrift
 
FileSystemMasterWorkerService.Client - Class in alluxio.thrift
 
FileSystemMasterWorkerService.Client.Factory - Class in alluxio.thrift
 
FileSystemMasterWorkerService.fileSystemHeartbeat_args - Class in alluxio.thrift
 
FileSystemMasterWorkerService.fileSystemHeartbeat_args._Fields - Enum in alluxio.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
FileSystemMasterWorkerService.fileSystemHeartbeat_result - Class in alluxio.thrift
 
FileSystemMasterWorkerService.fileSystemHeartbeat_result._Fields - Enum in alluxio.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
FileSystemMasterWorkerService.getFileInfo_args - Class in alluxio.thrift
 
FileSystemMasterWorkerService.getFileInfo_args._Fields - Enum in alluxio.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
FileSystemMasterWorkerService.getFileInfo_result - Class in alluxio.thrift
 
FileSystemMasterWorkerService.getFileInfo_result._Fields - Enum in alluxio.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
FileSystemMasterWorkerService.getPinnedFileIds_args - Class in alluxio.thrift
 
FileSystemMasterWorkerService.getPinnedFileIds_args._Fields - Enum in alluxio.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
FileSystemMasterWorkerService.getPinnedFileIds_result - Class in alluxio.thrift
 
FileSystemMasterWorkerService.getPinnedFileIds_result._Fields - Enum in alluxio.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
FileSystemMasterWorkerService.getUfsInfo_args - Class in alluxio.thrift
 
FileSystemMasterWorkerService.getUfsInfo_args._Fields - Enum in alluxio.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
FileSystemMasterWorkerService.getUfsInfo_result - Class in alluxio.thrift
 
FileSystemMasterWorkerService.getUfsInfo_result._Fields - Enum in alluxio.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
FileSystemMasterWorkerService.Iface - Interface in alluxio.thrift
This interface contains file system master service endpoints for Alluxio workers.
FileSystemMasterWorkerService.Processor<I extends FileSystemMasterWorkerService.Iface> - Class in alluxio.thrift
 
FileSystemMasterWorkerService.Processor.fileSystemHeartbeat<I extends FileSystemMasterWorkerService.Iface> - Class in alluxio.thrift
 
FileSystemMasterWorkerService.Processor.getFileInfo<I extends FileSystemMasterWorkerService.Iface> - Class in alluxio.thrift
 
FileSystemMasterWorkerService.Processor.getPinnedFileIds<I extends FileSystemMasterWorkerService.Iface> - Class in alluxio.thrift
 
FileSystemMasterWorkerService.Processor.getUfsInfo<I extends FileSystemMasterWorkerService.Iface> - Class in alluxio.thrift
 
FileSystemMasterWorkerServiceHandler - Class in alluxio.master.file
This class is a Thrift handler for file system master RPCs invoked by an Alluxio worker.
FileSystemShell - Class in alluxio.cli.fs
Class for handling command line inputs.
FileSystemShell() - Constructor for class alluxio.cli.fs.FileSystemShell
Creates a new instance of FileSystemShell.
FileSystemShellUtils - Class in alluxio.cli.fs
Class for convenience methods used by FileSystemShell.
FileSystemUtils - Class in alluxio.client.file
Collection of utility methods to handle with FileSystem related objects.
FileSystemWorker - Interface in alluxio.worker.file
Interface representing a file system worker.
FileSystemWorkerClientService - Class in alluxio.thrift
 
FileSystemWorkerClientService() - Constructor for class alluxio.thrift.FileSystemWorkerClientService
 
FileSystemWorkerClientService.AsyncClient - Class in alluxio.thrift
 
FileSystemWorkerClientService.AsyncClient.cancelUfsFile_call - Class in alluxio.thrift
 
FileSystemWorkerClientService.AsyncClient.closeUfsFile_call - Class in alluxio.thrift
 
FileSystemWorkerClientService.AsyncClient.completeUfsFile_call - Class in alluxio.thrift
 
FileSystemWorkerClientService.AsyncClient.createUfsFile_call - Class in alluxio.thrift
 
FileSystemWorkerClientService.AsyncClient.Factory - Class in alluxio.thrift
 
FileSystemWorkerClientService.AsyncClient.openUfsFile_call - Class in alluxio.thrift
 
FileSystemWorkerClientService.AsyncClient.sessionFileSystemHeartbeat_call - Class in alluxio.thrift
 
FileSystemWorkerClientService.AsyncIface - Interface in alluxio.thrift
 
FileSystemWorkerClientService.AsyncProcessor<I extends FileSystemWorkerClientService.AsyncIface> - Class in alluxio.thrift
 
FileSystemWorkerClientService.AsyncProcessor.cancelUfsFile<I extends FileSystemWorkerClientService.AsyncIface> - Class in alluxio.thrift
 
FileSystemWorkerClientService.AsyncProcessor.closeUfsFile<I extends FileSystemWorkerClientService.AsyncIface> - Class in alluxio.thrift
 
FileSystemWorkerClientService.AsyncProcessor.completeUfsFile<I extends FileSystemWorkerClientService.AsyncIface> - Class in alluxio.thrift
 
FileSystemWorkerClientService.AsyncProcessor.createUfsFile<I extends FileSystemWorkerClientService.AsyncIface> - Class in alluxio.thrift
 
FileSystemWorkerClientService.AsyncProcessor.openUfsFile<I extends FileSystemWorkerClientService.AsyncIface> - Class in alluxio.thrift
 
FileSystemWorkerClientService.AsyncProcessor.sessionFileSystemHeartbeat<I extends FileSystemWorkerClientService.AsyncIface> - Class in alluxio.thrift
 
FileSystemWorkerClientService.cancelUfsFile_args - Class in alluxio.thrift
 
FileSystemWorkerClientService.cancelUfsFile_args._Fields - Enum in alluxio.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
FileSystemWorkerClientService.cancelUfsFile_result - Class in alluxio.thrift
 
FileSystemWorkerClientService.cancelUfsFile_result._Fields - Enum in alluxio.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
FileSystemWorkerClientService.Client - Class in alluxio.thrift
 
FileSystemWorkerClientService.Client.Factory - Class in alluxio.thrift
 
FileSystemWorkerClientService.closeUfsFile_args - Class in alluxio.thrift
 
FileSystemWorkerClientService.closeUfsFile_args._Fields - Enum in alluxio.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
FileSystemWorkerClientService.closeUfsFile_result - Class in alluxio.thrift
 
FileSystemWorkerClientService.closeUfsFile_result._Fields - Enum in alluxio.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
FileSystemWorkerClientService.completeUfsFile_args - Class in alluxio.thrift
 
FileSystemWorkerClientService.completeUfsFile_args._Fields - Enum in alluxio.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
FileSystemWorkerClientService.completeUfsFile_result - Class in alluxio.thrift
 
FileSystemWorkerClientService.completeUfsFile_result._Fields - Enum in alluxio.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
FileSystemWorkerClientService.createUfsFile_args - Class in alluxio.thrift
 
FileSystemWorkerClientService.createUfsFile_args._Fields - Enum in alluxio.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
FileSystemWorkerClientService.createUfsFile_result - Class in alluxio.thrift
 
FileSystemWorkerClientService.createUfsFile_result._Fields - Enum in alluxio.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
FileSystemWorkerClientService.Iface - Interface in alluxio.thrift
This interface contains file system worker service endpoints for Alluxio clients.
FileSystemWorkerClientService.openUfsFile_args - Class in alluxio.thrift
 
FileSystemWorkerClientService.openUfsFile_args._Fields - Enum in alluxio.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
FileSystemWorkerClientService.openUfsFile_result - Class in alluxio.thrift
 
FileSystemWorkerClientService.openUfsFile_result._Fields - Enum in alluxio.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
FileSystemWorkerClientService.Processor<I extends FileSystemWorkerClientService.Iface> - Class in alluxio.thrift
 
FileSystemWorkerClientService.Processor.cancelUfsFile<I extends FileSystemWorkerClientService.Iface> - Class in alluxio.thrift
 
FileSystemWorkerClientService.Processor.closeUfsFile<I extends FileSystemWorkerClientService.Iface> - Class in alluxio.thrift
 
FileSystemWorkerClientService.Processor.completeUfsFile<I extends FileSystemWorkerClientService.Iface> - Class in alluxio.thrift
 
FileSystemWorkerClientService.Processor.createUfsFile<I extends FileSystemWorkerClientService.Iface> - Class in alluxio.thrift
 
FileSystemWorkerClientService.Processor.openUfsFile<I extends FileSystemWorkerClientService.Iface> - Class in alluxio.thrift
 
FileSystemWorkerClientService.Processor.sessionFileSystemHeartbeat<I extends FileSystemWorkerClientService.Iface> - Class in alluxio.thrift
 
FileSystemWorkerClientService.sessionFileSystemHeartbeat_args - Class in alluxio.thrift
 
FileSystemWorkerClientService.sessionFileSystemHeartbeat_args._Fields - Enum in alluxio.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
FileSystemWorkerClientService.sessionFileSystemHeartbeat_result - Class in alluxio.thrift
 
FileSystemWorkerClientService.sessionFileSystemHeartbeat_result._Fields - Enum in alluxio.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
FileSystemWorkerClientServiceHandler - Class in alluxio.worker.file
Handles incoming thrift requests from a worker file system client.
FileSystemWorkerFactory - Class in alluxio.worker.file
Factory to create a DefaultFileSystemWorker instance.
FileSystemWorkerFactory() - Constructor for class alluxio.worker.file.FileSystemWorkerFactory
Constructs a new FileSystemWorkerFactory.
FileUtils - Class in alluxio.util.io
Provides utility methods for working with files and directories.
FileWriteLocationPolicy - Interface in alluxio.client.file.policy
Interface for the location policy of which workers a file's blocks are written into.
find(String) - Static method in class alluxio.underfs.UnderFileSystemFactoryRegistry
Finds the first Under File System factory that supports the given path.
find(String, UnderFileSystemConfiguration) - Static method in class alluxio.underfs.UnderFileSystemFactoryRegistry
Finds the first Under File System factory that supports the given path.
findAll(String, S) - Method in class alluxio.extensions.ExtensionFactoryRegistry
Finds all the factories that support the given path.
findAll(String, UnderFileSystemConfiguration) - Static method in class alluxio.underfs.UnderFileSystemFactoryRegistry
Finds all the Under File System factories that support the given path.
findByName(String) - Static method in enum alluxio.thrift.AccessBlockTOptions._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum alluxio.thrift.AccessBlockTResponse._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum alluxio.thrift.AlluxioService.getServiceVersion_args._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum alluxio.thrift.AlluxioService.getServiceVersion_result._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum alluxio.thrift.AlluxioTException._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum alluxio.thrift.BackupTOptions._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum alluxio.thrift.BackupTResponse._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum alluxio.thrift.BlockHeartbeatTOptions._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum alluxio.thrift.BlockHeartbeatTResponse._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum alluxio.thrift.BlockInfo._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum alluxio.thrift.BlockLocation._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum alluxio.thrift.BlockMasterClientService.getBlockInfo_args._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum alluxio.thrift.BlockMasterClientService.getBlockInfo_result._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum alluxio.thrift.BlockMasterClientService.getBlockMasterInfo_args._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum alluxio.thrift.BlockMasterClientService.getBlockMasterInfo_result._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum alluxio.thrift.BlockMasterClientService.getCapacityBytes_args._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum alluxio.thrift.BlockMasterClientService.getCapacityBytes_result._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum alluxio.thrift.BlockMasterClientService.getUsedBytes_args._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum alluxio.thrift.BlockMasterClientService.getUsedBytes_result._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum alluxio.thrift.BlockMasterClientService.getWorkerInfoList_args._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum alluxio.thrift.BlockMasterClientService.getWorkerInfoList_result._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum alluxio.thrift.BlockMasterClientService.getWorkerReport_args._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum alluxio.thrift.BlockMasterClientService.getWorkerReport_result._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum alluxio.thrift.BlockMasterInfo._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum alluxio.thrift.BlockMasterWorkerService.blockHeartbeat_args._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum alluxio.thrift.BlockMasterWorkerService.blockHeartbeat_result._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum alluxio.thrift.BlockMasterWorkerService.commitBlock_args._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum alluxio.thrift.BlockMasterWorkerService.commitBlock_result._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum alluxio.thrift.BlockMasterWorkerService.getWorkerId_args._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum alluxio.thrift.BlockMasterWorkerService.getWorkerId_result._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum alluxio.thrift.BlockMasterWorkerService.registerWorker_args._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum alluxio.thrift.BlockMasterWorkerService.registerWorker_result._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum alluxio.thrift.BlockWorkerClientService.accessBlock_args._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum alluxio.thrift.BlockWorkerClientService.accessBlock_result._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum alluxio.thrift.BlockWorkerClientService.cacheBlock_args._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum alluxio.thrift.BlockWorkerClientService.cacheBlock_result._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum alluxio.thrift.BlockWorkerClientService.cancelBlock_args._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum alluxio.thrift.BlockWorkerClientService.cancelBlock_result._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum alluxio.thrift.BlockWorkerClientService.lockBlock_args._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum alluxio.thrift.BlockWorkerClientService.lockBlock_result._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum alluxio.thrift.BlockWorkerClientService.promoteBlock_args._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum alluxio.thrift.BlockWorkerClientService.promoteBlock_result._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum alluxio.thrift.BlockWorkerClientService.removeBlock_args._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum alluxio.thrift.BlockWorkerClientService.removeBlock_result._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum alluxio.thrift.BlockWorkerClientService.requestBlockLocation_args._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum alluxio.thrift.BlockWorkerClientService.requestBlockLocation_result._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum alluxio.thrift.BlockWorkerClientService.requestSpace_args._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum alluxio.thrift.BlockWorkerClientService.requestSpace_result._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum alluxio.thrift.BlockWorkerClientService.sessionBlockHeartbeat_args._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum alluxio.thrift.BlockWorkerClientService.sessionBlockHeartbeat_result._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum alluxio.thrift.BlockWorkerClientService.unlockBlock_args._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum alluxio.thrift.BlockWorkerClientService.unlockBlock_result._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum alluxio.thrift.CacheBlockTOptions._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum alluxio.thrift.CacheBlockTResponse._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum alluxio.thrift.CancelBlockTOptions._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum alluxio.thrift.CancelBlockTResponse._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum alluxio.thrift.CancelUfsFileTOptions._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum alluxio.thrift.CancelUfsFileTResponse._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum alluxio.thrift.CheckConsistencyTOptions._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum alluxio.thrift.CheckConsistencyTResponse._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum alluxio.thrift.CloseUfsFileTOptions._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum alluxio.thrift.CloseUfsFileTResponse._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum alluxio.thrift.Command._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum alluxio.thrift.CommandLineJobInfo._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum alluxio.thrift.CommitBlockTOptions._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum alluxio.thrift.CommitBlockTResponse._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum alluxio.thrift.CompleteFileTOptions._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum alluxio.thrift.CompleteFileTResponse._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum alluxio.thrift.CompletePartitionTOptions._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum alluxio.thrift.CompletePartitionTResponse._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum alluxio.thrift.CompleteStoreTOptions._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum alluxio.thrift.CompleteStoreTResponse._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum alluxio.thrift.CompleteUfsFileTOptions._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum alluxio.thrift.CompleteUfsFileTReponse._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum alluxio.thrift.ConfigCheckReport._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum alluxio.thrift.ConfigProperty._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum alluxio.thrift.CreateDirectoryTOptions._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum alluxio.thrift.CreateDirectoryTResponse._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum alluxio.thrift.CreateFileTOptions._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum alluxio.thrift.CreateFileTResponse._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum alluxio.thrift.CreateLineageTOptions._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum alluxio.thrift.CreateLineageTResponse._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum alluxio.thrift.CreateStoreTOptions._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum alluxio.thrift.CreateStoreTResponse._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum alluxio.thrift.CreateUfsFileTOptions._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum alluxio.thrift.CreateUfsFileTResponse._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum alluxio.thrift.DeleteLineageTOptions._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum alluxio.thrift.DeleteLineageTResponse._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum alluxio.thrift.DeleteStoreTOptions._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum alluxio.thrift.DeleteStoreTResponse._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum alluxio.thrift.DeleteTOptions._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum alluxio.thrift.DeleteTResponse._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum alluxio.thrift.DependencyInfo._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum alluxio.thrift.FileBlockInfo._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum alluxio.thrift.FileInfo._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum alluxio.thrift.FileSystemCommand._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum alluxio.thrift.FileSystemCommandOptions._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum alluxio.thrift.FileSystemHeartbeatTOptions._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum alluxio.thrift.FileSystemHeartbeatTResponse._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum alluxio.thrift.FileSystemMasterClientService.checkConsistency_args._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum alluxio.thrift.FileSystemMasterClientService.checkConsistency_result._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum alluxio.thrift.FileSystemMasterClientService.completeFile_args._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum alluxio.thrift.FileSystemMasterClientService.completeFile_result._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum alluxio.thrift.FileSystemMasterClientService.createDirectory_args._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum alluxio.thrift.FileSystemMasterClientService.createDirectory_result._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum alluxio.thrift.FileSystemMasterClientService.createFile_args._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum alluxio.thrift.FileSystemMasterClientService.createFile_result._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum alluxio.thrift.FileSystemMasterClientService.free_args._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum alluxio.thrift.FileSystemMasterClientService.free_result._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum alluxio.thrift.FileSystemMasterClientService.getFilePath_args._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum alluxio.thrift.FileSystemMasterClientService.getFilePath_result._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum alluxio.thrift.FileSystemMasterClientService.getMountTable_args._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum alluxio.thrift.FileSystemMasterClientService.getMountTable_result._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum alluxio.thrift.FileSystemMasterClientService.getNewBlockIdForFile_args._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum alluxio.thrift.FileSystemMasterClientService.getNewBlockIdForFile_result._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum alluxio.thrift.FileSystemMasterClientService.getStatus_args._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum alluxio.thrift.FileSystemMasterClientService.getStatus_result._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum alluxio.thrift.FileSystemMasterClientService.listStatus_args._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum alluxio.thrift.FileSystemMasterClientService.listStatus_result._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum alluxio.thrift.FileSystemMasterClientService.loadMetadata_args._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum alluxio.thrift.FileSystemMasterClientService.loadMetadata_result._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum alluxio.thrift.FileSystemMasterClientService.mount_args._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum alluxio.thrift.FileSystemMasterClientService.mount_result._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum alluxio.thrift.FileSystemMasterClientService.remove_args._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum alluxio.thrift.FileSystemMasterClientService.remove_result._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum alluxio.thrift.FileSystemMasterClientService.rename_args._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum alluxio.thrift.FileSystemMasterClientService.rename_result._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum alluxio.thrift.FileSystemMasterClientService.scheduleAsyncPersistence_args._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum alluxio.thrift.FileSystemMasterClientService.scheduleAsyncPersistence_result._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum alluxio.thrift.FileSystemMasterClientService.setAttribute_args._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum alluxio.thrift.FileSystemMasterClientService.setAttribute_result._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum alluxio.thrift.FileSystemMasterClientService.unmount_args._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum alluxio.thrift.FileSystemMasterClientService.unmount_result._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum alluxio.thrift.FileSystemMasterClientService.updateUfsMode_args._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum alluxio.thrift.FileSystemMasterClientService.updateUfsMode_result._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum alluxio.thrift.FileSystemMasterCommonTOptions._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum alluxio.thrift.FileSystemMasterWorkerService.fileSystemHeartbeat_args._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum alluxio.thrift.FileSystemMasterWorkerService.fileSystemHeartbeat_result._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum alluxio.thrift.FileSystemMasterWorkerService.getFileInfo_args._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum alluxio.thrift.FileSystemMasterWorkerService.getFileInfo_result._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum alluxio.thrift.FileSystemMasterWorkerService.getPinnedFileIds_args._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum alluxio.thrift.FileSystemMasterWorkerService.getPinnedFileIds_result._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum alluxio.thrift.FileSystemMasterWorkerService.getUfsInfo_args._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum alluxio.thrift.FileSystemMasterWorkerService.getUfsInfo_result._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum alluxio.thrift.FileSystemWorkerClientService.cancelUfsFile_args._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum alluxio.thrift.FileSystemWorkerClientService.cancelUfsFile_result._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum alluxio.thrift.FileSystemWorkerClientService.closeUfsFile_args._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum alluxio.thrift.FileSystemWorkerClientService.closeUfsFile_result._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum alluxio.thrift.FileSystemWorkerClientService.completeUfsFile_args._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum alluxio.thrift.FileSystemWorkerClientService.completeUfsFile_result._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum alluxio.thrift.FileSystemWorkerClientService.createUfsFile_args._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum alluxio.thrift.FileSystemWorkerClientService.createUfsFile_result._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum alluxio.thrift.FileSystemWorkerClientService.openUfsFile_args._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum alluxio.thrift.FileSystemWorkerClientService.openUfsFile_result._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum alluxio.thrift.FileSystemWorkerClientService.sessionFileSystemHeartbeat_args._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum alluxio.thrift.FileSystemWorkerClientService.sessionFileSystemHeartbeat_result._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum alluxio.thrift.FreeTOptions._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum alluxio.thrift.FreeTResponse._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum alluxio.thrift.GetBlockInfoTOptions._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum alluxio.thrift.GetBlockInfoTResponse._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum alluxio.thrift.GetBlockMasterInfoTOptions._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum alluxio.thrift.GetBlockMasterInfoTResponse._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum alluxio.thrift.GetCapacityBytesTOptions._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum alluxio.thrift.GetCapacityBytesTResponse._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum alluxio.thrift.GetConfigReportTOptions._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum alluxio.thrift.GetConfigReportTResponse._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum alluxio.thrift.GetConfigurationTOptions._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum alluxio.thrift.GetConfigurationTResponse._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum alluxio.thrift.GetFileInfoTOptions._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum alluxio.thrift.GetFileInfoTResponse._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum alluxio.thrift.GetFilePathTOptions._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum alluxio.thrift.GetFilePathTResponse._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum alluxio.thrift.GetLineageInfoListTOptions._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum alluxio.thrift.GetLineageInfoListTResponse._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum alluxio.thrift.GetMasterIdTOptions._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum alluxio.thrift.GetMasterIdTResponse._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum alluxio.thrift.GetMasterInfoTOptions._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum alluxio.thrift.GetMasterInfoTResponse._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum alluxio.thrift.GetMetricsTOptions._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum alluxio.thrift.GetMetricsTResponse._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum alluxio.thrift.GetMountTableTResponse._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum alluxio.thrift.GetNewBlockIdForFileTOptions._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum alluxio.thrift.GetNewBlockIdForFileTResponse._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum alluxio.thrift.GetNextKeysTOptions._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum alluxio.thrift.GetNextKeysTResponse._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum alluxio.thrift.GetPartitionInfoTOptions._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum alluxio.thrift.GetPartitionInfoTResponse._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum alluxio.thrift.GetPinnedFileIdsTOptions._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum alluxio.thrift.GetPinnedFileIdsTResponse._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum alluxio.thrift.GetServiceVersionTOptions._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum alluxio.thrift.GetServiceVersionTResponse._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum alluxio.thrift.GetSizeTOptions._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum alluxio.thrift.GetSizeTResponse._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum alluxio.thrift.GetStatusTOptions._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum alluxio.thrift.GetStatusTResponse._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum alluxio.thrift.GetTOptions._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum alluxio.thrift.GetTResponse._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum alluxio.thrift.GetUfsInfoTOptions._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum alluxio.thrift.GetUfsInfoTResponse._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum alluxio.thrift.GetUsedBytesTOptions._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum alluxio.thrift.GetUsedBytesTResponse._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum alluxio.thrift.GetWorkerIdTOptions._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum alluxio.thrift.GetWorkerIdTResponse._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum alluxio.thrift.GetWorkerInfoListTOptions._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum alluxio.thrift.GetWorkerInfoListTResponse._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum alluxio.thrift.GetWorkerReportTOptions._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum alluxio.thrift.InconsistentProperty._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum alluxio.thrift.JobConfInfo._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum alluxio.thrift.KeyValueMasterClientService.completePartition_args._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum alluxio.thrift.KeyValueMasterClientService.completePartition_result._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum alluxio.thrift.KeyValueMasterClientService.completeStore_args._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum alluxio.thrift.KeyValueMasterClientService.completeStore_result._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum alluxio.thrift.KeyValueMasterClientService.createStore_args._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum alluxio.thrift.KeyValueMasterClientService.createStore_result._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum alluxio.thrift.KeyValueMasterClientService.deleteStore_args._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum alluxio.thrift.KeyValueMasterClientService.deleteStore_result._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum alluxio.thrift.KeyValueMasterClientService.getPartitionInfo_args._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum alluxio.thrift.KeyValueMasterClientService.getPartitionInfo_result._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum alluxio.thrift.KeyValueMasterClientService.mergeStore_args._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum alluxio.thrift.KeyValueMasterClientService.mergeStore_result._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum alluxio.thrift.KeyValueMasterClientService.renameStore_args._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum alluxio.thrift.KeyValueMasterClientService.renameStore_result._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum alluxio.thrift.KeyValueWorkerClientService.get_args._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum alluxio.thrift.KeyValueWorkerClientService.get_result._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum alluxio.thrift.KeyValueWorkerClientService.getNextKeys_args._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum alluxio.thrift.KeyValueWorkerClientService.getNextKeys_result._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum alluxio.thrift.KeyValueWorkerClientService.getSize_args._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum alluxio.thrift.KeyValueWorkerClientService.getSize_result._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum alluxio.thrift.LineageInfo._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum alluxio.thrift.LineageMasterClientService.createLineage_args._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum alluxio.thrift.LineageMasterClientService.createLineage_result._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum alluxio.thrift.LineageMasterClientService.deleteLineage_args._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum alluxio.thrift.LineageMasterClientService.deleteLineage_result._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum alluxio.thrift.LineageMasterClientService.getLineageInfoList_args._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum alluxio.thrift.LineageMasterClientService.getLineageInfoList_result._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum alluxio.thrift.LineageMasterClientService.reinitializeFile_args._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum alluxio.thrift.LineageMasterClientService.reinitializeFile_result._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum alluxio.thrift.LineageMasterClientService.reportLostFile_args._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum alluxio.thrift.LineageMasterClientService.reportLostFile_result._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum alluxio.thrift.ListStatusTOptions._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum alluxio.thrift.ListStatusTResponse._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum alluxio.thrift.LoadMetadataTOptions._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum alluxio.thrift.LoadMetadataTResponse._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum alluxio.thrift.LocalityTier._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum alluxio.thrift.LockBlockTOptions._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum alluxio.thrift.LockBlockTResponse._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum alluxio.thrift.MasterHeartbeatTOptions._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum alluxio.thrift.MasterHeartbeatTResponse._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum alluxio.thrift.MasterInfo._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum alluxio.thrift.MasterNetAddress._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum alluxio.thrift.MergeStoreTOptions._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum alluxio.thrift.MergeStoreTResponse._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum alluxio.thrift.MetaMasterClientService.backup_args._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum alluxio.thrift.MetaMasterClientService.backup_result._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum alluxio.thrift.MetaMasterClientService.getConfigReport_args._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum alluxio.thrift.MetaMasterClientService.getConfigReport_result._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum alluxio.thrift.MetaMasterClientService.getConfiguration_args._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum alluxio.thrift.MetaMasterClientService.getConfiguration_result._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum alluxio.thrift.MetaMasterClientService.getMasterInfo_args._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum alluxio.thrift.MetaMasterClientService.getMasterInfo_result._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum alluxio.thrift.MetaMasterClientService.getMetrics_args._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum alluxio.thrift.MetaMasterClientService.getMetrics_result._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum alluxio.thrift.MetaMasterMasterService.getMasterId_args._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum alluxio.thrift.MetaMasterMasterService.getMasterId_result._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum alluxio.thrift.MetaMasterMasterService.masterHeartbeat_args._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum alluxio.thrift.MetaMasterMasterService.masterHeartbeat_result._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum alluxio.thrift.MetaMasterMasterService.registerMaster_args._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum alluxio.thrift.MetaMasterMasterService.registerMaster_result._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum alluxio.thrift.Metric._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum alluxio.thrift.MetricsHeartbeatTOptions._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum alluxio.thrift.MetricsHeartbeatTResponse._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum alluxio.thrift.MetricsMasterClientService.metricsHeartbeat_args._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum alluxio.thrift.MetricsMasterClientService.metricsHeartbeat_result._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum alluxio.thrift.MetricValue._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum alluxio.thrift.MountPointInfo._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum alluxio.thrift.MountTOptions._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum alluxio.thrift.MountTResponse._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum alluxio.thrift.OpenUfsFileTOptions._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum alluxio.thrift.OpenUfsFileTResponse._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum alluxio.thrift.OptionalString._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum alluxio.thrift.PartitionInfo._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum alluxio.thrift.PersistCommandOptions._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum alluxio.thrift.PersistFile._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum alluxio.thrift.PromoteBlockTOptions._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum alluxio.thrift.PromoteBlockTResponse._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum alluxio.thrift.RegisterMasterTOptions._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum alluxio.thrift.RegisterMasterTResponse._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum alluxio.thrift.RegisterWorkerTOptions._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum alluxio.thrift.RegisterWorkerTResponse._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum alluxio.thrift.ReinitializeFileTOptions._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum alluxio.thrift.ReinitializeFileTResponse._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum alluxio.thrift.RemoveBlockTOptions._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum alluxio.thrift.RemoveBlockTResponse._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum alluxio.thrift.RenameStoreTOptions._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum alluxio.thrift.RenameStoreTResponse._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum alluxio.thrift.RenameTOptions._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum alluxio.thrift.RenameTResponse._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum alluxio.thrift.ReportLostFileTOptions._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum alluxio.thrift.ReportLostFileTResponse._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum alluxio.thrift.RequestBlockLocationTOptions._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum alluxio.thrift.RequestBlockLocationTResponse._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum alluxio.thrift.RequestSpaceTOptions._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum alluxio.thrift.RequestSpaceTResponse._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum alluxio.thrift.ScheduleAsyncPersistenceTOptions._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum alluxio.thrift.ScheduleAsyncPersistenceTResponse._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum alluxio.thrift.SessionBlockHeartbeatTOptions._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum alluxio.thrift.SessionBlockHeartbeatTResponse._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum alluxio.thrift.SessionFileSystemHeartbeatTOptions._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum alluxio.thrift.SessionFileSystemHeartbeatTResponse._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum alluxio.thrift.SetAttributeTOptions._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum alluxio.thrift.SetAttributeTResponse._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum alluxio.thrift.SyncMetadataTOptions._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum alluxio.thrift.SyncMetadataTResponse._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum alluxio.thrift.TieredIdentity._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum alluxio.thrift.UfsInfo._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum alluxio.thrift.UnlockBlockTOptions._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum alluxio.thrift.UnlockBlockTResponse._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum alluxio.thrift.UnmountTOptions._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum alluxio.thrift.UnmountTResponse._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum alluxio.thrift.UpdateUfsModeTOptions._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum alluxio.thrift.UpdateUfsModeTResponse._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum alluxio.thrift.WorkerInfo._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum alluxio.thrift.WorkerNetAddress._Fields
Find the _Fields constant that matches name, or null if its not found.
findByThriftId(int) - Static method in enum alluxio.thrift.AccessBlockTOptions._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum alluxio.thrift.AccessBlockTResponse._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum alluxio.thrift.AlluxioService.getServiceVersion_args._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum alluxio.thrift.AlluxioService.getServiceVersion_result._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum alluxio.thrift.AlluxioTException._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum alluxio.thrift.BackupTOptions._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum alluxio.thrift.BackupTResponse._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum alluxio.thrift.BlockHeartbeatTOptions._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum alluxio.thrift.BlockHeartbeatTResponse._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum alluxio.thrift.BlockInfo._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum alluxio.thrift.BlockLocation._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum alluxio.thrift.BlockMasterClientService.getBlockInfo_args._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum alluxio.thrift.BlockMasterClientService.getBlockInfo_result._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum alluxio.thrift.BlockMasterClientService.getBlockMasterInfo_args._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum alluxio.thrift.BlockMasterClientService.getBlockMasterInfo_result._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum alluxio.thrift.BlockMasterClientService.getCapacityBytes_args._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum alluxio.thrift.BlockMasterClientService.getCapacityBytes_result._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum alluxio.thrift.BlockMasterClientService.getUsedBytes_args._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum alluxio.thrift.BlockMasterClientService.getUsedBytes_result._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum alluxio.thrift.BlockMasterClientService.getWorkerInfoList_args._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum alluxio.thrift.BlockMasterClientService.getWorkerInfoList_result._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum alluxio.thrift.BlockMasterClientService.getWorkerReport_args._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum alluxio.thrift.BlockMasterClientService.getWorkerReport_result._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum alluxio.thrift.BlockMasterInfo._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum alluxio.thrift.BlockMasterWorkerService.blockHeartbeat_args._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum alluxio.thrift.BlockMasterWorkerService.blockHeartbeat_result._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum alluxio.thrift.BlockMasterWorkerService.commitBlock_args._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum alluxio.thrift.BlockMasterWorkerService.commitBlock_result._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum alluxio.thrift.BlockMasterWorkerService.getWorkerId_args._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum alluxio.thrift.BlockMasterWorkerService.getWorkerId_result._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum alluxio.thrift.BlockMasterWorkerService.registerWorker_args._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum alluxio.thrift.BlockMasterWorkerService.registerWorker_result._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum alluxio.thrift.BlockWorkerClientService.accessBlock_args._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum alluxio.thrift.BlockWorkerClientService.accessBlock_result._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum alluxio.thrift.BlockWorkerClientService.cacheBlock_args._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum alluxio.thrift.BlockWorkerClientService.cacheBlock_result._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum alluxio.thrift.BlockWorkerClientService.cancelBlock_args._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum alluxio.thrift.BlockWorkerClientService.cancelBlock_result._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum alluxio.thrift.BlockWorkerClientService.lockBlock_args._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum alluxio.thrift.BlockWorkerClientService.lockBlock_result._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum alluxio.thrift.BlockWorkerClientService.promoteBlock_args._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum alluxio.thrift.BlockWorkerClientService.promoteBlock_result._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum alluxio.thrift.BlockWorkerClientService.removeBlock_args._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum alluxio.thrift.BlockWorkerClientService.removeBlock_result._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum alluxio.thrift.BlockWorkerClientService.requestBlockLocation_args._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum alluxio.thrift.BlockWorkerClientService.requestBlockLocation_result._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum alluxio.thrift.BlockWorkerClientService.requestSpace_args._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum alluxio.thrift.BlockWorkerClientService.requestSpace_result._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum alluxio.thrift.BlockWorkerClientService.sessionBlockHeartbeat_args._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum alluxio.thrift.BlockWorkerClientService.sessionBlockHeartbeat_result._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum alluxio.thrift.BlockWorkerClientService.unlockBlock_args._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum alluxio.thrift.BlockWorkerClientService.unlockBlock_result._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum alluxio.thrift.CacheBlockTOptions._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum alluxio.thrift.CacheBlockTResponse._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum alluxio.thrift.CancelBlockTOptions._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum alluxio.thrift.CancelBlockTResponse._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum alluxio.thrift.CancelUfsFileTOptions._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum alluxio.thrift.CancelUfsFileTResponse._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum alluxio.thrift.CheckConsistencyTOptions._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum alluxio.thrift.CheckConsistencyTResponse._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum alluxio.thrift.CloseUfsFileTOptions._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum alluxio.thrift.CloseUfsFileTResponse._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum alluxio.thrift.Command._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum alluxio.thrift.CommandLineJobInfo._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum alluxio.thrift.CommitBlockTOptions._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum alluxio.thrift.CommitBlockTResponse._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum alluxio.thrift.CompleteFileTOptions._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum alluxio.thrift.CompleteFileTResponse._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum alluxio.thrift.CompletePartitionTOptions._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum alluxio.thrift.CompletePartitionTResponse._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum alluxio.thrift.CompleteStoreTOptions._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum alluxio.thrift.CompleteStoreTResponse._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum alluxio.thrift.CompleteUfsFileTOptions._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum alluxio.thrift.CompleteUfsFileTReponse._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum alluxio.thrift.ConfigCheckReport._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum alluxio.thrift.ConfigProperty._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum alluxio.thrift.CreateDirectoryTOptions._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum alluxio.thrift.CreateDirectoryTResponse._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum alluxio.thrift.CreateFileTOptions._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum alluxio.thrift.CreateFileTResponse._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum alluxio.thrift.CreateLineageTOptions._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum alluxio.thrift.CreateLineageTResponse._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum alluxio.thrift.CreateStoreTOptions._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum alluxio.thrift.CreateStoreTResponse._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum alluxio.thrift.CreateUfsFileTOptions._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum alluxio.thrift.CreateUfsFileTResponse._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum alluxio.thrift.DeleteLineageTOptions._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum alluxio.thrift.DeleteLineageTResponse._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum alluxio.thrift.DeleteStoreTOptions._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum alluxio.thrift.DeleteStoreTResponse._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum alluxio.thrift.DeleteTOptions._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum alluxio.thrift.DeleteTResponse._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum alluxio.thrift.DependencyInfo._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum alluxio.thrift.FileBlockInfo._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum alluxio.thrift.FileInfo._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum alluxio.thrift.FileSystemCommand._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum alluxio.thrift.FileSystemCommandOptions._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum alluxio.thrift.FileSystemHeartbeatTOptions._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum alluxio.thrift.FileSystemHeartbeatTResponse._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum alluxio.thrift.FileSystemMasterClientService.checkConsistency_args._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum alluxio.thrift.FileSystemMasterClientService.checkConsistency_result._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum alluxio.thrift.FileSystemMasterClientService.completeFile_args._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum alluxio.thrift.FileSystemMasterClientService.completeFile_result._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum alluxio.thrift.FileSystemMasterClientService.createDirectory_args._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum alluxio.thrift.FileSystemMasterClientService.createDirectory_result._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum alluxio.thrift.FileSystemMasterClientService.createFile_args._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum alluxio.thrift.FileSystemMasterClientService.createFile_result._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum alluxio.thrift.FileSystemMasterClientService.free_args._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum alluxio.thrift.FileSystemMasterClientService.free_result._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum alluxio.thrift.FileSystemMasterClientService.getFilePath_args._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum alluxio.thrift.FileSystemMasterClientService.getFilePath_result._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum alluxio.thrift.FileSystemMasterClientService.getMountTable_args._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum alluxio.thrift.FileSystemMasterClientService.getMountTable_result._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum alluxio.thrift.FileSystemMasterClientService.getNewBlockIdForFile_args._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum alluxio.thrift.FileSystemMasterClientService.getNewBlockIdForFile_result._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum alluxio.thrift.FileSystemMasterClientService.getStatus_args._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum alluxio.thrift.FileSystemMasterClientService.getStatus_result._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum alluxio.thrift.FileSystemMasterClientService.listStatus_args._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum alluxio.thrift.FileSystemMasterClientService.listStatus_result._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum alluxio.thrift.FileSystemMasterClientService.loadMetadata_args._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum alluxio.thrift.FileSystemMasterClientService.loadMetadata_result._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum alluxio.thrift.FileSystemMasterClientService.mount_args._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum alluxio.thrift.FileSystemMasterClientService.mount_result._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum alluxio.thrift.FileSystemMasterClientService.remove_args._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum alluxio.thrift.FileSystemMasterClientService.remove_result._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum alluxio.thrift.FileSystemMasterClientService.rename_args._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum alluxio.thrift.FileSystemMasterClientService.rename_result._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum alluxio.thrift.FileSystemMasterClientService.scheduleAsyncPersistence_args._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum alluxio.thrift.FileSystemMasterClientService.scheduleAsyncPersistence_result._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum alluxio.thrift.FileSystemMasterClientService.setAttribute_args._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum alluxio.thrift.FileSystemMasterClientService.setAttribute_result._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum alluxio.thrift.FileSystemMasterClientService.unmount_args._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum alluxio.thrift.FileSystemMasterClientService.unmount_result._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum alluxio.thrift.FileSystemMasterClientService.updateUfsMode_args._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum alluxio.thrift.FileSystemMasterClientService.updateUfsMode_result._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum alluxio.thrift.FileSystemMasterCommonTOptions._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum alluxio.thrift.FileSystemMasterWorkerService.fileSystemHeartbeat_args._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum alluxio.thrift.FileSystemMasterWorkerService.fileSystemHeartbeat_result._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum alluxio.thrift.FileSystemMasterWorkerService.getFileInfo_args._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum alluxio.thrift.FileSystemMasterWorkerService.getFileInfo_result._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum alluxio.thrift.FileSystemMasterWorkerService.getPinnedFileIds_args._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum alluxio.thrift.FileSystemMasterWorkerService.getPinnedFileIds_result._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum alluxio.thrift.FileSystemMasterWorkerService.getUfsInfo_args._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum alluxio.thrift.FileSystemMasterWorkerService.getUfsInfo_result._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum alluxio.thrift.FileSystemWorkerClientService.cancelUfsFile_args._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum alluxio.thrift.FileSystemWorkerClientService.cancelUfsFile_result._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum alluxio.thrift.FileSystemWorkerClientService.closeUfsFile_args._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum alluxio.thrift.FileSystemWorkerClientService.closeUfsFile_result._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum alluxio.thrift.FileSystemWorkerClientService.completeUfsFile_args._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum alluxio.thrift.FileSystemWorkerClientService.completeUfsFile_result._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum alluxio.thrift.FileSystemWorkerClientService.createUfsFile_args._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum alluxio.thrift.FileSystemWorkerClientService.createUfsFile_result._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum alluxio.thrift.FileSystemWorkerClientService.openUfsFile_args._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum alluxio.thrift.FileSystemWorkerClientService.openUfsFile_result._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum alluxio.thrift.FileSystemWorkerClientService.sessionFileSystemHeartbeat_args._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum alluxio.thrift.FileSystemWorkerClientService.sessionFileSystemHeartbeat_result._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum alluxio.thrift.FreeTOptions._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum alluxio.thrift.FreeTResponse._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum alluxio.thrift.GetBlockInfoTOptions._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum alluxio.thrift.GetBlockInfoTResponse._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum alluxio.thrift.GetBlockMasterInfoTOptions._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum alluxio.thrift.GetBlockMasterInfoTResponse._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum alluxio.thrift.GetCapacityBytesTOptions._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum alluxio.thrift.GetCapacityBytesTResponse._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum alluxio.thrift.GetConfigReportTOptions._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum alluxio.thrift.GetConfigReportTResponse._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum alluxio.thrift.GetConfigurationTOptions._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum alluxio.thrift.GetConfigurationTResponse._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum alluxio.thrift.GetFileInfoTOptions._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum alluxio.thrift.GetFileInfoTResponse._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum alluxio.thrift.GetFilePathTOptions._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum alluxio.thrift.GetFilePathTResponse._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum alluxio.thrift.GetLineageInfoListTOptions._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum alluxio.thrift.GetLineageInfoListTResponse._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum alluxio.thrift.GetMasterIdTOptions._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum alluxio.thrift.GetMasterIdTResponse._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum alluxio.thrift.GetMasterInfoTOptions._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum alluxio.thrift.GetMasterInfoTResponse._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum alluxio.thrift.GetMetricsTOptions._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum alluxio.thrift.GetMetricsTResponse._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum alluxio.thrift.GetMountTableTResponse._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum alluxio.thrift.GetNewBlockIdForFileTOptions._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum alluxio.thrift.GetNewBlockIdForFileTResponse._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum alluxio.thrift.GetNextKeysTOptions._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum alluxio.thrift.GetNextKeysTResponse._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum alluxio.thrift.GetPartitionInfoTOptions._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum alluxio.thrift.GetPartitionInfoTResponse._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum alluxio.thrift.GetPinnedFileIdsTOptions._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum alluxio.thrift.GetPinnedFileIdsTResponse._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum alluxio.thrift.GetServiceVersionTOptions._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum alluxio.thrift.GetServiceVersionTResponse._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum alluxio.thrift.GetSizeTOptions._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum alluxio.thrift.GetSizeTResponse._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum alluxio.thrift.GetStatusTOptions._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum alluxio.thrift.GetStatusTResponse._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum alluxio.thrift.GetTOptions._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum alluxio.thrift.GetTResponse._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum alluxio.thrift.GetUfsInfoTOptions._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum alluxio.thrift.GetUfsInfoTResponse._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum alluxio.thrift.GetUsedBytesTOptions._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum alluxio.thrift.GetUsedBytesTResponse._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum alluxio.thrift.GetWorkerIdTOptions._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum alluxio.thrift.GetWorkerIdTResponse._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum alluxio.thrift.GetWorkerInfoListTOptions._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum alluxio.thrift.GetWorkerInfoListTResponse._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum alluxio.thrift.GetWorkerReportTOptions._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum alluxio.thrift.InconsistentProperty._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum alluxio.thrift.JobConfInfo._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum alluxio.thrift.KeyValueMasterClientService.completePartition_args._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum alluxio.thrift.KeyValueMasterClientService.completePartition_result._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum alluxio.thrift.KeyValueMasterClientService.completeStore_args._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum alluxio.thrift.KeyValueMasterClientService.completeStore_result._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum alluxio.thrift.KeyValueMasterClientService.createStore_args._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum alluxio.thrift.KeyValueMasterClientService.createStore_result._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum alluxio.thrift.KeyValueMasterClientService.deleteStore_args._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum alluxio.thrift.KeyValueMasterClientService.deleteStore_result._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum alluxio.thrift.KeyValueMasterClientService.getPartitionInfo_args._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum alluxio.thrift.KeyValueMasterClientService.getPartitionInfo_result._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum alluxio.thrift.KeyValueMasterClientService.mergeStore_args._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum alluxio.thrift.KeyValueMasterClientService.mergeStore_result._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum alluxio.thrift.KeyValueMasterClientService.renameStore_args._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum alluxio.thrift.KeyValueMasterClientService.renameStore_result._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum alluxio.thrift.KeyValueWorkerClientService.get_args._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum alluxio.thrift.KeyValueWorkerClientService.get_result._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum alluxio.thrift.KeyValueWorkerClientService.getNextKeys_args._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum alluxio.thrift.KeyValueWorkerClientService.getNextKeys_result._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum alluxio.thrift.KeyValueWorkerClientService.getSize_args._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum alluxio.thrift.KeyValueWorkerClientService.getSize_result._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum alluxio.thrift.LineageInfo._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum alluxio.thrift.LineageMasterClientService.createLineage_args._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum alluxio.thrift.LineageMasterClientService.createLineage_result._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum alluxio.thrift.LineageMasterClientService.deleteLineage_args._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum alluxio.thrift.LineageMasterClientService.deleteLineage_result._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum alluxio.thrift.LineageMasterClientService.getLineageInfoList_args._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum alluxio.thrift.LineageMasterClientService.getLineageInfoList_result._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum alluxio.thrift.LineageMasterClientService.reinitializeFile_args._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum alluxio.thrift.LineageMasterClientService.reinitializeFile_result._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum alluxio.thrift.LineageMasterClientService.reportLostFile_args._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum alluxio.thrift.LineageMasterClientService.reportLostFile_result._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum alluxio.thrift.ListStatusTOptions._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum alluxio.thrift.ListStatusTResponse._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum alluxio.thrift.LoadMetadataTOptions._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum alluxio.thrift.LoadMetadataTResponse._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum alluxio.thrift.LocalityTier._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum alluxio.thrift.LockBlockTOptions._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum alluxio.thrift.LockBlockTResponse._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum alluxio.thrift.MasterHeartbeatTOptions._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum alluxio.thrift.MasterHeartbeatTResponse._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum alluxio.thrift.MasterInfo._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum alluxio.thrift.MasterNetAddress._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum alluxio.thrift.MergeStoreTOptions._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum alluxio.thrift.MergeStoreTResponse._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum alluxio.thrift.MetaMasterClientService.backup_args._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum alluxio.thrift.MetaMasterClientService.backup_result._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum alluxio.thrift.MetaMasterClientService.getConfigReport_args._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum alluxio.thrift.MetaMasterClientService.getConfigReport_result._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum alluxio.thrift.MetaMasterClientService.getConfiguration_args._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum alluxio.thrift.MetaMasterClientService.getConfiguration_result._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum alluxio.thrift.MetaMasterClientService.getMasterInfo_args._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum alluxio.thrift.MetaMasterClientService.getMasterInfo_result._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum alluxio.thrift.MetaMasterClientService.getMetrics_args._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum alluxio.thrift.MetaMasterClientService.getMetrics_result._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum alluxio.thrift.MetaMasterMasterService.getMasterId_args._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum alluxio.thrift.MetaMasterMasterService.getMasterId_result._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum alluxio.thrift.MetaMasterMasterService.masterHeartbeat_args._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum alluxio.thrift.MetaMasterMasterService.masterHeartbeat_result._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum alluxio.thrift.MetaMasterMasterService.registerMaster_args._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum alluxio.thrift.MetaMasterMasterService.registerMaster_result._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum alluxio.thrift.Metric._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum alluxio.thrift.MetricsHeartbeatTOptions._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum alluxio.thrift.MetricsHeartbeatTResponse._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum alluxio.thrift.MetricsMasterClientService.metricsHeartbeat_args._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum alluxio.thrift.MetricsMasterClientService.metricsHeartbeat_result._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum alluxio.thrift.MetricValue._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum alluxio.thrift.MountPointInfo._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum alluxio.thrift.MountTOptions._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum alluxio.thrift.MountTResponse._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum alluxio.thrift.OpenUfsFileTOptions._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum alluxio.thrift.OpenUfsFileTResponse._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum alluxio.thrift.OptionalString._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum alluxio.thrift.PartitionInfo._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum alluxio.thrift.PersistCommandOptions._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum alluxio.thrift.PersistFile._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum alluxio.thrift.PromoteBlockTOptions._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum alluxio.thrift.PromoteBlockTResponse._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum alluxio.thrift.RegisterMasterTOptions._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum alluxio.thrift.RegisterMasterTResponse._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum alluxio.thrift.RegisterWorkerTOptions._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum alluxio.thrift.RegisterWorkerTResponse._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum alluxio.thrift.ReinitializeFileTOptions._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum alluxio.thrift.ReinitializeFileTResponse._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum alluxio.thrift.RemoveBlockTOptions._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum alluxio.thrift.RemoveBlockTResponse._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum alluxio.thrift.RenameStoreTOptions._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum alluxio.thrift.RenameStoreTResponse._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum alluxio.thrift.RenameTOptions._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum alluxio.thrift.RenameTResponse._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum alluxio.thrift.ReportLostFileTOptions._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum alluxio.thrift.ReportLostFileTResponse._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum alluxio.thrift.RequestBlockLocationTOptions._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum alluxio.thrift.RequestBlockLocationTResponse._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum alluxio.thrift.RequestSpaceTOptions._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum alluxio.thrift.RequestSpaceTResponse._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum alluxio.thrift.ScheduleAsyncPersistenceTOptions._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum alluxio.thrift.ScheduleAsyncPersistenceTResponse._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum alluxio.thrift.SessionBlockHeartbeatTOptions._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum alluxio.thrift.SessionBlockHeartbeatTResponse._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum alluxio.thrift.SessionFileSystemHeartbeatTOptions._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum alluxio.thrift.SessionFileSystemHeartbeatTResponse._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum alluxio.thrift.SetAttributeTOptions._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum alluxio.thrift.SetAttributeTResponse._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum alluxio.thrift.SyncMetadataTOptions._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum alluxio.thrift.SyncMetadataTResponse._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum alluxio.thrift.TieredIdentity._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum alluxio.thrift.UfsInfo._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum alluxio.thrift.UnlockBlockTOptions._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum alluxio.thrift.UnlockBlockTResponse._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum alluxio.thrift.UnmountTOptions._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum alluxio.thrift.UnmountTResponse._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum alluxio.thrift.UpdateUfsModeTOptions._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum alluxio.thrift.UpdateUfsModeTResponse._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum alluxio.thrift.WorkerInfo._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum alluxio.thrift.WorkerNetAddress._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftIdOrThrow(int) - Static method in enum alluxio.thrift.AccessBlockTOptions._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum alluxio.thrift.AccessBlockTResponse._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum alluxio.thrift.AlluxioService.getServiceVersion_args._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum alluxio.thrift.AlluxioService.getServiceVersion_result._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum alluxio.thrift.AlluxioTException._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum alluxio.thrift.BackupTOptions._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum alluxio.thrift.BackupTResponse._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum alluxio.thrift.BlockHeartbeatTOptions._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum alluxio.thrift.BlockHeartbeatTResponse._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum alluxio.thrift.BlockInfo._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum alluxio.thrift.BlockLocation._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum alluxio.thrift.BlockMasterClientService.getBlockInfo_args._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum alluxio.thrift.BlockMasterClientService.getBlockInfo_result._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum alluxio.thrift.BlockMasterClientService.getBlockMasterInfo_args._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum alluxio.thrift.BlockMasterClientService.getBlockMasterInfo_result._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum alluxio.thrift.BlockMasterClientService.getCapacityBytes_args._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum alluxio.thrift.BlockMasterClientService.getCapacityBytes_result._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum alluxio.thrift.BlockMasterClientService.getUsedBytes_args._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum alluxio.thrift.BlockMasterClientService.getUsedBytes_result._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum alluxio.thrift.BlockMasterClientService.getWorkerInfoList_args._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum alluxio.thrift.BlockMasterClientService.getWorkerInfoList_result._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum alluxio.thrift.BlockMasterClientService.getWorkerReport_args._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum alluxio.thrift.BlockMasterClientService.getWorkerReport_result._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum alluxio.thrift.BlockMasterInfo._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum alluxio.thrift.BlockMasterWorkerService.blockHeartbeat_args._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum alluxio.thrift.BlockMasterWorkerService.blockHeartbeat_result._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum alluxio.thrift.BlockMasterWorkerService.commitBlock_args._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum alluxio.thrift.BlockMasterWorkerService.commitBlock_result._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum alluxio.thrift.BlockMasterWorkerService.getWorkerId_args._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum alluxio.thrift.BlockMasterWorkerService.getWorkerId_result._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum alluxio.thrift.BlockMasterWorkerService.registerWorker_args._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum alluxio.thrift.BlockMasterWorkerService.registerWorker_result._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum alluxio.thrift.BlockWorkerClientService.accessBlock_args._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum alluxio.thrift.BlockWorkerClientService.accessBlock_result._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum alluxio.thrift.BlockWorkerClientService.cacheBlock_args._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum alluxio.thrift.BlockWorkerClientService.cacheBlock_result._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum alluxio.thrift.BlockWorkerClientService.cancelBlock_args._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum alluxio.thrift.BlockWorkerClientService.cancelBlock_result._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum alluxio.thrift.BlockWorkerClientService.lockBlock_args._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum alluxio.thrift.BlockWorkerClientService.lockBlock_result._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum alluxio.thrift.BlockWorkerClientService.promoteBlock_args._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum alluxio.thrift.BlockWorkerClientService.promoteBlock_result._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum alluxio.thrift.BlockWorkerClientService.removeBlock_args._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum alluxio.thrift.BlockWorkerClientService.removeBlock_result._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum alluxio.thrift.BlockWorkerClientService.requestBlockLocation_args._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum alluxio.thrift.BlockWorkerClientService.requestBlockLocation_result._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum alluxio.thrift.BlockWorkerClientService.requestSpace_args._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum alluxio.thrift.BlockWorkerClientService.requestSpace_result._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum alluxio.thrift.BlockWorkerClientService.sessionBlockHeartbeat_args._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum alluxio.thrift.BlockWorkerClientService.sessionBlockHeartbeat_result._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum alluxio.thrift.BlockWorkerClientService.unlockBlock_args._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum alluxio.thrift.BlockWorkerClientService.unlockBlock_result._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum alluxio.thrift.CacheBlockTOptions._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum alluxio.thrift.CacheBlockTResponse._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum alluxio.thrift.CancelBlockTOptions._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum alluxio.thrift.CancelBlockTResponse._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum alluxio.thrift.CancelUfsFileTOptions._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum alluxio.thrift.CancelUfsFileTResponse._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum alluxio.thrift.CheckConsistencyTOptions._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum alluxio.thrift.CheckConsistencyTResponse._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum alluxio.thrift.CloseUfsFileTOptions._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum alluxio.thrift.CloseUfsFileTResponse._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum alluxio.thrift.Command._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum alluxio.thrift.CommandLineJobInfo._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum alluxio.thrift.CommitBlockTOptions._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum alluxio.thrift.CommitBlockTResponse._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum alluxio.thrift.CompleteFileTOptions._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum alluxio.thrift.CompleteFileTResponse._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum alluxio.thrift.CompletePartitionTOptions._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum alluxio.thrift.CompletePartitionTResponse._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum alluxio.thrift.CompleteStoreTOptions._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum alluxio.thrift.CompleteStoreTResponse._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum alluxio.thrift.CompleteUfsFileTOptions._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum alluxio.thrift.CompleteUfsFileTReponse._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum alluxio.thrift.ConfigCheckReport._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum alluxio.thrift.ConfigProperty._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum alluxio.thrift.CreateDirectoryTOptions._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum alluxio.thrift.CreateDirectoryTResponse._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum alluxio.thrift.CreateFileTOptions._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum alluxio.thrift.CreateFileTResponse._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum alluxio.thrift.CreateLineageTOptions._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum alluxio.thrift.CreateLineageTResponse._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum alluxio.thrift.CreateStoreTOptions._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum alluxio.thrift.CreateStoreTResponse._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum alluxio.thrift.CreateUfsFileTOptions._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum alluxio.thrift.CreateUfsFileTResponse._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum alluxio.thrift.DeleteLineageTOptions._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum alluxio.thrift.DeleteLineageTResponse._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum alluxio.thrift.DeleteStoreTOptions._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum alluxio.thrift.DeleteStoreTResponse._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum alluxio.thrift.DeleteTOptions._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum alluxio.thrift.DeleteTResponse._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum alluxio.thrift.DependencyInfo._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum alluxio.thrift.FileBlockInfo._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum alluxio.thrift.FileInfo._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum alluxio.thrift.FileSystemCommand._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum alluxio.thrift.FileSystemCommandOptions._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum alluxio.thrift.FileSystemHeartbeatTOptions._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum alluxio.thrift.FileSystemHeartbeatTResponse._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum alluxio.thrift.FileSystemMasterClientService.checkConsistency_args._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum alluxio.thrift.FileSystemMasterClientService.checkConsistency_result._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum alluxio.thrift.FileSystemMasterClientService.completeFile_args._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum alluxio.thrift.FileSystemMasterClientService.completeFile_result._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum alluxio.thrift.FileSystemMasterClientService.createDirectory_args._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum alluxio.thrift.FileSystemMasterClientService.createDirectory_result._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum alluxio.thrift.FileSystemMasterClientService.createFile_args._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum alluxio.thrift.FileSystemMasterClientService.createFile_result._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum alluxio.thrift.FileSystemMasterClientService.free_args._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum alluxio.thrift.FileSystemMasterClientService.free_result._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum alluxio.thrift.FileSystemMasterClientService.getFilePath_args._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum alluxio.thrift.FileSystemMasterClientService.getFilePath_result._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum alluxio.thrift.FileSystemMasterClientService.getMountTable_args._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum alluxio.thrift.FileSystemMasterClientService.getMountTable_result._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum alluxio.thrift.FileSystemMasterClientService.getNewBlockIdForFile_args._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum alluxio.thrift.FileSystemMasterClientService.getNewBlockIdForFile_result._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum alluxio.thrift.FileSystemMasterClientService.getStatus_args._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum alluxio.thrift.FileSystemMasterClientService.getStatus_result._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum alluxio.thrift.FileSystemMasterClientService.listStatus_args._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum alluxio.thrift.FileSystemMasterClientService.listStatus_result._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum alluxio.thrift.FileSystemMasterClientService.loadMetadata_args._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum alluxio.thrift.FileSystemMasterClientService.loadMetadata_result._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum alluxio.thrift.FileSystemMasterClientService.mount_args._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum alluxio.thrift.FileSystemMasterClientService.mount_result._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum alluxio.thrift.FileSystemMasterClientService.remove_args._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum alluxio.thrift.FileSystemMasterClientService.remove_result._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum alluxio.thrift.FileSystemMasterClientService.rename_args._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum alluxio.thrift.FileSystemMasterClientService.rename_result._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum alluxio.thrift.FileSystemMasterClientService.scheduleAsyncPersistence_args._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum alluxio.thrift.FileSystemMasterClientService.scheduleAsyncPersistence_result._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum alluxio.thrift.FileSystemMasterClientService.setAttribute_args._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum alluxio.thrift.FileSystemMasterClientService.setAttribute_result._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum alluxio.thrift.FileSystemMasterClientService.unmount_args._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum alluxio.thrift.FileSystemMasterClientService.unmount_result._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum alluxio.thrift.FileSystemMasterClientService.updateUfsMode_args._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum alluxio.thrift.FileSystemMasterClientService.updateUfsMode_result._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum alluxio.thrift.FileSystemMasterCommonTOptions._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum alluxio.thrift.FileSystemMasterWorkerService.fileSystemHeartbeat_args._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum alluxio.thrift.FileSystemMasterWorkerService.fileSystemHeartbeat_result._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum alluxio.thrift.FileSystemMasterWorkerService.getFileInfo_args._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum alluxio.thrift.FileSystemMasterWorkerService.getFileInfo_result._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum alluxio.thrift.FileSystemMasterWorkerService.getPinnedFileIds_args._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum alluxio.thrift.FileSystemMasterWorkerService.getPinnedFileIds_result._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum alluxio.thrift.FileSystemMasterWorkerService.getUfsInfo_args._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum alluxio.thrift.FileSystemMasterWorkerService.getUfsInfo_result._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum alluxio.thrift.FileSystemWorkerClientService.cancelUfsFile_args._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum alluxio.thrift.FileSystemWorkerClientService.cancelUfsFile_result._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum alluxio.thrift.FileSystemWorkerClientService.closeUfsFile_args._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum alluxio.thrift.FileSystemWorkerClientService.closeUfsFile_result._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum alluxio.thrift.FileSystemWorkerClientService.completeUfsFile_args._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum alluxio.thrift.FileSystemWorkerClientService.completeUfsFile_result._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum alluxio.thrift.FileSystemWorkerClientService.createUfsFile_args._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum alluxio.thrift.FileSystemWorkerClientService.createUfsFile_result._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum alluxio.thrift.FileSystemWorkerClientService.openUfsFile_args._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum alluxio.thrift.FileSystemWorkerClientService.openUfsFile_result._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum alluxio.thrift.FileSystemWorkerClientService.sessionFileSystemHeartbeat_args._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum alluxio.thrift.FileSystemWorkerClientService.sessionFileSystemHeartbeat_result._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum alluxio.thrift.FreeTOptions._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum alluxio.thrift.FreeTResponse._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum alluxio.thrift.GetBlockInfoTOptions._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum alluxio.thrift.GetBlockInfoTResponse._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum alluxio.thrift.GetBlockMasterInfoTOptions._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum alluxio.thrift.GetBlockMasterInfoTResponse._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum alluxio.thrift.GetCapacityBytesTOptions._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum alluxio.thrift.GetCapacityBytesTResponse._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum alluxio.thrift.GetConfigReportTOptions._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum alluxio.thrift.GetConfigReportTResponse._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum alluxio.thrift.GetConfigurationTOptions._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum alluxio.thrift.GetConfigurationTResponse._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum alluxio.thrift.GetFileInfoTOptions._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum alluxio.thrift.GetFileInfoTResponse._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum alluxio.thrift.GetFilePathTOptions._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum alluxio.thrift.GetFilePathTResponse._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum alluxio.thrift.GetLineageInfoListTOptions._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum alluxio.thrift.GetLineageInfoListTResponse._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum alluxio.thrift.GetMasterIdTOptions._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum alluxio.thrift.GetMasterIdTResponse._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum alluxio.thrift.GetMasterInfoTOptions._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum alluxio.thrift.GetMasterInfoTResponse._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum alluxio.thrift.GetMetricsTOptions._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum alluxio.thrift.GetMetricsTResponse._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum alluxio.thrift.GetMountTableTResponse._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum alluxio.thrift.GetNewBlockIdForFileTOptions._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum alluxio.thrift.GetNewBlockIdForFileTResponse._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum alluxio.thrift.GetNextKeysTOptions._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum alluxio.thrift.GetNextKeysTResponse._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum alluxio.thrift.GetPartitionInfoTOptions._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum alluxio.thrift.GetPartitionInfoTResponse._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum alluxio.thrift.GetPinnedFileIdsTOptions._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum alluxio.thrift.GetPinnedFileIdsTResponse._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum alluxio.thrift.GetServiceVersionTOptions._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum alluxio.thrift.GetServiceVersionTResponse._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum alluxio.thrift.GetSizeTOptions._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum alluxio.thrift.GetSizeTResponse._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum alluxio.thrift.GetStatusTOptions._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum alluxio.thrift.GetStatusTResponse._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum alluxio.thrift.GetTOptions._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum alluxio.thrift.GetTResponse._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum alluxio.thrift.GetUfsInfoTOptions._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum alluxio.thrift.GetUfsInfoTResponse._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum alluxio.thrift.GetUsedBytesTOptions._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum alluxio.thrift.GetUsedBytesTResponse._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum alluxio.thrift.GetWorkerIdTOptions._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum alluxio.thrift.GetWorkerIdTResponse._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum alluxio.thrift.GetWorkerInfoListTOptions._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum alluxio.thrift.GetWorkerInfoListTResponse._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum alluxio.thrift.GetWorkerReportTOptions._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum alluxio.thrift.InconsistentProperty._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum alluxio.thrift.JobConfInfo._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum alluxio.thrift.KeyValueMasterClientService.completePartition_args._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum alluxio.thrift.KeyValueMasterClientService.completePartition_result._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum alluxio.thrift.KeyValueMasterClientService.completeStore_args._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum alluxio.thrift.KeyValueMasterClientService.completeStore_result._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum alluxio.thrift.KeyValueMasterClientService.createStore_args._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum alluxio.thrift.KeyValueMasterClientService.createStore_result._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum alluxio.thrift.KeyValueMasterClientService.deleteStore_args._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum alluxio.thrift.KeyValueMasterClientService.deleteStore_result._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum alluxio.thrift.KeyValueMasterClientService.getPartitionInfo_args._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum alluxio.thrift.KeyValueMasterClientService.getPartitionInfo_result._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum alluxio.thrift.KeyValueMasterClientService.mergeStore_args._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum alluxio.thrift.KeyValueMasterClientService.mergeStore_result._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum alluxio.thrift.KeyValueMasterClientService.renameStore_args._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum alluxio.thrift.KeyValueMasterClientService.renameStore_result._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum alluxio.thrift.KeyValueWorkerClientService.get_args._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum alluxio.thrift.KeyValueWorkerClientService.get_result._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum alluxio.thrift.KeyValueWorkerClientService.getNextKeys_args._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum alluxio.thrift.KeyValueWorkerClientService.getNextKeys_result._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum alluxio.thrift.KeyValueWorkerClientService.getSize_args._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum alluxio.thrift.KeyValueWorkerClientService.getSize_result._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum alluxio.thrift.LineageInfo._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum alluxio.thrift.LineageMasterClientService.createLineage_args._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum alluxio.thrift.LineageMasterClientService.createLineage_result._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum alluxio.thrift.LineageMasterClientService.deleteLineage_args._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum alluxio.thrift.LineageMasterClientService.deleteLineage_result._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum alluxio.thrift.LineageMasterClientService.getLineageInfoList_args._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum alluxio.thrift.LineageMasterClientService.getLineageInfoList_result._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum alluxio.thrift.LineageMasterClientService.reinitializeFile_args._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum alluxio.thrift.LineageMasterClientService.reinitializeFile_result._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum alluxio.thrift.LineageMasterClientService.reportLostFile_args._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum alluxio.thrift.LineageMasterClientService.reportLostFile_result._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum alluxio.thrift.ListStatusTOptions._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum alluxio.thrift.ListStatusTResponse._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum alluxio.thrift.LoadMetadataTOptions._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum alluxio.thrift.LoadMetadataTResponse._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum alluxio.thrift.LocalityTier._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum alluxio.thrift.LockBlockTOptions._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum alluxio.thrift.LockBlockTResponse._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum alluxio.thrift.MasterHeartbeatTOptions._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum alluxio.thrift.MasterHeartbeatTResponse._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum alluxio.thrift.MasterInfo._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum alluxio.thrift.MasterNetAddress._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum alluxio.thrift.MergeStoreTOptions._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum alluxio.thrift.MergeStoreTResponse._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum alluxio.thrift.MetaMasterClientService.backup_args._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum alluxio.thrift.MetaMasterClientService.backup_result._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum alluxio.thrift.MetaMasterClientService.getConfigReport_args._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum alluxio.thrift.MetaMasterClientService.getConfigReport_result._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum alluxio.thrift.MetaMasterClientService.getConfiguration_args._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum alluxio.thrift.MetaMasterClientService.getConfiguration_result._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum alluxio.thrift.MetaMasterClientService.getMasterInfo_args._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum alluxio.thrift.MetaMasterClientService.getMasterInfo_result._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum alluxio.thrift.MetaMasterClientService.getMetrics_args._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum alluxio.thrift.MetaMasterClientService.getMetrics_result._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum alluxio.thrift.MetaMasterMasterService.getMasterId_args._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum alluxio.thrift.MetaMasterMasterService.getMasterId_result._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum alluxio.thrift.MetaMasterMasterService.masterHeartbeat_args._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum alluxio.thrift.MetaMasterMasterService.masterHeartbeat_result._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum alluxio.thrift.MetaMasterMasterService.registerMaster_args._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum alluxio.thrift.MetaMasterMasterService.registerMaster_result._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum alluxio.thrift.Metric._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum alluxio.thrift.MetricsHeartbeatTOptions._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum alluxio.thrift.MetricsHeartbeatTResponse._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum alluxio.thrift.MetricsMasterClientService.metricsHeartbeat_args._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum alluxio.thrift.MetricsMasterClientService.metricsHeartbeat_result._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum alluxio.thrift.MetricValue._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum alluxio.thrift.MountPointInfo._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum alluxio.thrift.MountTOptions._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum alluxio.thrift.MountTResponse._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum alluxio.thrift.OpenUfsFileTOptions._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum alluxio.thrift.OpenUfsFileTResponse._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum alluxio.thrift.OptionalString._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum alluxio.thrift.PartitionInfo._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum alluxio.thrift.PersistCommandOptions._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum alluxio.thrift.PersistFile._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum alluxio.thrift.PromoteBlockTOptions._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum alluxio.thrift.PromoteBlockTResponse._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum alluxio.thrift.RegisterMasterTOptions._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum alluxio.thrift.RegisterMasterTResponse._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum alluxio.thrift.RegisterWorkerTOptions._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum alluxio.thrift.RegisterWorkerTResponse._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum alluxio.thrift.ReinitializeFileTOptions._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum alluxio.thrift.ReinitializeFileTResponse._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum alluxio.thrift.RemoveBlockTOptions._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum alluxio.thrift.RemoveBlockTResponse._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum alluxio.thrift.RenameStoreTOptions._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum alluxio.thrift.RenameStoreTResponse._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum alluxio.thrift.RenameTOptions._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum alluxio.thrift.RenameTResponse._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum alluxio.thrift.ReportLostFileTOptions._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum alluxio.thrift.ReportLostFileTResponse._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum alluxio.thrift.RequestBlockLocationTOptions._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum alluxio.thrift.RequestBlockLocationTResponse._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum alluxio.thrift.RequestSpaceTOptions._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum alluxio.thrift.RequestSpaceTResponse._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum alluxio.thrift.ScheduleAsyncPersistenceTOptions._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum alluxio.thrift.ScheduleAsyncPersistenceTResponse._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum alluxio.thrift.SessionBlockHeartbeatTOptions._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum alluxio.thrift.SessionBlockHeartbeatTResponse._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum alluxio.thrift.SessionFileSystemHeartbeatTOptions._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum alluxio.thrift.SessionFileSystemHeartbeatTResponse._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum alluxio.thrift.SetAttributeTOptions._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum alluxio.thrift.SetAttributeTResponse._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum alluxio.thrift.SyncMetadataTOptions._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum alluxio.thrift.SyncMetadataTResponse._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum alluxio.thrift.TieredIdentity._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum alluxio.thrift.UfsInfo._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum alluxio.thrift.UnlockBlockTOptions._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum alluxio.thrift.UnlockBlockTResponse._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum alluxio.thrift.UnmountTOptions._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum alluxio.thrift.UnmountTResponse._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum alluxio.thrift.UpdateUfsModeTOptions._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum alluxio.thrift.UpdateUfsModeTResponse._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum alluxio.thrift.WorkerInfo._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum alluxio.thrift.WorkerNetAddress._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByValue(int) - Static method in enum alluxio.thrift.BlockMasterInfoField
Find a the enum type by its integer value, as defined in the Thrift IDL.
findByValue(int) - Static method in enum alluxio.thrift.CommandType
Find a the enum type by its integer value, as defined in the Thrift IDL.
findByValue(int) - Static method in enum alluxio.thrift.ConfigStatus
Find a the enum type by its integer value, as defined in the Thrift IDL.
findByValue(int) - Static method in enum alluxio.thrift.LoadMetadataTType
Find a the enum type by its integer value, as defined in the Thrift IDL.
findByValue(int) - Static method in enum alluxio.thrift.LockBlockStatus
Find a the enum type by its integer value, as defined in the Thrift IDL.
findByValue(int) - Static method in enum alluxio.thrift.MasterInfoField
Find a the enum type by its integer value, as defined in the Thrift IDL.
findByValue(int) - Static method in enum alluxio.thrift.MetaCommand
Find a the enum type by its integer value, as defined in the Thrift IDL.
findByValue(int) - Static method in enum alluxio.thrift.Scope
Find a the enum type by its integer value, as defined in the Thrift IDL.
findByValue(int) - Static method in enum alluxio.thrift.TStatus
Find a the enum type by its integer value, as defined in the Thrift IDL.
findByValue(int) - Static method in enum alluxio.thrift.TTtlAction
Find a the enum type by its integer value, as defined in the Thrift IDL.
findByValue(int) - Static method in enum alluxio.thrift.UfsMode
Find a the enum type by its integer value, as defined in the Thrift IDL.
findByValue(int) - Static method in enum alluxio.thrift.WorkerInfoField
Find a the enum type by its integer value, as defined in the Thrift IDL.
findByValue(int) - Static method in enum alluxio.thrift.WorkerRange
Find a the enum type by its integer value, as defined in the Thrift IDL.
findClass(String) - Method in class alluxio.extensions.ExtensionsClassLoader
 
Fingerprint - Class in alluxio.underfs
Fingerprint for a UFS file or directory.
Fingerprint.Tag - Enum in alluxio.underfs
The possible tags within the fingerprint.
Fingerprint.Type - Enum in alluxio.underfs
The possible types of the fingerprint.
fingerprintHash(byte[]) - Method in class alluxio.client.keyvalue.LinearProbingIndex
Hashes a key in byte array into a non-zero, one byte fingerprint.
fingerprintHash(ByteBuffer) - Method in class alluxio.client.keyvalue.LinearProbingIndex
Hashes a key in ByteBuffer into a non-zero, one byte fingerprint.
fireAndForget(NettyRPCContext, ProtoMessage) - Static method in class alluxio.network.netty.NettyRPC
Sends a request and waits until the request is flushed to network.
FIRST_COMPLETED_LOG_NUMBER - Static variable in class alluxio.master.journalv0.ufs.UfsJournal
The log number for the first completed log.
FIRST_TIER - Static variable in class alluxio.Constants
 
fixedThreadPoolExecutorServiceFactory(String, int) - Static method in class alluxio.util.executor.ExecutorServiceFactories
Returns a ExecutorServiceFactory which creates threadpool executors with the given base name and number of threads.
flush() - Method in class alluxio.client.block.stream.BlockOutStream
 
flush() - Method in class alluxio.client.block.stream.LocalFilePacketWriter
 
flush() - Method in class alluxio.client.block.stream.NettyPacketWriter
 
flush() - Method in interface alluxio.client.block.stream.PacketWriter
Flushes all the pending packets.
flush() - Method in class alluxio.client.file.FileOutStream
 
flush() - Method in class alluxio.client.lineage.DummyFileOutputStream
 
flush(long) - Method in class alluxio.master.journal.AsyncJournalWriter
Flushes and waits until the specified counter is flushed to the journal.
flush() - Method in interface alluxio.master.journal.JournalWriter
Flushes all the entries written to the underlying storage.
flush() - Method in class alluxio.master.journal.ufs.UfsJournal
Flushes the journal.
flush(long) - Method in class alluxio.master.journalv0.AsyncJournalWriter
Flushes and waits until the specified counter is flushed to the journal.
flush() - Method in interface alluxio.master.journalv0.JournalOutputStream
Flushes the stream.
flush() - Method in interface alluxio.master.journalv0.JournalWriter
Flushes the current log stream.
flush() - Method in class alluxio.master.journalv0.ufs.UfsJournalWriter.EntryOutputStream
 
flush() - Method in class alluxio.master.journalv0.ufs.UfsJournalWriter
 
flush() - Method in class alluxio.network.thrift.BootstrapClientTransport
 
flush() - Method in class alluxio.network.thrift.BootstrapServerTransport
 
flush() - Method in class alluxio.network.thrift.PeekableTransport
 
flush() - Method in class alluxio.underfs.cos.COSOutputStream
Flushes this output stream and forces any buffered output bytes to be written out.
flush() - Method in class alluxio.underfs.gcs.GCSOutputStream
 
flush() - Method in class alluxio.underfs.hdfs.HdfsUnderFileOutputStream
 
flush() - Method in class alluxio.underfs.oss.OSSOutputStream
Flushes this output stream and forces any buffered output bytes to be written out.
flush() - Method in class alluxio.underfs.s3a.S3AOutputStream
 
flush() - Method in class alluxio.underfs.swift.SwiftMockOutputStream
 
flush() - Method in class alluxio.underfs.swift.SwiftOutputStream
 
forDouble(double) - Static method in class alluxio.wire.MetricValue
 
forEach(BiConsumer<? super PropertyKey, ? super String>) - Method in class alluxio.conf.AlluxioProperties
Iterates over all the key value pairs and performs the given action.
forLong(long) - Static method in class alluxio.wire.MetricValue
 
Format - Class in alluxio.cli
Formats the Alluxio file system.
format(Format.Mode) - Static method in class alluxio.cli.Format
Formats the Alluxio file system.
format() - Method in interface alluxio.master.journal.JournalSystem
Formats the journal system.
format() - Method in class alluxio.master.journal.noop.NoopJournalSystem
 
format() - Method in class alluxio.master.journal.ufs.UfsJournal
Formats the journal.
format() - Method in class alluxio.master.journal.ufs.UfsJournalSystem
 
format() - Method in interface alluxio.master.journalv0.MutableJournal
Formats the journal.
format() - Method in class alluxio.master.journalv0.ufs.UfsMutableJournal
 
format(Object...) - Method in enum alluxio.PropertyKey.Template
Converts a property key template (e.g., PropertyKey.Template.WORKER_TIERED_STORE_LEVEL_RESERVED_RATIO) to a PropertyKey instance.
Format.Mode - Enum in alluxio.cli
The format mode.
formatAndRestartMasters() - Method in class alluxio.master.AbstractLocalAlluxioCluster
Stops the masters, formats them, and then restarts them.
formatJournal() - Method in class alluxio.multi.process.MultiProcessCluster
Formats the cluster journal.
formatLsString(boolean, boolean, boolean, String, String, String, long, long, int, String, String) - Static method in class alluxio.cli.fs.command.LsCommand
Formats the ls result string.
formatMode(short, boolean) - Static method in class alluxio.util.FormatUtils
Formats digital representation of a model as a human-readable string.
formatStackTrace(Thread) - Static method in class alluxio.util.ThreadUtils
 
formatTimeTakenMs(long, String) - Static method in class alluxio.util.FormatUtils
Formats time elapsed since the given start time (in milliseconds).
formatTimeTakenNs(long, String) - Static method in class alluxio.util.FormatUtils
Formats time elapsed since the given start time (in nanoseconds).
FormatUtils - Class in alluxio.util
Utility methods to parse specific formats, print according to specific formats or transform among different formats.
free(AlluxioURI) - Method in class alluxio.client.file.BaseFileSystem
 
free(AlluxioURI, FreeOptions) - Method in class alluxio.client.file.BaseFileSystem
 
free(AlluxioURI) - Method in interface alluxio.client.file.FileSystem
Convenience method for FileSystem.free(AlluxioURI, FreeOptions) with default options.
free(AlluxioURI, FreeOptions) - Method in interface alluxio.client.file.FileSystem
Evicts any data under the given path from Alluxio space, but does not delete the data from the UFS.
free(AlluxioURI, FreeOptions) - Method in interface alluxio.client.file.FileSystemMasterClient
Frees a file.
free(AlluxioURI, FreeOptions) - Method in class alluxio.client.file.RetryHandlingFileSystemMasterClient
 
free(AlluxioURI, FreeOptions) - Method in class alluxio.master.file.DefaultFileSystemMaster
 
free(AlluxioURI, FreeOptions) - Method in interface alluxio.master.file.FileSystemMaster
Frees or evicts all of the blocks of the file from alluxio storage.
FREE - Static variable in class alluxio.master.file.FileSystemMasterClientRestServiceHandler
Deprecated.
 
free(String, boolean) - Method in class alluxio.master.file.FileSystemMasterClientRestServiceHandler
Deprecated.
 
free(String, boolean, FreeTOptions) - Method in class alluxio.master.file.FileSystemMasterClientServiceHandler
 
FREE - Static variable in class alluxio.proxy.PathsRestServiceHandler
 
free(String, FreeOptions) - Method in class alluxio.proxy.PathsRestServiceHandler
 
free(String, boolean, FreeTOptions, AsyncMethodCallback) - Method in class alluxio.thrift.FileSystemMasterClientService.AsyncClient
 
free(String, boolean, FreeTOptions, AsyncMethodCallback) - Method in interface alluxio.thrift.FileSystemMasterClientService.AsyncIface
 
free() - Constructor for class alluxio.thrift.FileSystemMasterClientService.AsyncProcessor.free
 
free(String, boolean, FreeTOptions) - Method in class alluxio.thrift.FileSystemMasterClientService.Client
 
free(String, boolean, FreeTOptions) - Method in interface alluxio.thrift.FileSystemMasterClientService.Iface
Frees the given file or directory from Alluxio.
free() - Constructor for class alluxio.thrift.FileSystemMasterClientService.Processor.free
 
free_args() - Constructor for class alluxio.thrift.FileSystemMasterClientService.free_args
 
free_args(String, boolean, FreeTOptions) - Constructor for class alluxio.thrift.FileSystemMasterClientService.free_args
 
free_args(FileSystemMasterClientService.free_args) - Constructor for class alluxio.thrift.FileSystemMasterClientService.free_args
Performs a deep copy on other.
free_call(String, boolean, FreeTOptions, AsyncMethodCallback, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class alluxio.thrift.FileSystemMasterClientService.AsyncClient.free_call
 
FREE_FILE_OPS - Static variable in class alluxio.metrics.MasterMetrics
 
free_result() - Constructor for class alluxio.thrift.FileSystemMasterClientService.free_result
 
free_result(FreeTResponse, AlluxioTException) - Constructor for class alluxio.thrift.FileSystemMasterClientService.free_result
 
free_result(FileSystemMasterClientService.free_result) - Constructor for class alluxio.thrift.FileSystemMasterClientService.free_result
Performs a deep copy on other.
FREE_VALUE - Static variable in enum alluxio.proto.journal.File.PTtlAction
FREE = 1;
FreeCommand - Class in alluxio.cli.fs.command
Frees the given file or folder from Alluxio storage (recursively freeing all children if a folder).
FreeCommand(FileSystem) - Constructor for class alluxio.cli.fs.command.FreeCommand
Constructs a new instance to free the given file or folder from Alluxio.
FreeOptions - Class in alluxio.client.file.options
Method options for freeing space.
FreeOptions - Class in alluxio.master.file.options
Method options for list status.
FreeOptions(FreeTOptions) - Constructor for class alluxio.master.file.options.FreeOptions
Creates an instance of FreeOptions from a FreeTOptions.
freeSpace(long, long, BlockStoreLocation) - Method in interface alluxio.worker.block.BlockStore
Frees space to make a specific amount of bytes available in a best-effort way in the location.
freeSpace(long, long, String) - Method in interface alluxio.worker.block.BlockWorker
Frees space to make a specific amount of bytes available in a best-effort way in the tier.
freeSpace(long, long, String) - Method in class alluxio.worker.block.DefaultBlockWorker
 
freeSpace(long, long, BlockStoreLocation) - Method in class alluxio.worker.block.TieredBlockStore
 
freeSpaceWithView(long, BlockStoreLocation, BlockMetadataManagerView) - Method in class alluxio.worker.block.evictor.AbstractEvictor
 
freeSpaceWithView(long, BlockStoreLocation, BlockMetadataManagerView, Evictor.Mode) - Method in class alluxio.worker.block.evictor.AbstractEvictor
 
freeSpaceWithView(long, BlockStoreLocation, BlockMetadataManagerView) - Method in interface alluxio.worker.block.evictor.Evictor
Frees space with the guaranteed mode.
freeSpaceWithView(long, BlockStoreLocation, BlockMetadataManagerView, Evictor.Mode) - Method in interface alluxio.worker.block.evictor.Evictor
Frees space in the given block store location and with the given view.
freeSpaceWithView(long, BlockStoreLocation, BlockMetadataManagerView) - Method in class alluxio.worker.block.evictor.GreedyEvictor
 
freeSpaceWithView(long, BlockStoreLocation, BlockMetadataManagerView, Evictor.Mode) - Method in class alluxio.worker.block.evictor.GreedyEvictor
 
freeSpaceWithView(long, BlockStoreLocation, BlockMetadataManagerView, Evictor.Mode) - Method in class alluxio.worker.block.evictor.LRFUEvictor
 
FreeTOptions - Class in alluxio.thrift
 
FreeTOptions() - Constructor for class alluxio.thrift.FreeTOptions
 
FreeTOptions(FreeTOptions) - Constructor for class alluxio.thrift.FreeTOptions
Performs a deep copy on other.
FreeTOptions._Fields - Enum in alluxio.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
FreeTResponse - Class in alluxio.thrift
 
FreeTResponse() - Constructor for class alluxio.thrift.FreeTResponse
 
FreeTResponse(FreeTResponse) - Constructor for class alluxio.thrift.FreeTResponse
Performs a deep copy on other.
FreeTResponse._Fields - Enum in alluxio.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
from(Status, String) - Static method in exception alluxio.exception.status.AlluxioStatusException
Converts an Alluxio exception from status and message representation to native representation.
from(String, double) - Static method in class alluxio.metrics.Metric
Creates the metric from the full name and the value.
from(Metric) - Static method in class alluxio.metrics.Metric
Constructs the metric object from the thrift format.
FROM_STORE_ID_FIELD_NUMBER - Static variable in class alluxio.proto.journal.KeyValue.MergeStoreEntry
 
fromAlluxioException(AlluxioException) - Static method in exception alluxio.exception.status.AlluxioStatusException
Converts checked Alluxio exceptions to Alluxio status exceptions.
fromCheckedException(Throwable) - Static method in exception alluxio.exception.status.AlluxioStatusException
Converts checked throwables to Alluxio status exceptions.
fromIOException(IOException) - Static method in exception alluxio.exception.status.AlluxioStatusException
Converts an IOException to a corresponding status exception.
fromJournalEntry(File.InodeDirectoryEntry) - Static method in class alluxio.master.file.meta.InodeDirectory
Converts the entry to an InodeDirectory.
fromJournalEntry(File.InodeFileEntry) - Static method in class alluxio.master.file.meta.InodeFile
Converts the entry to an InodeFile.
fromJournalEntry(Lineage.LineageEntry) - Static method in class alluxio.master.lineage.meta.Lineage
Converts the entry to a Lineage.
fromProto(Status.PStatus) - Static method in enum alluxio.exception.status.Status
Creates a Status from a protocol buffer type status.
fromProtobuf(File.PTtlAction) - Static method in class alluxio.master.ProtobufUtils
Converts Protobuf type to Wire type.
fromShort(short) - Static method in enum alluxio.security.authorization.Mode.Bits
Creates a Mode.Bits from a short.
fromShort(short) - Method in class alluxio.security.authorization.Mode
Sets Mode bits using a digital representation.
fromString(String) - Static method in enum alluxio.metrics.MetricsSystem.InstanceType
Creates an instance type from the string.
fromString(String) - Static method in class alluxio.network.TieredIdentityFactory
 
fromString(String) - Static method in class alluxio.PropertyKey
Parses a string and return its corresponding PropertyKey, throwing exception if no such a property can be found.
fromThrift(WorkerInfoField) - Static method in enum alluxio.client.block.options.GetWorkerReportOptions.WorkerInfoField
 
fromThrift(WorkerRange) - Static method in enum alluxio.client.block.options.GetWorkerReportOptions.WorkerRange
 
fromThrift(AlluxioTException) - Static method in exception alluxio.exception.status.AlluxioStatusException
Converts an Alluxio exception from Thrift representation to native representation.
fromThrift(TStatus) - Static method in enum alluxio.exception.status.Status
Creates a Status from a Thrift type status.
fromThrift(MasterNetAddress) - Static method in class alluxio.wire.Address
Creates a new instance of Address from thrift representation.
fromThrift(BackupTOptions) - Static method in class alluxio.wire.BackupOptions
 
fromThrift(BackupTResponse) - Static method in class alluxio.wire.BackupResponse
 
fromThrift(BlockInfo) - Static method in class alluxio.wire.BlockInfo
Creates a new instance of BlockInfo from a thrift representation.
fromThrift(BlockLocation) - Static method in class alluxio.wire.BlockLocation
Creates a new instance of BlockLocation from a thrift representation.
fromThrift(BlockMasterInfoField) - Static method in enum alluxio.wire.BlockMasterInfo.BlockMasterInfoField
 
fromThrift(BlockMasterInfo) - Static method in class alluxio.wire.BlockMasterInfo
Creates a new instance of BlockMasterInfo from a thrift representation.
fromThrift(CommandLineJobInfo) - Static method in class alluxio.wire.CommandLineJobInfo
Creates a new instance of CommandLineJobInfo from a thrift representation.
fromThrift(ConfigStatus) - Static method in enum alluxio.wire.ConfigCheckReport.ConfigStatus
 
fromThrift(ConfigCheckReport) - Static method in class alluxio.wire.ConfigCheckReport
Creates a new instance of ConfigCheckReport from thrift representation.
fromThrift(ConfigProperty) - Static method in class alluxio.wire.ConfigProperty
Converts a thrift type to a wire type.
fromThrift(FileBlockInfo) - Static method in class alluxio.wire.FileBlockInfo
Creates a new instance of FileBlockInfo from a thrift representation.
fromThrift(FileInfo) - Static method in class alluxio.wire.FileInfo
Creates a new instance of FileInfo from thrift representation.
fromThrift(GetConfigurationTOptions) - Static method in class alluxio.wire.GetConfigurationOptions
 
fromThrift(InconsistentProperty) - Static method in class alluxio.wire.InconsistentProperty
Creates a new instance of InconsistentProperty from thrift representation.
fromThrift(JobConfInfo) - Static method in class alluxio.wire.JobConfInfo
Creates a new instance of JobConfInfo from a thrift representation.
fromThrift(LineageInfo) - Static method in class alluxio.wire.LineageInfo
Creates a new instance of LineageInfo from a thrift representation.
fromThrift(LoadMetadataTType) - Static method in enum alluxio.wire.LoadMetadataType
 
fromThrift(MasterInfo) - Static method in class alluxio.wire.MasterInfo
Creates a new instance of MasterInfo from a thrift representation.
fromThrift(MasterInfoField) - Static method in enum alluxio.wire.MasterInfo.MasterInfoField
 
fromThrift(MetricValue) - Static method in class alluxio.wire.MetricValue
Converts a thrift type to a wire type.
fromThrift(MountPointInfo) - Static method in class alluxio.wire.MountPointInfo
Creates a new instance of MountPointInfo from thrift representation.
fromThrift(OptionalString) - Static method in class alluxio.wire.OptionalString
 
fromThrift(Scope) - Static method in enum alluxio.wire.Scope
 
fromThrift(TieredIdentity) - Static method in class alluxio.wire.TieredIdentity
 
fromThrift(LocalityTier) - Static method in class alluxio.wire.TieredIdentity.LocalityTier
 
fromThrift(TTtlAction) - Static method in enum alluxio.wire.TtlAction
Converts thrift type to wire type.
fromThrift(WorkerInfo) - Static method in class alluxio.wire.WorkerInfo
Creates a new instance of WorkerInfo from a thrift representation.
fromThrift(WorkerNetAddress) - Static method in class alluxio.wire.WorkerNetAddress
Creates a new instance of WorkerNetAddress from thrift representation.
fromThrowable(Throwable) - Static method in exception alluxio.exception.status.AlluxioStatusException
Converts an arbitrary throwable to an Alluxio status exception.
fromURIStatus(URIStatus) - Static method in class alluxio.proxy.s3.ListPartsResult.Part
 
fullPathExists() - Method in class alluxio.master.file.meta.LockedInodePath
 
FUSE_CACHED_PATHS_MAX - Static variable in class alluxio.PropertyKey
 
FUSE_CACHED_PATHS_MAX - Static variable in class alluxio.PropertyKey.Name
 
FUSE_DEBUG_ENABLED - Static variable in class alluxio.PropertyKey
 
FUSE_DEBUG_ENABLED - Static variable in class alluxio.PropertyKey.Name
 
FUSE_FS_NAME - Static variable in class alluxio.PropertyKey
 
FUSE_FS_NAME - Static variable in class alluxio.PropertyKey.Name
 
FUSE_MAXWRITE_BYTES - Static variable in class alluxio.PropertyKey
 
FUSE_MAXWRITE_BYTES - Static variable in class alluxio.PropertyKey.Name
 
FUSE_USER_GROUP_TRANSLATION_ENABLED - Static variable in class alluxio.PropertyKey
 
FUSE_USER_GROUP_TRANSLATION_ENABLED - Static variable in class alluxio.PropertyKey.Name
 

G

gainPrimacy() - Method in interface alluxio.master.journal.JournalSystem
Transitions the journal to primary mode.
gainPrimacy() - Method in class alluxio.master.journal.noop.NoopJournalSystem
 
gainPrimacy() - Method in class alluxio.master.journal.ufs.UfsJournal
Transitions the journal from secondary to primary mode.
gainPrimacy() - Method in class alluxio.master.journal.ufs.UfsJournalSystem
 
GB - Static variable in class alluxio.Constants
 
GCS_ACCESS_KEY - Static variable in class alluxio.PropertyKey
 
GCS_ACCESS_KEY - Static variable in class alluxio.PropertyKey.Name
 
GCS_SECRET_KEY - Static variable in class alluxio.PropertyKey
 
GCS_SECRET_KEY - Static variable in class alluxio.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) - Constructor for class alluxio.underfs.gcs.GCSOutputStream
Constructs a new stream for writing a file.
GCSUnderFileSystem - Class in alluxio.underfs.gcs
GCS FS UnderFileSystem implementation based on the jets3t library.
GCSUnderFileSystem(AlluxioURI, GoogleStorageService, String, short, String, UnderFileSystemConfiguration) - Constructor for class alluxio.underfs.gcs.GCSUnderFileSystem
Constructor for GCSUnderFileSystem.
GCSUnderFileSystemFactory - Class in alluxio.underfs.gcs
Factory for creating GCSUnderFileSystem.
GCSUnderFileSystemFactory() - Constructor for class alluxio.underfs.gcs.GCSUnderFileSystemFactory
Constructs a new GCSUnderFileSystemFactory.
GCSUtils - Class in alluxio.underfs.gcs
Util functions for GCS under file system.
GeneralWorker(int, int, int, ByteBuffer, boolean, boolean, String) - Constructor for class alluxio.examples.Performance.GeneralWorker
 
generateCapacityReport(GetWorkerReportOptions) - Method in class alluxio.cli.fsadmin.report.CapacityCommand
Generates capacity report.
generateClientFileInfo(String) - Method in class alluxio.master.file.meta.Inode
Generates a FileInfo of the file or folder.
generateClientFileInfo(String) - Method in class alluxio.master.file.meta.InodeDirectory
Generates client file info for a folder.
generateClientFileInfo(String) - Method in class alluxio.master.file.meta.InodeFile
 
generateCommandLineJobInfo() - Method in class alluxio.job.CommandLineJob
Generates the CommandLineJobInfo for the command.
generateNewByteBufferFromThriftRPCResults(ByteBuffer) - Static method in class alluxio.util.io.BufferUtils
Extracts a correct ByteBuffer from Thrift RPC result.
generatePlan(LineageStoreView, FileSystemMasterView) - Method in class alluxio.master.lineage.checkpoint.CheckpointLatestPlanner
 
generatePlan(LineageStoreView, FileSystemMasterView) - Method in interface alluxio.master.lineage.checkpoint.CheckpointPlanner
Generates a plan to decide what lineages to checkpoint.
generateQueryString(Map<String, String>) - Static method in class alluxio.util.URIUtils
Generates a query string from a of key/value pairs.
generateReport() - Method in class alluxio.worker.block.BlockHeartbeatReporter
Generates the report of the block store delta in the last heartbeat period.
generateWorkerInfo(Set<GetWorkerReportOptions.WorkerInfoField>, boolean) - Method in class alluxio.master.block.meta.MasterWorkerInfo
Gets the selected field information for this worker.
get(PropertyKey) - Method in interface alluxio.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.AlluxioConfiguration
Gets the value for the given key in the Properties; if this key is not found, a RuntimeException is thrown.
get(FileSystemContext) - Static method in class alluxio.client.file.BaseFileSystem
 
get() - Static method in class alluxio.client.file.FileSystem.Factory
 
get(FileSystemContext) - Static method in class alluxio.client.file.FileSystem.Factory
 
get() - Static method in class alluxio.client.file.FileSystemContext
 
get(Subject) - Static method in class alluxio.client.file.FileSystemContext
 
get(byte[]) - Method in class alluxio.client.keyvalue.ByteBufferKeyValuePartitionReader
Gets the value associated with the given key in the key-value partition, returning null if the key is not found.
get(ByteBuffer) - Method in class alluxio.client.keyvalue.ByteBufferKeyValuePartitionReader
 
get(ByteBuffer, PayloadReader) - Method in interface alluxio.client.keyvalue.Index
Gets the bytes of value given the key and payload storage reader.
get(byte[]) - Method in interface alluxio.client.keyvalue.KeyValuePartitionReader
Gets the value associated with the given key in the key-value partition, returning null if the key is not found.
get(ByteBuffer) - Method in interface alluxio.client.keyvalue.KeyValuePartitionReader
Gets the value associated with the given key in the key-value partition, returning null if the key is not found.
get(byte[]) - Method in interface alluxio.client.keyvalue.KeyValueStoreReader
Gets the value associated with key, returns null if not found.
get(ByteBuffer) - Method in interface alluxio.client.keyvalue.KeyValueStoreReader
Gets the value associated with key, returns null if not found.
get(long, ByteBuffer) - Method in class alluxio.client.keyvalue.KeyValueWorkerClient
Gets the value of a given key from a specific key-value block.
get(ByteBuffer, PayloadReader) - Method in class alluxio.client.keyvalue.LinearProbingIndex
 
get() - Static method in class alluxio.client.lineage.AlluxioLineage
 
get(LineageContext) - Static method in class alluxio.client.lineage.AlluxioLineage
 
get(FileSystemContext, LineageContext) - Static method in class alluxio.client.lineage.LineageFileSystem
 
get(PropertyKey) - Method in class alluxio.conf.AlluxioProperties
 
get(PropertyKey) - Method in class alluxio.conf.InstancedConfiguration
 
get(PropertyKey, ConfigurationValueOptions) - Method in class alluxio.conf.InstancedConfiguration
 
get(PropertyKey) - Static method in class alluxio.Configuration
Gets the value for the given key in the Properties; if this key is not found, a RuntimeException is thrown.
get(PropertyKey, ConfigurationValueOptions) - Static method in class alluxio.Configuration
Gets the value for the given key in the Properties; if this key is not found, a RuntimeException is thrown.
get() - Method in class alluxio.DefaultSupplier
 
get(long) - Method in class alluxio.master.file.meta.LazyUfsBlockLocationCache
 
get(long, AlluxioURI, long) - Method in class alluxio.master.file.meta.LazyUfsBlockLocationCache
 
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(Class<W>) - Method in class alluxio.Registry
Convenience method for calling Registry.get(Class, int) with a default timeout.
get(Class<W>, int) - Method in class alluxio.Registry
Attempts to look up the Server for the given class.
get() - Method in class alluxio.resource.CloseableResource
 
get() - Static method in class alluxio.security.authentication.AuthenticatedClientUser
Gets the User from the ThreadLocal variable.
get() - Static method in class alluxio.security.group.GroupMappingService.Factory
Gets the cached groups mapping service being used to map user-to-groups.
get() - Static method in class alluxio.security.LoginUser
Gets current singleton login user.
get(long, ByteBuffer, GetTOptions, AsyncMethodCallback) - Method in class alluxio.thrift.KeyValueWorkerClientService.AsyncClient
 
get(long, ByteBuffer, GetTOptions, AsyncMethodCallback) - Method in interface alluxio.thrift.KeyValueWorkerClientService.AsyncIface
 
get() - Constructor for class alluxio.thrift.KeyValueWorkerClientService.AsyncProcessor.get
 
get(long, ByteBuffer, GetTOptions) - Method in class alluxio.thrift.KeyValueWorkerClientService.Client
 
get(long, ByteBuffer, GetTOptions) - Method in interface alluxio.thrift.KeyValueWorkerClientService.Iface
Looks up a key in the block with the given block id.
get() - Constructor for class alluxio.thrift.KeyValueWorkerClientService.Processor.get
 
get(long) - Method in class alluxio.underfs.AbstractUfsManager
 
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(long, ByteBuffer, GetTOptions) - Method in class alluxio.worker.keyvalue.KeyValueWorkerClientServiceHandler
 
get_args() - Constructor for class alluxio.thrift.KeyValueWorkerClientService.get_args
 
get_args(long, ByteBuffer, GetTOptions) - Constructor for class alluxio.thrift.KeyValueWorkerClientService.get_args
 
get_args(KeyValueWorkerClientService.get_args) - Constructor for class alluxio.thrift.KeyValueWorkerClientService.get_args
Performs a deep copy on other.
GET_BLOCK_INFO - Static variable in class alluxio.master.block.BlockMasterClientRestServiceHandler
Deprecated.
 
get_call(long, ByteBuffer, GetTOptions, AsyncMethodCallback, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class alluxio.thrift.KeyValueWorkerClientService.AsyncClient.get_call
 
GET_CAPACITY_BYTES - Static variable in class alluxio.master.meta.AlluxioMasterRestServiceHandler
 
GET_CAPACITY_BYTES - Static variable in class alluxio.worker.AlluxioWorkerRestServiceHandler
 
GET_CAPACITY_BYTES_ON_TIERS - Static variable in class alluxio.master.meta.AlluxioMasterRestServiceHandler
 
GET_CAPACITY_BYTES_ON_TIERS - Static variable in class alluxio.worker.AlluxioWorkerRestServiceHandler
 
GET_CONFIGURATION - Static variable in class alluxio.master.meta.AlluxioMasterRestServiceHandler
 
GET_CONFIGURATION - Static variable in class alluxio.worker.AlluxioWorkerRestServiceHandler
 
GET_DIRECTORY_PATHS_ON_TIERS - Static variable in class alluxio.worker.AlluxioWorkerRestServiceHandler
 
GET_FILE_BLOCK_INFO_OPS - Static variable in class alluxio.metrics.MasterMetrics
 
GET_FILE_INFO_OPS - Static variable in class alluxio.metrics.MasterMetrics
 
GET_FREE_BYTES - Static variable in class alluxio.master.meta.AlluxioMasterRestServiceHandler
 
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.AlluxioWorkerRestServiceHandler
 
GET_LINEAGE_INFO_LIST - Static variable in class alluxio.master.lineage.LineageMasterClientRestServiceHandler
Deprecated.
 
GET_METRICS - Static variable in class alluxio.master.meta.AlluxioMasterRestServiceHandler
 
GET_METRICS - Static variable in class alluxio.worker.AlluxioWorkerRestServiceHandler
 
GET_MOUNT_POINTS - Static variable in class alluxio.master.file.FileSystemMasterClientRestServiceHandler
Deprecated.
 
GET_NEW_BLOCK_ID_FOR_FILE - Static variable in class alluxio.master.file.FileSystemMasterClientRestServiceHandler
Deprecated.
 
GET_NEW_BLOCK_OPS - Static variable in class alluxio.metrics.MasterMetrics
 
get_result() - Constructor for class alluxio.thrift.KeyValueWorkerClientService.get_result
 
get_result(GetTResponse, AlluxioTException) - Constructor for class alluxio.thrift.KeyValueWorkerClientService.get_result
 
get_result(KeyValueWorkerClientService.get_result) - Constructor for class alluxio.thrift.KeyValueWorkerClientService.get_result
Performs a deep copy on other.
GET_RPC_ADDRESS - Static variable in class alluxio.master.meta.AlluxioMasterRestServiceHandler
 
GET_RPC_ADDRESS - Static variable in class alluxio.worker.AlluxioWorkerRestServiceHandler
 
GET_START_TIME_MS - Static variable in class alluxio.master.meta.AlluxioMasterRestServiceHandler
 
GET_START_TIME_MS - Static variable in class alluxio.worker.AlluxioWorkerRestServiceHandler
 
GET_STATUS - Static variable in class alluxio.master.file.FileSystemMasterClientRestServiceHandler
Deprecated.
 
GET_STATUS - Static variable in class alluxio.proxy.PathsRestServiceHandler
 
GET_UFS_CAPACITY_BYTES - Static variable in class alluxio.master.meta.AlluxioMasterRestServiceHandler
 
GET_UFS_FREE_BYTES - Static variable in class alluxio.master.meta.AlluxioMasterRestServiceHandler
 
GET_UFS_USED_BYTES - Static variable in class alluxio.master.meta.AlluxioMasterRestServiceHandler
 
GET_UPTIME_MS - Static variable in class alluxio.master.meta.AlluxioMasterRestServiceHandler
 
GET_UPTIME_MS - Static variable in class alluxio.worker.AlluxioWorkerRestServiceHandler
 
GET_USED_BYTES - Static variable in class alluxio.master.meta.AlluxioMasterRestServiceHandler
 
GET_USED_BYTES - Static variable in class alluxio.worker.AlluxioWorkerRestServiceHandler
 
GET_USED_BYTES_ON_TIERS - Static variable in class alluxio.master.meta.AlluxioMasterRestServiceHandler
 
GET_USED_BYTES_ON_TIERS - Static variable in class alluxio.worker.AlluxioWorkerRestServiceHandler
 
GET_VERSION - Static variable in class alluxio.master.meta.AlluxioMasterRestServiceHandler
 
GET_VERSION - Static variable in class alluxio.worker.AlluxioWorkerRestServiceHandler
 
GET_WORKER_COUNT - Static variable in class alluxio.master.meta.AlluxioMasterRestServiceHandler
 
GET_WORKER_INFO_LIST - Static variable in class alluxio.master.meta.AlluxioMasterRestServiceHandler
 
getAbsolutePath() - Method in class alluxio.web.UIFileInfo
 
getAddedBlocks() - Method in class alluxio.worker.block.BlockHeartbeatReport
Gets the list of blocks added by the worker in the heartbeat this report represents.
getAddedBlocksOnTiers() - Method in class alluxio.thrift.BlockMasterWorkerService.blockHeartbeat_args
the map of added blocks on all tiers
getAddedBlocksOnTiersSize() - Method in class alluxio.thrift.BlockMasterWorkerService.blockHeartbeat_args
 
getAddMountPoint() - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
optional .alluxio.proto.journal.AddMountPointEntry add_mount_point = 2;
getAddMountPoint() - Method in class alluxio.proto.journal.Journal.JournalEntry
optional .alluxio.proto.journal.AddMountPointEntry add_mount_point = 2;
getAddMountPoint() - Method in interface alluxio.proto.journal.Journal.JournalEntryOrBuilder
optional .alluxio.proto.journal.AddMountPointEntry add_mount_point = 2;
getAddMountPointBuilder() - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
optional .alluxio.proto.journal.AddMountPointEntry add_mount_point = 2;
getAddMountPointOrBuilder() - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
optional .alluxio.proto.journal.AddMountPointEntry add_mount_point = 2;
getAddMountPointOrBuilder() - Method in class alluxio.proto.journal.Journal.JournalEntry
optional .alluxio.proto.journal.AddMountPointEntry add_mount_point = 2;
getAddMountPointOrBuilder() - Method in interface alluxio.proto.journal.Journal.JournalEntryOrBuilder
optional .alluxio.proto.journal.AddMountPointEntry add_mount_point = 2;
getAddress() - Method in class alluxio.AbstractClient
 
getAddress() - Method in class alluxio.AbstractMasterClient
 
getAddress() - Method in class alluxio.client.block.stream.BlockInStream
 
getAddress() - Method in class alluxio.client.block.stream.BlockOutStream
 
getAddress() - Method in interface alluxio.Client
 
getAddress() - Method in class alluxio.master.LocalAlluxioMaster
 
getAddress() - Method in class alluxio.master.meta.MasterInfo
 
getAddress() - Method in class alluxio.master.SingleMasterInquireClient.SingleMasterConnectDetails
 
getAddress() - Method in class alluxio.thrift.WorkerInfo
 
getAddress() - Method in class alluxio.wire.WorkerInfo
 
getAddress() - Method in class alluxio.worker.AlluxioWorkerProcess
 
getAddress() - Method in interface alluxio.worker.WorkerProcess
 
getAddresses() - Method in class alluxio.client.block.options.GetWorkerReportOptions
 
getAddresses() - Method in class alluxio.master.PollingMasterInquireClient.MultiMasterConnectDetails
 
getAddresses() - Method in class alluxio.thrift.GetWorkerReportTOptions
addresses are only valid when workerRange is SPECIFIED
getAddressesIterator() - Method in class alluxio.thrift.GetWorkerReportTOptions
 
getAddressesSize() - Method in class alluxio.thrift.GetWorkerReportTOptions
 
getAlias(int) - Method in class alluxio.StorageTierAssoc
 
getAliases() - Method in class alluxio.PropertyKey
 
getAllInTopologicalOrder() - Method in class alluxio.collections.DirectedAcyclicGraph
Gets all payloads of the DAG in the topological order.
getAllInTopologicalOrder() - Method in class alluxio.master.lineage.meta.LineageStore
 
getAllLineagesInTopologicalOrder() - Method in class alluxio.master.lineage.meta.LineageStoreView
 
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.proto.journal.File.DeleteFileEntry.Builder
optional bool alluxioOnly = 4;
getAlluxioOnly() - Method in class alluxio.proto.journal.File.DeleteFileEntry
optional bool alluxioOnly = 4;
getAlluxioOnly() - Method in interface alluxio.proto.journal.File.DeleteFileEntryOrBuilder
optional bool alluxioOnly = 4;
getAlluxioPath() - Method in class alluxio.proto.journal.File.AddMountPointEntry.Builder
optional string alluxio_path = 1;
getAlluxioPath() - Method in class alluxio.proto.journal.File.AddMountPointEntry
optional string alluxio_path = 1;
getAlluxioPath() - Method in interface alluxio.proto.journal.File.AddMountPointEntryOrBuilder
optional string alluxio_path = 1;
getAlluxioPath() - Method in class alluxio.proto.journal.File.DeleteMountPointEntry.Builder
optional string alluxio_path = 1;
getAlluxioPath() - Method in class alluxio.proto.journal.File.DeleteMountPointEntry
optional string alluxio_path = 1;
getAlluxioPath() - Method in interface alluxio.proto.journal.File.DeleteMountPointEntryOrBuilder
optional string alluxio_path = 1;
getAlluxioPath() - Method in class alluxio.thrift.FileSystemMasterClientService.mount_args
the path of alluxio mount point
getAlluxioPath() - Method in class alluxio.thrift.FileSystemMasterClientService.unmount_args
the path of the alluxio mount point
getAlluxioPathBytes() - Method in class alluxio.proto.journal.File.AddMountPointEntry.Builder
optional string alluxio_path = 1;
getAlluxioPathBytes() - Method in class alluxio.proto.journal.File.AddMountPointEntry
optional string alluxio_path = 1;
getAlluxioPathBytes() - Method in interface alluxio.proto.journal.File.AddMountPointEntryOrBuilder
optional string alluxio_path = 1;
getAlluxioPathBytes() - Method in class alluxio.proto.journal.File.DeleteMountPointEntry.Builder
optional string alluxio_path = 1;
getAlluxioPathBytes() - Method in class alluxio.proto.journal.File.DeleteMountPointEntry
optional string alluxio_path = 1;
getAlluxioPathBytes() - Method in interface alluxio.proto.journal.File.DeleteMountPointEntryOrBuilder
optional string alluxio_path = 1;
getAlluxioStorageType() - Method in class alluxio.client.file.options.OutStreamOptions
 
getAlluxioStorageType() - Method in enum alluxio.client.ReadType
 
getAlluxioStorageType() - Method in enum alluxio.client.WriteType
 
getAlluxioUri() - Method in class alluxio.master.file.meta.options.MountInfo
 
getAlluxioURIs(FileSystem, AlluxioURI) - Static method in class alluxio.cli.fs.FileSystemShellUtils
Gets all the AlluxioURIs that match inputURI.
getAllWorkers() - Method in class alluxio.client.block.AlluxioBlockStore
 
getAncestorInode() - Method in class alluxio.master.file.meta.LockedInodePath
Returns the closest ancestor of the target inode (last inode in the full path).
getAppConfigurationEntry(String) - Method in class alluxio.security.login.LoginModuleConfiguration
 
getAppId() - Static method in class alluxio.metrics.MetricsSystem
 
getAsyncClient(TNonblockingTransport) - Method in class alluxio.thrift.AlluxioService.AsyncClient.Factory
 
getAsyncClient(TNonblockingTransport) - Method in class alluxio.thrift.BlockMasterClientService.AsyncClient.Factory
 
getAsyncClient(TNonblockingTransport) - Method in class alluxio.thrift.BlockMasterWorkerService.AsyncClient.Factory
 
getAsyncClient(TNonblockingTransport) - Method in class alluxio.thrift.BlockWorkerClientService.AsyncClient.Factory
 
getAsyncClient(TNonblockingTransport) - Method in class alluxio.thrift.FileSystemMasterClientService.AsyncClient.Factory
 
getAsyncClient(TNonblockingTransport) - Method in class alluxio.thrift.FileSystemMasterWorkerService.AsyncClient.Factory
 
getAsyncClient(TNonblockingTransport) - Method in class alluxio.thrift.FileSystemWorkerClientService.AsyncClient.Factory
 
getAsyncClient(TNonblockingTransport) - Method in class alluxio.thrift.KeyValueMasterClientService.AsyncClient.Factory
 
getAsyncClient(TNonblockingTransport) - Method in class alluxio.thrift.KeyValueWorkerClientService.AsyncClient.Factory
 
getAsyncClient(TNonblockingTransport) - Method in class alluxio.thrift.LineageMasterClientService.AsyncClient.Factory
 
getAsyncClient(TNonblockingTransport) - Method in class alluxio.thrift.MetaMasterClientService.AsyncClient.Factory
 
getAsyncClient(TNonblockingTransport) - Method in class alluxio.thrift.MetaMasterMasterService.AsyncClient.Factory
 
getAsyncClient(TNonblockingTransport) - Method in class alluxio.thrift.MetricsMasterClientService.AsyncClient.Factory
 
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;
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
 
getAuthName() - Method in enum alluxio.security.authentication.AuthType
 
getAuthority() - Method in class alluxio.AlluxioURI
Gets the authority of the AlluxioURI.
getAuthority() - Method in class alluxio.StandardURI
 
getAuthority() - Method in interface alluxio.URI
 
getAuthorizationID() - Method in class alluxio.security.authentication.PlainSaslServer
 
getAvailable() - Method in class alluxio.extensions.ExtensionFactoryRegistry
Returns a read-only view of the available base factories.
getAvailableBytes() - Method in class alluxio.master.block.meta.MasterWorkerInfo
 
getAvailableBytes(BlockStoreLocation) - Method in class alluxio.worker.block.BlockMetadataManager
Gets the amount of available space of given location in bytes.
getAvailableBytes(BlockStoreLocation) - Method in class alluxio.worker.block.BlockMetadataManagerView
Gets available bytes given certain location BlockMetadataManager.getAvailableBytes(BlockStoreLocation).
getAvailableBytes() - Method in class alluxio.worker.block.meta.StorageDir
Gets the total available capacity of this StorageDir in bytes.
getAvailableBytes() - Method in class alluxio.worker.block.meta.StorageDirView
Gets available bytes for this dir.
getAvailableBytes() - Method in class alluxio.worker.block.meta.StorageTier
 
getBackupManager() - Method in class alluxio.master.MasterContext
 
getBackupUri() - Method in class alluxio.thrift.BackupTResponse
 
getBackupUri() - Method in class alluxio.wire.BackupResponse
 
getBaseTransport() - Method in class alluxio.network.thrift.BootstrapServerTransport
 
getBaseTransport() - Method in class alluxio.network.thrift.PeekableTransport
 
getBaseURI() - Method in class alluxio.StandardURI
 
getBaseURI() - Method in interface alluxio.URI
 
getBindAddress(NetworkAddressUtils.ServiceType) - 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.netty.NettyDataServer
 
getBindHost(NetworkAddressUtils.ServiceType) - Static method in class alluxio.util.network.NetworkAddressUtils
Helper method to get the InetSocketAddress bind address on a given service.
getBindHost() - Method in class alluxio.web.WebServer
Gets the actual bind hostname.
getBindHostKey() - Method in enum alluxio.util.network.NetworkAddressUtils.ServiceType
Gets the key of bind hostname.
getBlockClient() - Method in class alluxio.cli.fsadmin.command.Context
 
getBlockContainerIdGenerator() - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
optional .alluxio.proto.journal.BlockContainerIdGeneratorEntry block_container_id_generator = 3;
getBlockContainerIdGenerator() - Method in class alluxio.proto.journal.Journal.JournalEntry
optional .alluxio.proto.journal.BlockContainerIdGeneratorEntry block_container_id_generator = 3;
getBlockContainerIdGenerator() - Method in interface alluxio.proto.journal.Journal.JournalEntryOrBuilder
optional .alluxio.proto.journal.BlockContainerIdGeneratorEntry block_container_id_generator = 3;
getBlockContainerIdGeneratorBuilder() - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
optional .alluxio.proto.journal.BlockContainerIdGeneratorEntry block_container_id_generator = 3;
getBlockContainerIdGeneratorOrBuilder() - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
optional .alluxio.proto.journal.BlockContainerIdGeneratorEntry block_container_id_generator = 3;
getBlockContainerIdGeneratorOrBuilder() - Method in class alluxio.proto.journal.Journal.JournalEntry
optional .alluxio.proto.journal.BlockContainerIdGeneratorEntry block_container_id_generator = 3;
getBlockContainerIdGeneratorOrBuilder() - Method in interface alluxio.proto.journal.Journal.JournalEntryOrBuilder
optional .alluxio.proto.journal.BlockContainerIdGeneratorEntry block_container_id_generator = 3;
getBlockDeletionContext() - Method in class alluxio.master.file.RpcContext
 
getBlockId() - Method in class alluxio.client.block.policy.options.GetWorkerOptions
 
getBlockId() - Method in class alluxio.master.block.meta.MasterBlockInfo
 
getBlockId() - Method in class alluxio.proto.dataserver.Protocol.AsyncCacheRequest.Builder
optional int64 block_id = 1;
getBlockId() - Method in class alluxio.proto.dataserver.Protocol.AsyncCacheRequest
optional int64 block_id = 1;
getBlockId() - Method in interface alluxio.proto.dataserver.Protocol.AsyncCacheRequestOrBuilder
optional int64 block_id = 1;
getBlockId() - Method in class alluxio.proto.dataserver.Protocol.LocalBlockCloseRequest.Builder
optional int64 block_id = 1;
getBlockId() - Method in class alluxio.proto.dataserver.Protocol.LocalBlockCloseRequest
optional int64 block_id = 1;
getBlockId() - Method in interface alluxio.proto.dataserver.Protocol.LocalBlockCloseRequestOrBuilder
optional int64 block_id = 1;
getBlockId() - Method in class alluxio.proto.dataserver.Protocol.LocalBlockCompleteRequest.Builder
optional int64 block_id = 1;
getBlockId() - Method in class alluxio.proto.dataserver.Protocol.LocalBlockCompleteRequest
optional int64 block_id = 1;
getBlockId() - Method in interface alluxio.proto.dataserver.Protocol.LocalBlockCompleteRequestOrBuilder
optional int64 block_id = 1;
getBlockId() - Method in class alluxio.proto.dataserver.Protocol.LocalBlockCreateRequest.Builder
optional int64 block_id = 1;
getBlockId() - Method in class alluxio.proto.dataserver.Protocol.LocalBlockCreateRequest
optional int64 block_id = 1;
getBlockId() - Method in interface alluxio.proto.dataserver.Protocol.LocalBlockCreateRequestOrBuilder
optional int64 block_id = 1;
getBlockId() - Method in class alluxio.proto.dataserver.Protocol.LocalBlockOpenRequest.Builder
optional int64 block_id = 1;
getBlockId() - Method in class alluxio.proto.dataserver.Protocol.LocalBlockOpenRequest
optional int64 block_id = 1;
getBlockId() - Method in interface alluxio.proto.dataserver.Protocol.LocalBlockOpenRequestOrBuilder
optional int64 block_id = 1;
getBlockId() - Method in class alluxio.proto.dataserver.Protocol.ReadRequest.Builder
optional int64 block_id = 1;
getBlockId() - Method in class alluxio.proto.dataserver.Protocol.ReadRequest
optional int64 block_id = 1;
getBlockId() - Method in interface alluxio.proto.dataserver.Protocol.ReadRequestOrBuilder
optional int64 block_id = 1;
getBlockId() - Method in class alluxio.proto.journal.Block.BlockInfoEntry.Builder
optional int64 block_id = 1;
getBlockId() - Method in class alluxio.proto.journal.Block.BlockInfoEntry
optional int64 block_id = 1;
getBlockId() - Method in interface alluxio.proto.journal.Block.BlockInfoEntryOrBuilder
optional int64 block_id = 1;
getBlockId() - Method in class alluxio.proto.journal.Block.DeleteBlockEntry.Builder
optional int64 block_id = 1;
getBlockId() - Method in class alluxio.proto.journal.Block.DeleteBlockEntry
optional int64 block_id = 1;
getBlockId() - Method in interface alluxio.proto.journal.Block.DeleteBlockEntryOrBuilder
optional int64 block_id = 1;
getBlockId() - Method in class alluxio.proto.journal.KeyValue.CompletePartitionEntry.Builder
optional int64 block_id = 4;
getBlockId() - Method in class alluxio.proto.journal.KeyValue.CompletePartitionEntry
optional int64 block_id = 4;
getBlockId() - Method in interface alluxio.proto.journal.KeyValue.CompletePartitionEntryOrBuilder
optional int64 block_id = 4;
getBlockId() - Method in class alluxio.thrift.BlockInfo
 
getBlockId() - Method in class alluxio.thrift.BlockMasterClientService.getBlockInfo_args
the id of the block
getBlockId() - Method in class alluxio.thrift.BlockMasterWorkerService.commitBlock_args
the id of the block being committed
getBlockId() - Method in class alluxio.thrift.BlockWorkerClientService.accessBlock_args
the id of the block being accessed
getBlockId() - Method in class alluxio.thrift.BlockWorkerClientService.cacheBlock_args
the id of the block being accessed
getBlockId() - Method in class alluxio.thrift.BlockWorkerClientService.cancelBlock_args
the id of the block being accessed
getBlockId() - Method in class alluxio.thrift.BlockWorkerClientService.lockBlock_args
the id of the block being accessed
getBlockId() - Method in class alluxio.thrift.BlockWorkerClientService.promoteBlock_args
the id of the block being accessed
getBlockId() - Method in class alluxio.thrift.BlockWorkerClientService.removeBlock_args
the id of the block being removed
getBlockId() - Method in class alluxio.thrift.BlockWorkerClientService.requestBlockLocation_args
the id of the block being accessed
getBlockId() - Method in class alluxio.thrift.BlockWorkerClientService.requestSpace_args
the id of the block being accessed
getBlockId() - Method in class alluxio.thrift.BlockWorkerClientService.unlockBlock_args
the id of the block being accessed
getBlockId() - Method in class alluxio.thrift.KeyValueWorkerClientService.get_args
the id of the block being accessed
getBlockId() - Method in class alluxio.thrift.KeyValueWorkerClientService.getNextKeys_args
the id of the partition
getBlockId() - Method in class alluxio.thrift.KeyValueWorkerClientService.getSize_args
the id of the partition
getBlockId() - Method in class alluxio.thrift.PartitionInfo
 
getBlockId() - Method in class alluxio.wire.BlockInfo
 
getBlockId() - Method in class alluxio.worker.block.evictor.BlockTransferInfo
 
getBlockId() - Method in class alluxio.worker.block.meta.AbstractBlockMeta
 
getBlockId() - Method in class alluxio.worker.block.meta.UnderFileSystemBlockMeta
 
getBlockIdByIndex(int) - Method in class alluxio.master.file.meta.InodeFile
Gets the block id for a given index.
getBlockIds() - Method in class alluxio.client.file.URIStatus
 
getBlockIds() - Method in class alluxio.master.file.meta.InodeFile
 
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.thrift.FileInfo
 
getBlockIds() - Method in class alluxio.thrift.PersistFile
 
getBlockIds() - Method in class alluxio.wire.FileInfo
 
getBlockIds() - Method in class alluxio.worker.block.meta.StorageDir
Returns the list of block ids in this dir.
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;
getBlockIdsIterator() - Method in class alluxio.thrift.FileInfo
 
getBlockIdsIterator() - Method in class alluxio.thrift.PersistFile
 
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;
getBlockIdsSize() - Method in class alluxio.thrift.FileInfo
 
getBlockIdsSize() - Method in class alluxio.thrift.PersistFile
 
getBlockInfo(long) - Method in interface alluxio.client.block.BlockMasterClient
Returns the BlockInfo for a block id.
getBlockInfo(long) - Method in class alluxio.client.block.RetryHandlingBlockMasterClient
Returns the BlockInfo for a block id.
getBlockInfo(long) - Method in class alluxio.client.file.options.InStreamOptions
 
getBlockInfo(long) - Method in interface alluxio.master.block.BlockMaster
 
getBlockInfo(Long) - Method in class alluxio.master.block.BlockMasterClientRestServiceHandler
Deprecated.
 
getBlockInfo(long, GetBlockInfoTOptions) - 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(long, GetBlockInfoTOptions, AsyncMethodCallback) - Method in class alluxio.thrift.BlockMasterClientService.AsyncClient
 
getBlockInfo(long, GetBlockInfoTOptions, AsyncMethodCallback) - Method in interface alluxio.thrift.BlockMasterClientService.AsyncIface
 
getBlockInfo() - Constructor for class alluxio.thrift.BlockMasterClientService.AsyncProcessor.getBlockInfo
 
getBlockInfo(long, GetBlockInfoTOptions) - Method in class alluxio.thrift.BlockMasterClientService.Client
 
getBlockInfo(long, GetBlockInfoTOptions) - Method in interface alluxio.thrift.BlockMasterClientService.Iface
Returns the block information for the given block id.
getBlockInfo() - Constructor for class alluxio.thrift.BlockMasterClientService.Processor.getBlockInfo
 
getBlockInfo() - Method in class alluxio.thrift.FileBlockInfo
 
getBlockInfo() - Method in class alluxio.thrift.GetBlockInfoTResponse
 
getBlockInfo() - Method in class alluxio.wire.FileBlockInfo
 
getBlockInfo_args() - Constructor for class alluxio.thrift.BlockMasterClientService.getBlockInfo_args
 
getBlockInfo_args(long, GetBlockInfoTOptions) - Constructor for class alluxio.thrift.BlockMasterClientService.getBlockInfo_args
 
getBlockInfo_args(BlockMasterClientService.getBlockInfo_args) - Constructor for class alluxio.thrift.BlockMasterClientService.getBlockInfo_args
Performs a deep copy on other.
getBlockInfo_call(long, GetBlockInfoTOptions, AsyncMethodCallback, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class alluxio.thrift.BlockMasterClientService.AsyncClient.getBlockInfo_call
 
getBlockInfo_result() - Constructor for class alluxio.thrift.BlockMasterClientService.getBlockInfo_result
 
getBlockInfo_result(GetBlockInfoTResponse, AlluxioTException) - Constructor for class alluxio.thrift.BlockMasterClientService.getBlockInfo_result
 
getBlockInfo_result(BlockMasterClientService.getBlockInfo_result) - Constructor for class alluxio.thrift.BlockMasterClientService.getBlockInfo_result
Performs a deep copy on other.
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) - 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.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;
GetBlockInfoTOptions - Class in alluxio.thrift
 
GetBlockInfoTOptions() - Constructor for class alluxio.thrift.GetBlockInfoTOptions
 
GetBlockInfoTOptions(GetBlockInfoTOptions) - Constructor for class alluxio.thrift.GetBlockInfoTOptions
Performs a deep copy on other.
GetBlockInfoTOptions._Fields - Enum in alluxio.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
GetBlockInfoTResponse - Class in alluxio.thrift
 
GetBlockInfoTResponse() - Constructor for class alluxio.thrift.GetBlockInfoTResponse
 
GetBlockInfoTResponse(BlockInfo) - Constructor for class alluxio.thrift.GetBlockInfoTResponse
 
GetBlockInfoTResponse(GetBlockInfoTResponse) - Constructor for class alluxio.thrift.GetBlockInfoTResponse
Performs a deep copy on other.
GetBlockInfoTResponse._Fields - Enum in alluxio.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
getBlockIterator() - Method in class alluxio.worker.block.evictor.AbstractEvictor
Returns an iterator for evictor cache blocks.
getBlockIterator() - Method in class alluxio.worker.block.evictor.LRFUEvictor
 
getBlockIterator() - Method in class alluxio.worker.block.evictor.LRUEvictor
 
getBlockLength() - Method in class alluxio.web.UIFileBlockInfo
 
getBlockList() - Method in interface alluxio.worker.block.BlockStoreMeta
getBlockList() - Method in class alluxio.worker.block.DefaultBlockStoreMeta
 
getBlockLocation() - Method in class alluxio.worker.block.meta.AbstractBlockMeta
 
getBlockLocations() - Method in class alluxio.master.block.meta.MasterBlockInfo
Gets the net addresses for all workers which have the block's data in their tiered storage.
getBlockMasterInfo(Set<BlockMasterInfo.BlockMasterInfoField>) - Method in interface alluxio.client.block.BlockMasterClient
 
getBlockMasterInfo(Set<BlockMasterInfo.BlockMasterInfoField>) - Method in class alluxio.client.block.RetryHandlingBlockMasterClient
 
getBlockMasterInfo(GetBlockMasterInfoTOptions) - Method in class alluxio.master.block.BlockMasterClientServiceHandler
 
getBlockMasterInfo(GetBlockMasterInfoTOptions, AsyncMethodCallback) - Method in class alluxio.thrift.BlockMasterClientService.AsyncClient
 
getBlockMasterInfo(GetBlockMasterInfoTOptions, AsyncMethodCallback) - Method in interface alluxio.thrift.BlockMasterClientService.AsyncIface
 
getBlockMasterInfo() - Constructor for class alluxio.thrift.BlockMasterClientService.AsyncProcessor.getBlockMasterInfo
 
getBlockMasterInfo(GetBlockMasterInfoTOptions) - Method in class alluxio.thrift.BlockMasterClientService.Client
 
getBlockMasterInfo(GetBlockMasterInfoTOptions) - Method in interface alluxio.thrift.BlockMasterClientService.Iface
Returns block master information.
getBlockMasterInfo() - Constructor for class alluxio.thrift.BlockMasterClientService.Processor.getBlockMasterInfo
 
getBlockMasterInfo() - Method in class alluxio.thrift.GetBlockMasterInfoTResponse
 
getBlockMasterInfo_args() - Constructor for class alluxio.thrift.BlockMasterClientService.getBlockMasterInfo_args
 
getBlockMasterInfo_args(GetBlockMasterInfoTOptions) - Constructor for class alluxio.thrift.BlockMasterClientService.getBlockMasterInfo_args
 
getBlockMasterInfo_args(BlockMasterClientService.getBlockMasterInfo_args) - Constructor for class alluxio.thrift.BlockMasterClientService.getBlockMasterInfo_args
Performs a deep copy on other.
getBlockMasterInfo_call(GetBlockMasterInfoTOptions, AsyncMethodCallback, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class alluxio.thrift.BlockMasterClientService.AsyncClient.getBlockMasterInfo_call
 
getBlockMasterInfo_result() - Constructor for class alluxio.thrift.BlockMasterClientService.getBlockMasterInfo_result
 
getBlockMasterInfo_result(GetBlockMasterInfoTResponse, AlluxioTException) - Constructor for class alluxio.thrift.BlockMasterClientService.getBlockMasterInfo_result
 
getBlockMasterInfo_result(BlockMasterClientService.getBlockMasterInfo_result) - Constructor for class alluxio.thrift.BlockMasterClientService.getBlockMasterInfo_result
Performs a deep copy on other.
GetBlockMasterInfoTOptions - Class in alluxio.thrift
 
GetBlockMasterInfoTOptions() - Constructor for class alluxio.thrift.GetBlockMasterInfoTOptions
 
GetBlockMasterInfoTOptions(Set<BlockMasterInfoField>) - Constructor for class alluxio.thrift.GetBlockMasterInfoTOptions
 
GetBlockMasterInfoTOptions(GetBlockMasterInfoTOptions) - Constructor for class alluxio.thrift.GetBlockMasterInfoTOptions
Performs a deep copy on other.
GetBlockMasterInfoTOptions._Fields - Enum in alluxio.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
GetBlockMasterInfoTResponse - Class in alluxio.thrift
 
GetBlockMasterInfoTResponse() - Constructor for class alluxio.thrift.GetBlockMasterInfoTResponse
 
GetBlockMasterInfoTResponse(BlockMasterInfo) - Constructor for class alluxio.thrift.GetBlockMasterInfoTResponse
 
GetBlockMasterInfoTResponse(GetBlockMasterInfoTResponse) - Constructor for class alluxio.thrift.GetBlockMasterInfoTResponse
Performs a deep copy on other.
GetBlockMasterInfoTResponse._Fields - Enum in alluxio.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
getBlockMeta(long) - Method in class alluxio.worker.block.BlockMetadataManager
Gets the metadata of a block given its block id.
getBlockMeta(long) - Method in class alluxio.worker.block.BlockMetadataManagerView
Returns null if block is pinned or currently being locked, otherwise returns BlockMetadataManager.getBlockMeta(long).
getBlockMeta(long, long, long) - Method in interface alluxio.worker.block.BlockStore
Gets the metadata of a specific block from local storage.
getBlockMeta(long, long, long) - Method in interface alluxio.worker.block.BlockWorker
Gets the metadata of a specific block from local storage.
getBlockMeta(long, long, long) - Method in class alluxio.worker.block.DefaultBlockWorker
 
getBlockMeta(long) - Method in class alluxio.worker.block.meta.StorageDir
Gets the BlockMeta from this storage dir by its block id.
getBlockMeta(long, long, long) - Method in class alluxio.worker.block.TieredBlockStore
 
getBlockMetadataManagerView() - Method in class alluxio.worker.block.meta.StorageTierView
 
getBlockPath() - Method in class alluxio.thrift.LockBlockTResponse
 
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) - 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.netty.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() - Method in class alluxio.worker.block.meta.StorageDir
Returns the list of blocks stored in this dir.
getBlocksCount() - Method in class alluxio.proto.journal.File.InodeFileEntry.Builder
repeated int64 blocks = 12;
getBlocksCount() - Method in class alluxio.proto.journal.File.InodeFileEntry
repeated int64 blocks = 12;
getBlocksCount() - Method in interface alluxio.proto.journal.File.InodeFileEntryOrBuilder
repeated int64 blocks = 12;
getBlockSize() - Method in class alluxio.client.block.options.LockBlockOptions
 
getBlockSize() - Method in class alluxio.client.block.policy.options.GetWorkerOptions
 
getBlockSize() - Method in class alluxio.proto.dataserver.Protocol.OpenUfsBlockOptions.Builder
optional int64 block_size = 3;
getBlockSize() - Method in class alluxio.proto.dataserver.Protocol.OpenUfsBlockOptions
optional int64 block_size = 3;
getBlockSize() - Method in interface alluxio.proto.dataserver.Protocol.OpenUfsBlockOptionsOrBuilder
optional int64 block_size = 3;
getBlockSize() - Method in class alluxio.thrift.LockBlockTOptions
 
getBlockSize() - Method in class alluxio.worker.block.meta.AbstractBlockMeta
 
getBlockSize() - Method in class alluxio.worker.block.meta.BlockMeta
 
getBlockSize() - Method in class alluxio.worker.block.meta.TempBlockMeta
 
getBlockSize() - Method in class alluxio.worker.block.meta.UnderFileSystemBlockMeta
 
getBlockSizeByte(String) - Method in class alluxio.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
Gets the block size of a file in under file system, in bytes.
getBlockSizeByte(String) - Method in class alluxio.underfs.UnderFileSystemWithLogging
 
getBlockSizeByte(String) - Method in class alluxio.underfs.wasb.WasbUnderFileSystem
 
getBlockSizeBytes() - Method in class alluxio.client.file.options.CreateFileOptions
 
getBlockSizeBytes() - Method in class alluxio.client.file.options.OutStreamOptions
 
getBlockSizeBytes() - Method in class alluxio.client.file.URIStatus
 
getBlockSizeBytes() - Method in class alluxio.master.file.meta.InodeFile
 
getBlockSizeBytes() - Method in class alluxio.master.file.options.CreateFileOptions
 
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.ReinitializeFileEntry.Builder
optional int64 block_size_bytes = 2;
getBlockSizeBytes() - Method in class alluxio.proto.journal.File.ReinitializeFileEntry
optional int64 block_size_bytes = 2;
getBlockSizeBytes() - Method in interface alluxio.proto.journal.File.ReinitializeFileEntryOrBuilder
optional int64 block_size_bytes = 2;
getBlockSizeBytes() - Method in class alluxio.thrift.CreateFileTOptions
 
getBlockSizeBytes() - Method in class alluxio.thrift.FileInfo
 
getBlockSizeBytes() - Method in class alluxio.thrift.LineageMasterClientService.reinitializeFile_args
block size in bytes
getBlockSizeBytes() - Method in class alluxio.web.UIFileInfo
 
getBlockSizeBytes() - Method in class alluxio.wire.FileInfo
 
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;
getBlocksOnTier() - Method in class alluxio.web.UIFileInfo
 
getBlockStore() - Method in interface alluxio.worker.block.BlockWorker
 
getBlockStore() - Method in class alluxio.worker.block.DefaultBlockWorker
 
getBlockStoreMeta() - Method in class alluxio.worker.block.BlockMetadataManager
Gets a summary of the metadata.
getBlockStoreMeta() - Method in interface alluxio.worker.block.BlockStore
Gets the metadata of the entire store in a snapshot.
getBlockStoreMeta() - Method in class alluxio.worker.block.TieredBlockStore
 
getBlockStoreMetaFull() - Method in class alluxio.worker.block.BlockMetadataManager
Gets a full summary of block store metadata.
getBlockStoreMetaFull() - Method in interface alluxio.worker.block.BlockStore
Similar as BlockStore.getBlockStoreMeta() except that this includes more information about the block store (e.g.
getBlockStoreMetaFull() - Method in class alluxio.worker.block.TieredBlockStore
 
getBlockWorkerInfos() - Method in class alluxio.client.block.policy.options.GetWorkerOptions
 
getBlockWriter(long, long) - Method in interface alluxio.worker.block.BlockStore
Creates a writer to write data to a temp block.
getBlockWriter(long, long) - Method in class alluxio.worker.block.TieredBlockStore
 
getBlockWriter() - Method in class alluxio.worker.netty.BlockWriteRequestContext
 
getBoolean(PropertyKey) - Method in interface alluxio.AlluxioConfiguration
Gets the boolean representation of the value for the given key.
getBoolean(PropertyKey) - Method in class alluxio.conf.InstancedConfiguration
 
getBoolean(PropertyKey) - Static method in class alluxio.Configuration
Gets the boolean representation of the value for the given key.
getBucket() - Method in class alluxio.proxy.s3.CompleteMultipartUploadResult
 
getBucket() - Method in class alluxio.proxy.s3.InitiateMultipartUploadResult
 
getBucket() - Method in class alluxio.proxy.s3.ListPartsResult
 
getBucket(String, String, String, String) - Method in class alluxio.proxy.s3.S3RestServiceHandler
 
getBucketName(AlluxioURI) - Static method in class alluxio.util.UnderFileSystemUtils
 
getBufferPosition() - Method in class alluxio.network.thrift.PeekableTransport
 
getByField(Object) - Method in interface alluxio.collections.FieldIndex
Gets a subset of objects with the specified field value.
getByField(IndexDefinition<T>, Object) - Method in class alluxio.collections.IndexedSet
Gets a subset of objects with the specified field value.
getByField(Object) - Method in class alluxio.collections.NonUniqueFieldIndex
 
getByField(Object) - Method in class alluxio.collections.UniqueFieldIndex
 
getBytes(PropertyKey) - Method in interface alluxio.AlluxioConfiguration
Gets the bytes of the value for the given key.
getBytes() - Method in interface alluxio.client.keyvalue.Index
 
getBytes() - Method in class alluxio.client.keyvalue.LinearProbingIndex
 
getBytes(PropertyKey) - Method in class alluxio.conf.InstancedConfiguration
 
getBytes(PropertyKey) - Static method in class alluxio.Configuration
Gets the bytes of the value for the given key.
getBytes() - Method in class alluxio.thrift.GetCapacityBytesTResponse
 
getBytes() - Method in class alluxio.thrift.GetUsedBytesTResponse
 
getBytesRemainingInBuffer() - Method in class alluxio.network.thrift.PeekableTransport
 
getBytesReserved() - Method in class alluxio.worker.netty.BlockWriteRequestContext
 
getBytesWritten() - Method in class alluxio.client.AbstractOutStream
Deprecated.
this method will not work if more than MAX_INT bytes are written; to get a count of bytes written, wrap this stream in a counting output stream such as org.apache.commons.io.output.CountingOutputStream
getCacheable() - Method in class alluxio.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;
getCacheLocationPolicy() - Method in class alluxio.client.file.options.OpenFileOptions
 
getCacheLocationPolicyClass() - Method in class alluxio.client.file.options.OpenFileOptions
 
getCancel() - Method in class alluxio.proto.dataserver.Protocol.LocalBlockCompleteRequest.Builder
optional bool cancel = 2;
getCancel() - Method in class alluxio.proto.dataserver.Protocol.LocalBlockCompleteRequest
optional bool cancel = 2;
getCancel() - Method in interface alluxio.proto.dataserver.Protocol.LocalBlockCompleteRequestOrBuilder
optional bool cancel = 2;
getCancel() - Method in class alluxio.proto.dataserver.Protocol.ReadRequest.Builder
optional bool cancel = 4;
getCancel() - Method in class alluxio.proto.dataserver.Protocol.ReadRequest
optional bool cancel = 4;
getCancel() - Method in interface alluxio.proto.dataserver.Protocol.ReadRequestOrBuilder
optional bool cancel = 4;
getCancel() - Method in class alluxio.proto.dataserver.Protocol.WriteRequest.Builder
optional bool cancel = 6;
getCancel() - Method in class alluxio.proto.dataserver.Protocol.WriteRequest
optional bool cancel = 6;
getCancel() - Method in interface alluxio.proto.dataserver.Protocol.WriteRequestOrBuilder
optional bool cancel = 6;
getCapacity() - Method in class alluxio.web.WebInterfaceGeneralServlet.StorageTierInfo
 
getCapacity() - Method in class alluxio.web.WebInterfaceWorkersServlet.NodeInfo
 
getCapacity() - Method in class alluxio.wire.AlluxioMasterInfo
 
getCapacity() - Method in class alluxio.wire.AlluxioWorkerInfo
 
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() - Method in interface alluxio.master.block.BlockMaster
 
getCapacityBytes(GetCapacityBytesTOptions) - Method in class alluxio.master.block.BlockMasterClientServiceHandler
 
getCapacityBytes() - Method in class alluxio.master.block.DefaultBlockMaster
 
getCapacityBytes() - Method in class alluxio.master.block.meta.MasterWorkerInfo
 
getCapacityBytes() - Method in class alluxio.master.meta.AlluxioMasterRestServiceHandler
Deprecated.
since version 1.4 and will be removed in version 2.0
getCapacityBytes(GetCapacityBytesTOptions, AsyncMethodCallback) - Method in class alluxio.thrift.BlockMasterClientService.AsyncClient
 
getCapacityBytes(GetCapacityBytesTOptions, AsyncMethodCallback) - Method in interface alluxio.thrift.BlockMasterClientService.AsyncIface
 
getCapacityBytes() - Constructor for class alluxio.thrift.BlockMasterClientService.AsyncProcessor.getCapacityBytes
 
getCapacityBytes(GetCapacityBytesTOptions) - Method in class alluxio.thrift.BlockMasterClientService.Client
 
getCapacityBytes(GetCapacityBytesTOptions) - Method in interface alluxio.thrift.BlockMasterClientService.Iface
Returns the capacity (in bytes).
getCapacityBytes() - Constructor for class alluxio.thrift.BlockMasterClientService.Processor.getCapacityBytes
 
getCapacityBytes() - Method in class alluxio.thrift.BlockMasterInfo
 
getCapacityBytes() - Method in class alluxio.thrift.WorkerInfo
 
getCapacityBytes() - Method in class alluxio.web.WebInterfaceWorkerGeneralServlet.UIStorageDir
 
getCapacityBytes() - Method in class alluxio.web.WebInterfaceWorkerGeneralServlet.UIUsageOnTier
 
getCapacityBytes() - Method in class alluxio.wire.BlockMasterInfo
 
getCapacityBytes() - Method in class alluxio.wire.WorkerInfo
 
getCapacityBytes() - Method in class alluxio.worker.AlluxioWorkerRestServiceHandler
Deprecated.
since version 1.4 and will be removed in version 2.0
getCapacityBytes() - Method in interface alluxio.worker.block.BlockStoreMeta
 
getCapacityBytes() - Method in class alluxio.worker.block.DefaultBlockStoreMeta
 
getCapacityBytes() - Method in class alluxio.worker.block.meta.StorageDir
Gets the total capacity of this StorageDir in bytes, which is a constant once this StorageDir has been initialized.
getCapacityBytes() - Method in class alluxio.worker.block.meta.StorageDirView
Gets capacity bytes for this dir.
getCapacityBytes() - Method in class alluxio.worker.block.meta.StorageTier
 
getCapacityBytes_args() - Constructor for class alluxio.thrift.BlockMasterClientService.getCapacityBytes_args
 
getCapacityBytes_args(GetCapacityBytesTOptions) - Constructor for class alluxio.thrift.BlockMasterClientService.getCapacityBytes_args
 
getCapacityBytes_args(BlockMasterClientService.getCapacityBytes_args) - Constructor for class alluxio.thrift.BlockMasterClientService.getCapacityBytes_args
Performs a deep copy on other.
getCapacityBytes_call(GetCapacityBytesTOptions, AsyncMethodCallback, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class alluxio.thrift.BlockMasterClientService.AsyncClient.getCapacityBytes_call
 
getCapacityBytes_result() - Constructor for class alluxio.thrift.BlockMasterClientService.getCapacityBytes_result
 
getCapacityBytes_result(GetCapacityBytesTResponse, AlluxioTException) - Constructor for class alluxio.thrift.BlockMasterClientService.getCapacityBytes_result
 
getCapacityBytes_result(BlockMasterClientService.getCapacityBytes_result) - Constructor for class alluxio.thrift.BlockMasterClientService.getCapacityBytes_result
Performs a deep copy on other.
GetCapacityBytesCommand - Class in alluxio.cli.fs.command
Gets the capacity of the FileSystem.
GetCapacityBytesCommand(FileSystem) - 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.master.meta.AlluxioMasterRestServiceHandler
Deprecated.
since version 1.4 and will be removed in version 2.0
getCapacityBytesOnTiers() - Method in class alluxio.thrift.BlockMasterInfo
 
getCapacityBytesOnTiers() - Method in class alluxio.thrift.WorkerInfo
 
getCapacityBytesOnTiers() - Method in class alluxio.wire.BlockMasterInfo
 
getCapacityBytesOnTiers() - Method in class alluxio.wire.WorkerInfo
 
getCapacityBytesOnTiers() - Method in class alluxio.worker.AlluxioWorkerRestServiceHandler
Deprecated.
since version 1.4 and will be removed in version 2.0
getCapacityBytesOnTiers() - Method in interface alluxio.worker.block.BlockStoreMeta
 
getCapacityBytesOnTiers() - Method in class alluxio.worker.block.DefaultBlockStoreMeta
 
getCapacityBytesOnTiersSize() - Method in class alluxio.thrift.BlockMasterInfo
 
getCapacityBytesOnTiersSize() - Method in class alluxio.thrift.WorkerInfo
 
GetCapacityBytesTOptions - Class in alluxio.thrift
 
GetCapacityBytesTOptions() - Constructor for class alluxio.thrift.GetCapacityBytesTOptions
 
GetCapacityBytesTOptions(GetCapacityBytesTOptions) - Constructor for class alluxio.thrift.GetCapacityBytesTOptions
Performs a deep copy on other.
GetCapacityBytesTOptions._Fields - Enum in alluxio.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
GetCapacityBytesTResponse - Class in alluxio.thrift
 
GetCapacityBytesTResponse() - Constructor for class alluxio.thrift.GetCapacityBytesTResponse
 
GetCapacityBytesTResponse(long) - Constructor for class alluxio.thrift.GetCapacityBytesTResponse
 
GetCapacityBytesTResponse(GetCapacityBytesTResponse) - Constructor for class alluxio.thrift.GetCapacityBytesTResponse
Performs a deep copy on other.
GetCapacityBytesTResponse._Fields - Enum in alluxio.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
getCascade() - Method in class alluxio.proto.journal.Lineage.DeleteLineageEntry.Builder
optional bool cascade = 2;
getCascade() - Method in class alluxio.proto.journal.Lineage.DeleteLineageEntry
optional bool cascade = 2;
getCascade() - Method in interface alluxio.proto.journal.Lineage.DeleteLineageEntryOrBuilder
optional bool cascade = 2;
getChannel() - Method in class alluxio.network.netty.NettyRPCContext
 
getChannel() - Method in interface alluxio.worker.block.io.BlockReader
Returns a readable byte channel of the block.
getChannel() - Method in interface alluxio.worker.block.io.BlockWriter
 
getChannel() - Method in class alluxio.worker.block.io.LocalFileBlockReader
 
getChannel() - Method in class alluxio.worker.block.io.LocalFileBlockWriter
 
getChannel() - Method in class alluxio.worker.block.RemoteBlockReader
 
getChannel() - Method in class alluxio.worker.block.UnderFileSystemBlockReader
 
getCheckpoint() - Method in class alluxio.master.journalv0.ufs.UfsJournal
 
getCheckpointInputStream() - Method in interface alluxio.master.journalv0.JournalReader
Gets the JournalInputStream for the journal checkpoint.
getCheckpointInputStream() - Method in class alluxio.master.journalv0.ufs.UfsJournalReader
 
getCheckpointLastModifiedTimeMs() - Method in interface alluxio.master.journalv0.JournalReader
 
getCheckpointLastModifiedTimeMs() - Method in class alluxio.master.journalv0.ufs.UfsJournalReader
 
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(String) - Method in class alluxio.master.file.meta.InodeDirectory
 
getChildName(String, String) - Method in class alluxio.underfs.ObjectUnderFileSystem
Gets the child name based on the parent name.
getChildReadLock(String, InodeLockList) - Method in class alluxio.master.file.meta.InodeDirectory
 
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() - Method in class alluxio.master.file.meta.InodeDirectory
 
getChildren(Lineage) - Method in class alluxio.master.lineage.meta.LineageStore
Gets all the children of a given lineage.
getChildren(Lineage) - Method in class alluxio.master.lineage.meta.LineageStoreView
 
getChildren() - Method in class alluxio.thrift.LineageInfo
 
getChildren() - Method in class alluxio.wire.LineageInfo
 
getChildrenIds() - Method in class alluxio.master.file.meta.InodeDirectory
 
getChildrenIterator() - Method in class alluxio.thrift.LineageInfo
 
getChildrenSize() - Method in class alluxio.thrift.LineageInfo
 
getChildWriteLock(String, InodeLockList) - Method in class alluxio.master.file.meta.InodeDirectory
 
getClass(PropertyKey) - Method in interface alluxio.AlluxioConfiguration
Gets the value for the given key as a class.
getClass(PropertyKey) - Method in class alluxio.conf.InstancedConfiguration
 
getClass(PropertyKey) - Static method in class alluxio.Configuration
Gets the value for the given key as a class.
getClient() - Method in class alluxio.AbstractClient
 
getClient() - Method in class alluxio.client.block.RetryHandlingBlockMasterClient
 
getClient() - Method in class alluxio.client.file.RetryHandlingFileSystemMasterClient
 
getClient() - Method in class alluxio.client.keyvalue.KeyValueMasterClient
 
getClient() - Method in class alluxio.client.keyvalue.KeyValueWorkerClient
 
getClient() - Method in class alluxio.client.lineage.LineageMasterClient
 
getClient() - Method in class alluxio.client.metrics.MetricsMasterClient
 
getClient() - Method in class alluxio.client.RetryHandlingMetaMasterClient
 
getClient() - Method in class alluxio.master.AbstractLocalAlluxioCluster
Returns a FileSystem client.
getClient(FileSystemContext) - Method in class alluxio.master.AbstractLocalAlluxioCluster
 
getClient() - Method in class alluxio.master.ClientPool
Returns a FileSystem client.
getClient(FileSystemContext) - Method in class alluxio.master.ClientPool
Returns a FileSystem client using a specific context.
getClient() - Method in class alluxio.master.LocalAlluxioCluster
 
getClient(FileSystemContext) - Method in class alluxio.master.LocalAlluxioCluster
 
getClient() - Method in class alluxio.master.LocalAlluxioMaster
 
getClient(FileSystemContext) - Method in class alluxio.master.LocalAlluxioMaster
 
getClient() - Method in class alluxio.master.meta.RetryHandlingMetaMasterMasterClient
 
getClient() - Method in class alluxio.master.MultiMasterLocalAlluxioCluster
 
getClient(FileSystemContext) - Method in class alluxio.master.MultiMasterLocalAlluxioCluster
 
getClient(String, String, String, boolean) - Static method in class alluxio.master.ZkMasterInquireClient
Gets the client.
getClient(TProtocol) - Method in class alluxio.thrift.AlluxioService.Client.Factory
 
getClient(TProtocol, TProtocol) - Method in class alluxio.thrift.AlluxioService.Client.Factory
 
getClient(TProtocol) - Method in class alluxio.thrift.BlockMasterClientService.Client.Factory
 
getClient(TProtocol, TProtocol) - Method in class alluxio.thrift.BlockMasterClientService.Client.Factory
 
getClient(TProtocol) - Method in class alluxio.thrift.BlockMasterWorkerService.Client.Factory
 
getClient(TProtocol, TProtocol) - Method in class alluxio.thrift.BlockMasterWorkerService.Client.Factory
 
getClient(TProtocol) - Method in class alluxio.thrift.BlockWorkerClientService.Client.Factory
 
getClient(TProtocol, TProtocol) - Method in class alluxio.thrift.BlockWorkerClientService.Client.Factory
 
getClient(TProtocol) - Method in class alluxio.thrift.FileSystemMasterClientService.Client.Factory
 
getClient(TProtocol, TProtocol) - Method in class alluxio.thrift.FileSystemMasterClientService.Client.Factory
 
getClient(TProtocol) - Method in class alluxio.thrift.FileSystemMasterWorkerService.Client.Factory
 
getClient(TProtocol, TProtocol) - Method in class alluxio.thrift.FileSystemMasterWorkerService.Client.Factory
 
getClient(TProtocol) - Method in class alluxio.thrift.FileSystemWorkerClientService.Client.Factory
 
getClient(TProtocol, TProtocol) - Method in class alluxio.thrift.FileSystemWorkerClientService.Client.Factory
 
getClient(TProtocol) - Method in class alluxio.thrift.KeyValueMasterClientService.Client.Factory
 
getClient(TProtocol, TProtocol) - Method in class alluxio.thrift.KeyValueMasterClientService.Client.Factory
 
getClient(TProtocol) - Method in class alluxio.thrift.KeyValueWorkerClientService.Client.Factory
 
getClient(TProtocol, TProtocol) - Method in class alluxio.thrift.KeyValueWorkerClientService.Client.Factory
 
getClient(TProtocol) - Method in class alluxio.thrift.LineageMasterClientService.Client.Factory
 
getClient(TProtocol, TProtocol) - Method in class alluxio.thrift.LineageMasterClientService.Client.Factory
 
getClient(TProtocol) - Method in class alluxio.thrift.MetaMasterClientService.Client.Factory
 
getClient(TProtocol, TProtocol) - Method in class alluxio.thrift.MetaMasterClientService.Client.Factory
 
getClient(TProtocol) - Method in class alluxio.thrift.MetaMasterMasterService.Client.Factory
 
getClient(TProtocol, TProtocol) - Method in class alluxio.thrift.MetaMasterMasterService.Client.Factory
 
getClient(TProtocol) - Method in class alluxio.thrift.MetricsMasterClientService.Client.Factory
 
getClient(TProtocol, TProtocol) - Method in class alluxio.thrift.MetricsMasterClientService.Client.Factory
 
getClient() - Method in class alluxio.worker.block.BlockMasterClient
 
getClient() - Method in class alluxio.worker.file.FileSystemMasterClient
 
getClientChannelClass(boolean) - Static method in class alluxio.util.network.NettyUtils
Returns the correct SocketChannel class for use by the client.
getClientHostName() - Static method in class alluxio.util.network.NetworkAddressUtils
Gets the local hostname to be used by the client.
getClientId() - Method in class alluxio.thrift.MetricsMasterClientService.metricsHeartbeat_args
the id of the client
getClientIp() - Static method in class alluxio.master.file.FileSystemMasterClientServiceProcessor
Retrieves the client IP of current thread.
getClientTransport(InetSocketAddress) - Method in class alluxio.security.authentication.NoSaslTransportProvider
 
getClientTransport(Subject, InetSocketAddress) - Method in class alluxio.security.authentication.NoSaslTransportProvider
 
getClientTransport(InetSocketAddress) - Method in class alluxio.security.authentication.PlainSaslTransportProvider
 
getClientTransport(Subject, InetSocketAddress) - Method in class alluxio.security.authentication.PlainSaslTransportProvider
 
getClientTransport(String, String, String, InetSocketAddress) - Method in class alluxio.security.authentication.PlainSaslTransportProvider
Gets a PLAIN mechanism transport for client side.
getClientTransport(InetSocketAddress) - Method in interface alluxio.security.authentication.TransportProvider
Creates a transport per the connection options.
getClientTransport(Subject, InetSocketAddress) - Method in interface alluxio.security.authentication.TransportProvider
Similar as TransportProvider.getClientTransport(InetSocketAddress) but it also specifies the Subject explicitly.
getClientUser() - Static method in class alluxio.security.authentication.AuthenticatedClientUser
Gets the user name from the ThreadLocal variable.
getClock() - Method in class alluxio.time.TimeContext
 
getClusterMetricName(String) - Static method in class alluxio.metrics.MetricsSystem
Builds metric registry names for cluster.
getCode() - Method in class alluxio.proxy.s3.S3Error
 
getCode() - Method in class alluxio.proxy.s3.S3ErrorCode
 
getCommand() - Method in class alluxio.job.CommandLineJob
Gets the command.
getCommand() - Method in class alluxio.thrift.BlockHeartbeatTResponse
 
getCommand() - Method in class alluxio.thrift.CommandLineJobInfo
 
getCommand() - Method in class alluxio.thrift.FileSystemHeartbeatTResponse
 
getCommand() - Method in class alluxio.thrift.MasterHeartbeatTResponse
 
getCommand() - Method in class alluxio.wire.CommandLineJobInfo
 
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.CreateLineageCommand
 
getCommandName() - Method in class alluxio.cli.fs.command.DeleteLineageCommand
 
getCommandName() - Method in class alluxio.cli.fs.command.DuCommand
 
getCommandName() - Method in class alluxio.cli.fs.command.FileInfoCommand
Deprecated.
 
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.GetUsedBytesCommand
 
getCommandName() - Method in class alluxio.cli.fs.command.HeadCommand
 
getCommandName() - Method in class alluxio.cli.fs.command.HelpCommand
 
getCommandName() - Method in class alluxio.cli.fs.command.LeaderCommand
 
getCommandName() - Method in class alluxio.cli.fs.command.ListLineagesCommand
 
getCommandName() - Method in class alluxio.cli.fs.command.LoadCommand
 
getCommandName() - Method in class alluxio.cli.fs.command.LoadMetadataCommand
Deprecated.
 
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.ReportCommand
 
getCommandName() - Method in class alluxio.cli.fs.command.RmCommand
 
getCommandName() - Method in class alluxio.cli.fs.command.SetTtlCommand
 
getCommandName() - Method in class alluxio.cli.fs.command.StatCommand
 
getCommandName() - Method in class alluxio.cli.fs.command.TailCommand
 
getCommandName() - Method in class alluxio.cli.fs.command.TestCommand
 
getCommandName() - Method in class alluxio.cli.fs.command.TouchCommand
 
getCommandName() - Method in class alluxio.cli.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.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.ReportCommand
 
getCommandName() - Method in class alluxio.cli.fsadmin.command.UfsCommand
 
getCommandOptions() - Method in class alluxio.thrift.FileSystemCommand
 
getCommands() - Method in class alluxio.cli.AbstractShell
 
getCommandType() - Method in class alluxio.thrift.Command
 
getCommandType() - Method in class alluxio.thrift.FileSystemCommand
 
getCommitPath() - Method in class alluxio.worker.block.meta.TempBlockMeta
 
getCommittedBytes() - Method in class alluxio.worker.block.meta.StorageDir
Gets the total size of committed blocks in this StorageDir in bytes.
getCommittedBytes() - Method in class alluxio.worker.block.meta.StorageDirView
Gets committed bytes for this dir.
getCommonOptions() - Method in class alluxio.client.file.options.CheckConsistencyOptions
 
getCommonOptions() - Method in class alluxio.client.file.options.CompleteFileOptions
 
getCommonOptions() - Method in class alluxio.client.file.options.CreateDirectoryOptions
 
getCommonOptions() - Method in class alluxio.client.file.options.CreateFileOptions
 
getCommonOptions() - Method in class alluxio.client.file.options.DeleteOptions
 
getCommonOptions() - Method in class alluxio.client.file.options.ExistsOptions
 
getCommonOptions() - Method in class alluxio.client.file.options.FreeOptions
 
getCommonOptions() - Method in class alluxio.client.file.options.GetStatusOptions
 
getCommonOptions() - Method in class alluxio.client.file.options.ListStatusOptions
 
getCommonOptions() - Method in class alluxio.client.file.options.MountOptions
 
getCommonOptions() - Method in class alluxio.client.file.options.RenameOptions
 
getCommonOptions() - Method in class alluxio.client.file.options.SetAttributeOptions
 
getCommonOptions() - Method in class alluxio.client.file.options.UnmountOptions
 
getCommonOptions() - Method in class alluxio.master.file.options.CheckConsistencyOptions
 
getCommonOptions() - Method in class alluxio.master.file.options.CompleteFileOptions
 
getCommonOptions() - Method in class alluxio.master.file.options.CreatePathOptions
 
getCommonOptions() - Method in class alluxio.master.file.options.DeleteOptions
 
getCommonOptions() - Method in class alluxio.master.file.options.FreeOptions
 
getCommonOptions() - Method in class alluxio.master.file.options.GetStatusOptions
 
getCommonOptions() - Method in class alluxio.master.file.options.ListStatusOptions
 
getCommonOptions() - Method in class alluxio.master.file.options.LoadMetadataOptions
 
getCommonOptions() - Method in class alluxio.master.file.options.MountOptions
 
getCommonOptions() - Method in class alluxio.master.file.options.RenameOptions
 
getCommonOptions() - Method in class alluxio.master.file.options.SetAttributeOptions
 
getCommonOptions() - Method in class alluxio.master.file.options.SyncMetadataOptions
 
getCommonOptions() - Method in class alluxio.thrift.CheckConsistencyTOptions
 
getCommonOptions() - Method in class alluxio.thrift.CompleteFileTOptions
 
getCommonOptions() - Method in class alluxio.thrift.CreateDirectoryTOptions
 
getCommonOptions() - Method in class alluxio.thrift.CreateFileTOptions
 
getCommonOptions() - Method in class alluxio.thrift.DeleteTOptions
 
getCommonOptions() - Method in class alluxio.thrift.FreeTOptions
 
getCommonOptions() - Method in class alluxio.thrift.GetNewBlockIdForFileTOptions
 
getCommonOptions() - Method in class alluxio.thrift.GetStatusTOptions
 
getCommonOptions() - Method in class alluxio.thrift.ListStatusTOptions
 
getCommonOptions() - Method in class alluxio.thrift.LoadMetadataTOptions
 
getCommonOptions() - Method in class alluxio.thrift.MountTOptions
 
getCommonOptions() - Method in class alluxio.thrift.RenameTOptions
 
getCommonOptions() - Method in class alluxio.thrift.ScheduleAsyncPersistenceTOptions
 
getCommonOptions() - Method in class alluxio.thrift.SetAttributeTOptions
 
getCommonOptions() - Method in class alluxio.thrift.SyncMetadataTOptions
 
getCommonOptions() - Method in class alluxio.thrift.UnmountTOptions
 
getCommonPrefixes() - Method in interface alluxio.underfs.ObjectUnderFileSystem.ObjectListingChunk
Use common prefixes to infer pseudo-directories in object store.
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;
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;
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;
getCompletePartition() - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
optional .alluxio.proto.journal.CompletePartitionEntry complete_partition = 21;
getCompletePartition() - Method in class alluxio.proto.journal.Journal.JournalEntry
optional .alluxio.proto.journal.CompletePartitionEntry complete_partition = 21;
getCompletePartition() - Method in interface alluxio.proto.journal.Journal.JournalEntryOrBuilder
optional .alluxio.proto.journal.CompletePartitionEntry complete_partition = 21;
getCompletePartitionBuilder() - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
optional .alluxio.proto.journal.CompletePartitionEntry complete_partition = 21;
getCompletePartitionOrBuilder() - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
optional .alluxio.proto.journal.CompletePartitionEntry complete_partition = 21;
getCompletePartitionOrBuilder() - Method in class alluxio.proto.journal.Journal.JournalEntry
optional .alluxio.proto.journal.CompletePartitionEntry complete_partition = 21;
getCompletePartitionOrBuilder() - Method in interface alluxio.proto.journal.Journal.JournalEntryOrBuilder
optional .alluxio.proto.journal.CompletePartitionEntry complete_partition = 21;
getCompleteStore() - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
optional .alluxio.proto.journal.CompleteStoreEntry complete_store = 22;
getCompleteStore() - Method in class alluxio.proto.journal.Journal.JournalEntry
optional .alluxio.proto.journal.CompleteStoreEntry complete_store = 22;
getCompleteStore() - Method in interface alluxio.proto.journal.Journal.JournalEntryOrBuilder
optional .alluxio.proto.journal.CompleteStoreEntry complete_store = 22;
getCompleteStoreBuilder() - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
optional .alluxio.proto.journal.CompleteStoreEntry complete_store = 22;
getCompleteStoreOrBuilder() - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
optional .alluxio.proto.journal.CompleteStoreEntry complete_store = 22;
getCompleteStoreOrBuilder() - Method in class alluxio.proto.journal.Journal.JournalEntry
optional .alluxio.proto.journal.CompleteStoreEntry complete_store = 22;
getCompleteStoreOrBuilder() - Method in interface alluxio.proto.journal.Journal.JournalEntryOrBuilder
optional .alluxio.proto.journal.CompleteStoreEntry complete_store = 22;
GetConf - Class in alluxio.cli
Utility for printing Alluxio configuration.
getConf(String...) - Static method in class alluxio.cli.GetConf
Implements get configuration.
getConf() - Method in class alluxio.multi.process.Master
 
getConf() - Method in class alluxio.thrift.CommandLineJobInfo
 
getConf() - Method in class alluxio.wire.CommandLineJobInfo
 
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
 
getConfigErrors() - Method in class alluxio.wire.ConfigCheckReport
 
getConfigList() - Method in class alluxio.thrift.GetConfigurationTResponse
 
getConfigList() - Method in class alluxio.thrift.RegisterMasterTOptions
 
getConfigList() - Method in class alluxio.thrift.RegisterWorkerTOptions
 
getConfigListIterator() - Method in class alluxio.thrift.GetConfigurationTResponse
 
getConfigListIterator() - Method in class alluxio.thrift.RegisterMasterTOptions
 
getConfigListIterator() - Method in class alluxio.thrift.RegisterWorkerTOptions
 
getConfigListSize() - Method in class alluxio.thrift.GetConfigurationTResponse
 
getConfigListSize() - Method in class alluxio.thrift.RegisterMasterTOptions
 
getConfigListSize() - Method in class alluxio.thrift.RegisterWorkerTOptions
 
getConfigReport() - Method in interface alluxio.client.MetaMasterClient
Gets the server-side configuration check report.
getConfigReport() - Method in class alluxio.client.RetryHandlingMetaMasterClient
 
getConfigReport(GetConfigReportTOptions) - Method in class alluxio.master.meta.MetaMasterClientServiceHandler
 
getConfigReport(GetConfigReportTOptions, AsyncMethodCallback) - Method in class alluxio.thrift.MetaMasterClientService.AsyncClient
 
getConfigReport(GetConfigReportTOptions, AsyncMethodCallback) - Method in interface alluxio.thrift.MetaMasterClientService.AsyncIface
 
getConfigReport() - Constructor for class alluxio.thrift.MetaMasterClientService.AsyncProcessor.getConfigReport
 
getConfigReport(GetConfigReportTOptions) - Method in class alluxio.thrift.MetaMasterClientService.Client
 
getConfigReport(GetConfigReportTOptions) - Method in interface alluxio.thrift.MetaMasterClientService.Iface
Returns server-side configuration report.
getConfigReport() - Constructor for class alluxio.thrift.MetaMasterClientService.Processor.getConfigReport
 
getConfigReport_args() - Constructor for class alluxio.thrift.MetaMasterClientService.getConfigReport_args
 
getConfigReport_args(GetConfigReportTOptions) - Constructor for class alluxio.thrift.MetaMasterClientService.getConfigReport_args
 
getConfigReport_args(MetaMasterClientService.getConfigReport_args) - Constructor for class alluxio.thrift.MetaMasterClientService.getConfigReport_args
Performs a deep copy on other.
getConfigReport_call(GetConfigReportTOptions, AsyncMethodCallback, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class alluxio.thrift.MetaMasterClientService.AsyncClient.getConfigReport_call
 
getConfigReport_result() - Constructor for class alluxio.thrift.MetaMasterClientService.getConfigReport_result
 
getConfigReport_result(GetConfigReportTResponse, AlluxioTException) - Constructor for class alluxio.thrift.MetaMasterClientService.getConfigReport_result
 
getConfigReport_result(MetaMasterClientService.getConfigReport_result) - Constructor for class alluxio.thrift.MetaMasterClientService.getConfigReport_result
Performs a deep copy on other.
GetConfigReportTOptions - Class in alluxio.thrift
 
GetConfigReportTOptions() - Constructor for class alluxio.thrift.GetConfigReportTOptions
 
GetConfigReportTOptions(GetConfigReportTOptions) - Constructor for class alluxio.thrift.GetConfigReportTOptions
Performs a deep copy on other.
GetConfigReportTOptions._Fields - Enum in alluxio.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
GetConfigReportTResponse - Class in alluxio.thrift
 
GetConfigReportTResponse() - Constructor for class alluxio.thrift.GetConfigReportTResponse
 
GetConfigReportTResponse(ConfigCheckReport) - Constructor for class alluxio.thrift.GetConfigReportTResponse
 
GetConfigReportTResponse(GetConfigReportTResponse) - Constructor for class alluxio.thrift.GetConfigReportTResponse
Performs a deep copy on other.
GetConfigReportTResponse._Fields - Enum in alluxio.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
getConfigStatus() - Method in class alluxio.wire.ConfigCheckReport
 
getConfiguration() - Method in interface alluxio.client.MetaMasterClient
Gets the runtime configuration information.
getConfiguration() - Method in class alluxio.client.RetryHandlingMetaMasterClient
 
getConfiguration() - Method in class alluxio.master.meta.AlluxioMasterRestServiceHandler
Deprecated.
since version 1.4 and will be removed in version 2.0
getConfiguration(GetConfigurationOptions) - Method in class alluxio.master.meta.DefaultMetaMaster
 
getConfiguration(GetConfigurationOptions) - Method in interface alluxio.master.meta.MetaMaster
 
getConfiguration(GetConfigurationTOptions) - Method in class alluxio.master.meta.MetaMasterClientServiceHandler
 
getConfiguration(GetConfigurationTOptions, AsyncMethodCallback) - Method in class alluxio.thrift.MetaMasterClientService.AsyncClient
 
getConfiguration(GetConfigurationTOptions, AsyncMethodCallback) - Method in interface alluxio.thrift.MetaMasterClientService.AsyncIface
 
getConfiguration() - Constructor for class alluxio.thrift.MetaMasterClientService.AsyncProcessor.getConfiguration
 
getConfiguration(GetConfigurationTOptions) - Method in class alluxio.thrift.MetaMasterClientService.Client
 
getConfiguration(GetConfigurationTOptions) - Method in interface alluxio.thrift.MetaMasterClientService.Iface
Returns a list of Alluxio runtime configuration information.
getConfiguration() - Constructor for class alluxio.thrift.MetaMasterClientService.Processor.getConfiguration
 
getConfiguration(Scope) - Static method in class alluxio.util.ConfigurationUtils
Gets all global configuration properties filtered by the specified scope.
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.worker.AlluxioWorkerRestServiceHandler
Deprecated.
since version 1.4 and will be removed in version 2.0
getConfiguration_args() - Constructor for class alluxio.thrift.MetaMasterClientService.getConfiguration_args
 
getConfiguration_args(GetConfigurationTOptions) - Constructor for class alluxio.thrift.MetaMasterClientService.getConfiguration_args
 
getConfiguration_args(MetaMasterClientService.getConfiguration_args) - Constructor for class alluxio.thrift.MetaMasterClientService.getConfiguration_args
Performs a deep copy on other.
getConfiguration_call(GetConfigurationTOptions, AsyncMethodCallback, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class alluxio.thrift.MetaMasterClientService.AsyncClient.getConfiguration_call
 
getConfiguration_result() - Constructor for class alluxio.thrift.MetaMasterClientService.getConfiguration_result
 
getConfiguration_result(GetConfigurationTResponse, AlluxioTException) - Constructor for class alluxio.thrift.MetaMasterClientService.getConfiguration_result
 
getConfiguration_result(MetaMasterClientService.getConfiguration_result) - Constructor for class alluxio.thrift.MetaMasterClientService.getConfiguration_result
Performs a deep copy on other.
GetConfigurationOptions - Class in alluxio.wire
Options for getConfiguration operations from the Alluxio meta master.
GetConfigurationTOptions - Class in alluxio.thrift
 
GetConfigurationTOptions() - Constructor for class alluxio.thrift.GetConfigurationTOptions
 
GetConfigurationTOptions(boolean) - Constructor for class alluxio.thrift.GetConfigurationTOptions
 
GetConfigurationTOptions(GetConfigurationTOptions) - Constructor for class alluxio.thrift.GetConfigurationTOptions
Performs a deep copy on other.
GetConfigurationTOptions._Fields - Enum in alluxio.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
GetConfigurationTResponse - Class in alluxio.thrift
 
GetConfigurationTResponse() - Constructor for class alluxio.thrift.GetConfigurationTResponse
 
GetConfigurationTResponse(List<ConfigProperty>) - Constructor for class alluxio.thrift.GetConfigurationTResponse
 
GetConfigurationTResponse(GetConfigurationTResponse) - Constructor for class alluxio.thrift.GetConfigurationTResponse
Performs a deep copy on other.
GetConfigurationTResponse._Fields - Enum in alluxio.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
getConfigWarns() - Method in class alluxio.wire.ConfigCheckReport
 
getConfImpl(Supplier<RetryHandlingMetaMasterClient>, String...) - Static method in class alluxio.cli.GetConf
Implements get configuration.
GetConfKey - Class in alluxio.cli
Utility for printing Alluxio configuration key.
getConfKey(String...) - Static method in class alluxio.cli.GetConfKey
Implements get configuration key.
getConfMap() - Method in class alluxio.master.meta.checkconf.ServerConfigurationStore
 
getConnectAddress(NetworkAddressUtils.ServiceType) - Static method in class alluxio.util.network.NetworkAddressUtils
Helper method to get the InetSocketAddress address for client to communicate with the service.
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) - Static method in class alluxio.util.network.NetworkAddressUtils
Provides an externally resolvable hostname for client to communicate with the service.
getConnectHost(NetworkAddressUtils.ServiceType, AlluxioConfiguration) - Static method in class alluxio.util.network.NetworkAddressUtils
Provides an externally resolvable hostname for client to communicate with the service.
getConsistencyLevel() - Method in class alluxio.PropertyKey
 
getContainerId(long) - Static method in class alluxio.master.block.BlockId
 
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
 
getContinuationToken() - Method in class alluxio.proxy.s3.ListBucketOptions
 
getContinuationToken() - Method in class alluxio.proxy.s3.ListBucketResult
 
getCounter() - Method in class alluxio.worker.netty.ReadRequestContext
 
getCounter() - Method in class alluxio.worker.netty.WriteRequestContext
 
getCreated() - Method in class alluxio.master.file.meta.InodeTree.CreatePathResult
 
getCreateOptions() - Method in class alluxio.worker.netty.UfsFileWriteRequestContext
 
getCreateParent() - Method in class alluxio.underfs.options.CreateOptions
 
getCreateParent() - Method in class alluxio.underfs.options.MkdirsOptions
 
getCreateStore() - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
optional .alluxio.proto.journal.CreateStoreEntry create_store = 23;
getCreateStore() - Method in class alluxio.proto.journal.Journal.JournalEntry
optional .alluxio.proto.journal.CreateStoreEntry create_store = 23;
getCreateStore() - Method in interface alluxio.proto.journal.Journal.JournalEntryOrBuilder
optional .alluxio.proto.journal.CreateStoreEntry create_store = 23;
getCreateStoreBuilder() - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
optional .alluxio.proto.journal.CreateStoreEntry create_store = 23;
getCreateStoreOrBuilder() - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
optional .alluxio.proto.journal.CreateStoreEntry create_store = 23;
getCreateStoreOrBuilder() - Method in class alluxio.proto.journal.Journal.JournalEntry
optional .alluxio.proto.journal.CreateStoreEntry create_store = 23;
getCreateStoreOrBuilder() - Method in interface alluxio.proto.journal.Journal.JournalEntryOrBuilder
optional .alluxio.proto.journal.CreateStoreEntry create_store = 23;
getCreateUfsFileOptions() - Method in class alluxio.proto.dataserver.Protocol.WriteRequest.Builder
optional .alluxio.proto.dataserver.CreateUfsFileOptions create_ufs_file_options = 7;
getCreateUfsFileOptions() - Method in class alluxio.proto.dataserver.Protocol.WriteRequest
optional .alluxio.proto.dataserver.CreateUfsFileOptions create_ufs_file_options = 7;
getCreateUfsFileOptions() - Method in interface alluxio.proto.dataserver.Protocol.WriteRequestOrBuilder
optional .alluxio.proto.dataserver.CreateUfsFileOptions create_ufs_file_options = 7;
getCreateUfsFileOptions() - Method in class alluxio.worker.netty.UfsFileWriteRequest
 
getCreateUfsFileOptionsBuilder() - Method in class alluxio.proto.dataserver.Protocol.WriteRequest.Builder
optional .alluxio.proto.dataserver.CreateUfsFileOptions create_ufs_file_options = 7;
getCreateUfsFileOptionsOrBuilder() - Method in class alluxio.proto.dataserver.Protocol.WriteRequest.Builder
optional .alluxio.proto.dataserver.CreateUfsFileOptions create_ufs_file_options = 7;
getCreateUfsFileOptionsOrBuilder() - Method in class alluxio.proto.dataserver.Protocol.WriteRequest
optional .alluxio.proto.dataserver.CreateUfsFileOptions create_ufs_file_options = 7;
getCreateUfsFileOptionsOrBuilder() - Method in interface alluxio.proto.dataserver.Protocol.WriteRequestOrBuilder
optional .alluxio.proto.dataserver.CreateUfsFileOptions create_ufs_file_options = 7;
getCreationTime() - Method in class alluxio.master.lineage.meta.Lineage
 
getCreationTime() - Method in class alluxio.web.UIFileInfo
 
getCreationTimeMs() - Method in class alluxio.client.file.URIStatus
 
getCreationTimeMs() - Method in class alluxio.master.file.meta.Inode
 
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.Lineage.LineageEntry.Builder
optional int64 creation_time_ms = 6;
getCreationTimeMs() - Method in class alluxio.proto.journal.Lineage.LineageEntry
optional int64 creation_time_ms = 6;
getCreationTimeMs() - Method in interface alluxio.proto.journal.Lineage.LineageEntryOrBuilder
optional int64 creation_time_ms = 6;
getCreationTimeMs() - Method in class alluxio.thrift.FileInfo
 
getCreationTimeMs() - Method in class alluxio.thrift.LineageInfo
 
getCreationTimeMs() - Method in class alluxio.wire.FileInfo
 
getCreationTimeMs() - Method in class alluxio.wire.LineageInfo
 
getCurrentBlocksOnTiers() - Method in class alluxio.thrift.BlockMasterWorkerService.registerWorker_args
the map of list of blocks on each tier
getCurrentBlocksOnTiersSize() - Method in class alluxio.thrift.BlockMasterWorkerService.registerWorker_args
 
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
 
getCustomProvider() - Method in class alluxio.security.authentication.CustomAuthenticationProvider
 
getData() - Method in class alluxio.thrift.Command
 
getData() - Method in class alluxio.thrift.GetTResponse
 
getDataBindHost() - Method in class alluxio.worker.AlluxioWorkerProcess
 
getDataBindHost() - Method in interface alluxio.worker.WorkerProcess
 
getDataBuffer(BlockReadRequestContext, Channel, long, int) - Method in class alluxio.worker.netty.BlockReadHandler.BlockPacketReader
 
getDataDomainSocketPath() - Method in class alluxio.worker.AlluxioWorkerProcess
 
getDataDomainSocketPath() - Method in interface alluxio.worker.WorkerProcess
 
getDataIterator() - Method in class alluxio.thrift.Command
 
getDataLocalPort() - Method in class alluxio.worker.AlluxioWorkerProcess
 
getDataLocalPort() - Method in interface alluxio.worker.WorkerProcess
 
getDataPort() - Method in class alluxio.thrift.WorkerNetAddress
 
getDataPort() - Method in class alluxio.wire.WorkerNetAddress
 
getDataPortSocketAddress(WorkerNetAddress) - Static method in class alluxio.util.network.NetworkAddressUtils
Extracts dataPort socket address from Alluxio representation of network address.
getDataSize() - Method in class alluxio.thrift.Command
 
getDefaultInstance() - Static method in class alluxio.proto.dataserver.Protocol.AsyncCacheRequest
 
getDefaultInstance() - Static method in class alluxio.proto.dataserver.Protocol.CreateUfsFileOptions
 
getDefaultInstance() - Static method in class alluxio.proto.dataserver.Protocol.Heartbeat
 
getDefaultInstance() - Static method in class alluxio.proto.dataserver.Protocol.LocalBlockCloseRequest
 
getDefaultInstance() - Static method in class alluxio.proto.dataserver.Protocol.LocalBlockCompleteRequest
 
getDefaultInstance() - Static method in class alluxio.proto.dataserver.Protocol.LocalBlockCreateRequest
 
getDefaultInstance() - Static method in class alluxio.proto.dataserver.Protocol.LocalBlockCreateResponse
 
getDefaultInstance() - Static method in class alluxio.proto.dataserver.Protocol.LocalBlockOpenRequest
 
getDefaultInstance() - Static method in class alluxio.proto.dataserver.Protocol.LocalBlockOpenResponse
 
getDefaultInstance() - Static method in class alluxio.proto.dataserver.Protocol.OpenUfsBlockOptions
 
getDefaultInstance() - Static method in class alluxio.proto.dataserver.Protocol.ReadRequest
 
getDefaultInstance() - Static method in class alluxio.proto.dataserver.Protocol.ReadResponse
 
getDefaultInstance() - Static method in class alluxio.proto.dataserver.Protocol.Response
 
getDefaultInstance() - Static method in class alluxio.proto.dataserver.Protocol.WriteRequest
 
getDefaultInstance() - Static method in class alluxio.proto.journal.Block.BlockContainerIdGeneratorEntry
 
getDefaultInstance() - Static method in class alluxio.proto.journal.Block.BlockInfoEntry
 
getDefaultInstance() - Static method in class alluxio.proto.journal.Block.DeleteBlockEntry
 
getDefaultInstance() - Static method in class alluxio.proto.journal.File.AddMountPointEntry
 
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.PersistDirectoryEntry
 
getDefaultInstance() - Static method in class alluxio.proto.journal.File.PersistFileEntry
 
getDefaultInstance() - Static method in class alluxio.proto.journal.File.ReinitializeFileEntry
 
getDefaultInstance() - Static method in class alluxio.proto.journal.File.RenameEntry
 
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.UpdateUfsModeEntry
 
getDefaultInstance() - Static method in class alluxio.proto.journal.Journal.JournalEntry
 
getDefaultInstance() - Static method in class alluxio.proto.journal.KeyValue.CompletePartitionEntry
 
getDefaultInstance() - Static method in class alluxio.proto.journal.KeyValue.CompleteStoreEntry
 
getDefaultInstance() - Static method in class alluxio.proto.journal.KeyValue.CreateStoreEntry
 
getDefaultInstance() - Static method in class alluxio.proto.journal.KeyValue.DeleteStoreEntry
 
getDefaultInstance() - Static method in class alluxio.proto.journal.KeyValue.MergeStoreEntry
 
getDefaultInstance() - Static method in class alluxio.proto.journal.KeyValue.RenameStoreEntry
 
getDefaultInstance() - Static method in class alluxio.proto.journal.Lineage.DeleteLineageEntry
 
getDefaultInstance() - Static method in class alluxio.proto.journal.Lineage.LineageEntry
 
getDefaultInstance() - Static method in class alluxio.proto.journal.Lineage.LineageIdGeneratorEntry
 
getDefaultInstanceForType() - Method in class alluxio.proto.dataserver.Protocol.AsyncCacheRequest.Builder
 
getDefaultInstanceForType() - Method in class alluxio.proto.dataserver.Protocol.AsyncCacheRequest
 
getDefaultInstanceForType() - Method in class alluxio.proto.dataserver.Protocol.CreateUfsFileOptions.Builder
 
getDefaultInstanceForType() - Method in class alluxio.proto.dataserver.Protocol.CreateUfsFileOptions
 
getDefaultInstanceForType() - Method in class alluxio.proto.dataserver.Protocol.Heartbeat.Builder
 
getDefaultInstanceForType() - Method in class alluxio.proto.dataserver.Protocol.Heartbeat
 
getDefaultInstanceForType() - Method in class alluxio.proto.dataserver.Protocol.LocalBlockCloseRequest.Builder
 
getDefaultInstanceForType() - Method in class alluxio.proto.dataserver.Protocol.LocalBlockCloseRequest
 
getDefaultInstanceForType() - Method in class alluxio.proto.dataserver.Protocol.LocalBlockCompleteRequest.Builder
 
getDefaultInstanceForType() - Method in class alluxio.proto.dataserver.Protocol.LocalBlockCompleteRequest
 
getDefaultInstanceForType() - Method in class alluxio.proto.dataserver.Protocol.LocalBlockCreateRequest.Builder
 
getDefaultInstanceForType() - Method in class alluxio.proto.dataserver.Protocol.LocalBlockCreateRequest
 
getDefaultInstanceForType() - Method in class alluxio.proto.dataserver.Protocol.LocalBlockCreateResponse.Builder
 
getDefaultInstanceForType() - Method in class alluxio.proto.dataserver.Protocol.LocalBlockCreateResponse
 
getDefaultInstanceForType() - Method in class alluxio.proto.dataserver.Protocol.LocalBlockOpenRequest.Builder
 
getDefaultInstanceForType() - Method in class alluxio.proto.dataserver.Protocol.LocalBlockOpenRequest
 
getDefaultInstanceForType() - Method in class alluxio.proto.dataserver.Protocol.LocalBlockOpenResponse.Builder
 
getDefaultInstanceForType() - Method in class alluxio.proto.dataserver.Protocol.LocalBlockOpenResponse
 
getDefaultInstanceForType() - Method in class alluxio.proto.dataserver.Protocol.OpenUfsBlockOptions.Builder
 
getDefaultInstanceForType() - Method in class alluxio.proto.dataserver.Protocol.OpenUfsBlockOptions
 
getDefaultInstanceForType() - Method in class alluxio.proto.dataserver.Protocol.ReadRequest.Builder
 
getDefaultInstanceForType() - Method in class alluxio.proto.dataserver.Protocol.ReadRequest
 
getDefaultInstanceForType() - Method in class alluxio.proto.dataserver.Protocol.ReadResponse.Builder
 
getDefaultInstanceForType() - Method in class alluxio.proto.dataserver.Protocol.ReadResponse
 
getDefaultInstanceForType() - Method in class alluxio.proto.dataserver.Protocol.Response.Builder
 
getDefaultInstanceForType() - Method in class alluxio.proto.dataserver.Protocol.Response
 
getDefaultInstanceForType() - Method in class alluxio.proto.dataserver.Protocol.WriteRequest.Builder
 
getDefaultInstanceForType() - Method in class alluxio.proto.dataserver.Protocol.WriteRequest
 
getDefaultInstanceForType() - Method in class alluxio.proto.journal.Block.BlockContainerIdGeneratorEntry.Builder
 
getDefaultInstanceForType() - Method in class alluxio.proto.journal.Block.BlockContainerIdGeneratorEntry
 
getDefaultInstanceForType() - Method in class alluxio.proto.journal.Block.BlockInfoEntry.Builder
 
getDefaultInstanceForType() - Method in class alluxio.proto.journal.Block.BlockInfoEntry
 
getDefaultInstanceForType() - Method in class alluxio.proto.journal.Block.DeleteBlockEntry.Builder
 
getDefaultInstanceForType() - Method in class alluxio.proto.journal.Block.DeleteBlockEntry
 
getDefaultInstanceForType() - Method in class alluxio.proto.journal.File.AddMountPointEntry.Builder
 
getDefaultInstanceForType() - Method in class alluxio.proto.journal.File.AddMountPointEntry
 
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.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.ReinitializeFileEntry.Builder
 
getDefaultInstanceForType() - Method in class alluxio.proto.journal.File.ReinitializeFileEntry
 
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.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.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.KeyValue.CompletePartitionEntry.Builder
 
getDefaultInstanceForType() - Method in class alluxio.proto.journal.KeyValue.CompletePartitionEntry
 
getDefaultInstanceForType() - Method in class alluxio.proto.journal.KeyValue.CompleteStoreEntry.Builder
 
getDefaultInstanceForType() - Method in class alluxio.proto.journal.KeyValue.CompleteStoreEntry
 
getDefaultInstanceForType() - Method in class alluxio.proto.journal.KeyValue.CreateStoreEntry.Builder
 
getDefaultInstanceForType() - Method in class alluxio.proto.journal.KeyValue.CreateStoreEntry
 
getDefaultInstanceForType() - Method in class alluxio.proto.journal.KeyValue.DeleteStoreEntry.Builder
 
getDefaultInstanceForType() - Method in class alluxio.proto.journal.KeyValue.DeleteStoreEntry
 
getDefaultInstanceForType() - Method in class alluxio.proto.journal.KeyValue.MergeStoreEntry.Builder
 
getDefaultInstanceForType() - Method in class alluxio.proto.journal.KeyValue.MergeStoreEntry
 
getDefaultInstanceForType() - Method in class alluxio.proto.journal.KeyValue.RenameStoreEntry.Builder
 
getDefaultInstanceForType() - Method in class alluxio.proto.journal.KeyValue.RenameStoreEntry
 
getDefaultInstanceForType() - Method in class alluxio.proto.journal.Lineage.DeleteLineageEntry.Builder
 
getDefaultInstanceForType() - Method in class alluxio.proto.journal.Lineage.DeleteLineageEntry
 
getDefaultInstanceForType() - Method in class alluxio.proto.journal.Lineage.LineageEntry.Builder
 
getDefaultInstanceForType() - Method in class alluxio.proto.journal.Lineage.LineageEntry
 
getDefaultInstanceForType() - Method in class alluxio.proto.journal.Lineage.LineageIdGeneratorEntry.Builder
 
getDefaultInstanceForType() - Method in class alluxio.proto.journal.Lineage.LineageIdGeneratorEntry
 
getDefaultPort() - Method in enum alluxio.util.network.NetworkAddressUtils.ServiceType
Gets the default port number on service.
getDefaultSupplier() - Method in class alluxio.PropertyKey
 
getDefaultValue() - Method in class alluxio.PropertyKey
 
getDelay() - Method in class alluxio.util.executor.ControllableQueue.DelayNode
 
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;
getDeleteLineage() - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
optional .alluxio.proto.journal.DeleteLineageEntry delete_lineage = 7;
getDeleteLineage() - Method in class alluxio.proto.journal.Journal.JournalEntry
optional .alluxio.proto.journal.DeleteLineageEntry delete_lineage = 7;
getDeleteLineage() - Method in interface alluxio.proto.journal.Journal.JournalEntryOrBuilder
optional .alluxio.proto.journal.DeleteLineageEntry delete_lineage = 7;
getDeleteLineageBuilder() - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
optional .alluxio.proto.journal.DeleteLineageEntry delete_lineage = 7;
getDeleteLineageOrBuilder() - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
optional .alluxio.proto.journal.DeleteLineageEntry delete_lineage = 7;
getDeleteLineageOrBuilder() - Method in class alluxio.proto.journal.Journal.JournalEntry
optional .alluxio.proto.journal.DeleteLineageEntry delete_lineage = 7;
getDeleteLineageOrBuilder() - Method in interface alluxio.proto.journal.Journal.JournalEntryOrBuilder
optional .alluxio.proto.journal.DeleteLineageEntry delete_lineage = 7;
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;
getDeleteStore() - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
optional .alluxio.proto.journal.DeleteStoreEntry delete_store = 25;
getDeleteStore() - Method in class alluxio.proto.journal.Journal.JournalEntry
optional .alluxio.proto.journal.DeleteStoreEntry delete_store = 25;
getDeleteStore() - Method in interface alluxio.proto.journal.Journal.JournalEntryOrBuilder
optional .alluxio.proto.journal.DeleteStoreEntry delete_store = 25;
getDeleteStoreBuilder() - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
optional .alluxio.proto.journal.DeleteStoreEntry delete_store = 25;
getDeleteStoreOrBuilder() - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
optional .alluxio.proto.journal.DeleteStoreEntry delete_store = 25;
getDeleteStoreOrBuilder() - Method in class alluxio.proto.journal.Journal.JournalEntry
optional .alluxio.proto.journal.DeleteStoreEntry delete_store = 25;
getDeleteStoreOrBuilder() - Method in interface alluxio.proto.journal.Journal.JournalEntryOrBuilder
optional .alluxio.proto.journal.DeleteStoreEntry delete_store = 25;
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.keyvalue.DefaultKeyValueMaster
 
getDependencies() - Method in class alluxio.master.lineage.DefaultLineageMaster
 
getDependencies() - Method in class alluxio.master.meta.DefaultMetaMaster
 
getDependencies() - Method in class alluxio.master.NoopMaster
 
getDependencies() - Method in interface alluxio.Server
 
getDependencies() - Method in class alluxio.worker.block.DefaultBlockWorker
 
getDependencies() - Method in class alluxio.worker.file.DefaultFileSystemWorker
 
getDependencies() - Method in class alluxio.worker.keyvalue.KeyValueWorker
 
getDepth() - Method in class alluxio.AlluxioURI
Returns the number of elements of the path component of the AlluxioURI.
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.CreateLineageCommand
 
getDescription() - Method in class alluxio.cli.fs.command.DeleteLineageCommand
 
getDescription() - Method in class alluxio.cli.fs.command.DuCommand
 
getDescription() - Method in class alluxio.cli.fs.command.FileInfoCommand
Deprecated.
 
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.GetUsedBytesCommand
 
getDescription() - Method in class alluxio.cli.fs.command.HeadCommand
 
getDescription() - Method in class alluxio.cli.fs.command.HelpCommand
 
getDescription() - Method in class alluxio.cli.fs.command.LeaderCommand
 
getDescription() - Method in class alluxio.cli.fs.command.ListLineagesCommand
 
getDescription() - Method in class alluxio.cli.fs.command.LoadCommand
 
getDescription() - Method in class alluxio.cli.fs.command.LoadMetadataCommand
Deprecated.
 
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.ReportCommand
 
getDescription() - Method in class alluxio.cli.fs.command.RmCommand
 
getDescription() - Method in class alluxio.cli.fs.command.SetTtlCommand
 
getDescription() - Method in class alluxio.cli.fs.command.StatCommand
 
getDescription() - Method in class alluxio.cli.fs.command.TailCommand
 
getDescription() - Method in class alluxio.cli.fs.command.TestCommand
 
getDescription() - Method in class alluxio.cli.fs.command.TouchCommand
 
getDescription() - Method in class alluxio.cli.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.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.ReportCommand
 
getDescription() - Method in class alluxio.cli.fsadmin.command.UfsCommand
 
getDescription() - Method in class alluxio.DefaultSupplier
 
getDescription() - Method in class alluxio.PropertyKey
 
getDescription() - Method in class alluxio.proxy.s3.S3ErrorCode
 
getDescriptor() - Static method in class alluxio.proto.dataserver.Protocol.AsyncCacheRequest.Builder
 
getDescriptor() - Static method in class alluxio.proto.dataserver.Protocol.AsyncCacheRequest
 
getDescriptor() - Static method in class alluxio.proto.dataserver.Protocol.CreateUfsFileOptions.Builder
 
getDescriptor() - Static method in class alluxio.proto.dataserver.Protocol.CreateUfsFileOptions
 
getDescriptor() - Static method in class alluxio.proto.dataserver.Protocol
 
getDescriptor() - Static method in class alluxio.proto.dataserver.Protocol.Heartbeat.Builder
 
getDescriptor() - Static method in class alluxio.proto.dataserver.Protocol.Heartbeat
 
getDescriptor() - Static method in class alluxio.proto.dataserver.Protocol.LocalBlockCloseRequest.Builder
 
getDescriptor() - Static method in class alluxio.proto.dataserver.Protocol.LocalBlockCloseRequest
 
getDescriptor() - Static method in class alluxio.proto.dataserver.Protocol.LocalBlockCompleteRequest.Builder
 
getDescriptor() - Static method in class alluxio.proto.dataserver.Protocol.LocalBlockCompleteRequest
 
getDescriptor() - Static method in class alluxio.proto.dataserver.Protocol.LocalBlockCreateRequest.Builder
 
getDescriptor() - Static method in class alluxio.proto.dataserver.Protocol.LocalBlockCreateRequest
 
getDescriptor() - Static method in class alluxio.proto.dataserver.Protocol.LocalBlockCreateResponse.Builder
 
getDescriptor() - Static method in class alluxio.proto.dataserver.Protocol.LocalBlockCreateResponse
 
getDescriptor() - Static method in class alluxio.proto.dataserver.Protocol.LocalBlockOpenRequest.Builder
 
getDescriptor() - Static method in class alluxio.proto.dataserver.Protocol.LocalBlockOpenRequest
 
getDescriptor() - Static method in class alluxio.proto.dataserver.Protocol.LocalBlockOpenResponse.Builder
 
getDescriptor() - Static method in class alluxio.proto.dataserver.Protocol.LocalBlockOpenResponse
 
getDescriptor() - Static method in class alluxio.proto.dataserver.Protocol.OpenUfsBlockOptions.Builder
 
getDescriptor() - Static method in class alluxio.proto.dataserver.Protocol.OpenUfsBlockOptions
 
getDescriptor() - Static method in class alluxio.proto.dataserver.Protocol.ReadRequest.Builder
 
getDescriptor() - Static method in class alluxio.proto.dataserver.Protocol.ReadRequest
 
getDescriptor() - Static method in class alluxio.proto.dataserver.Protocol.ReadResponse.Builder
 
getDescriptor() - Static method in class alluxio.proto.dataserver.Protocol.ReadResponse
 
getDescriptor() - Static method in enum alluxio.proto.dataserver.Protocol.ReadResponse.Type
 
getDescriptor() - Static method in enum alluxio.proto.dataserver.Protocol.RequestType
 
getDescriptor() - Static method in class alluxio.proto.dataserver.Protocol.Response.Builder
 
getDescriptor() - Static method in class alluxio.proto.dataserver.Protocol.Response
 
getDescriptor() - Static method in class alluxio.proto.dataserver.Protocol.WriteRequest.Builder
 
getDescriptor() - Static method in class alluxio.proto.dataserver.Protocol.WriteRequest
 
getDescriptor() - Static method in class alluxio.proto.journal.Block.BlockContainerIdGeneratorEntry.Builder
 
getDescriptor() - Static method in class alluxio.proto.journal.Block.BlockContainerIdGeneratorEntry
 
getDescriptor() - Static method in class alluxio.proto.journal.Block.BlockInfoEntry.Builder
 
getDescriptor() - Static method in class alluxio.proto.journal.Block.BlockInfoEntry
 
getDescriptor() - Static method in class alluxio.proto.journal.Block.DeleteBlockEntry.Builder
 
getDescriptor() - Static method in class alluxio.proto.journal.Block.DeleteBlockEntry
 
getDescriptor() - Static method in class alluxio.proto.journal.Block
 
getDescriptor() - Static method in class alluxio.proto.journal.File.AddMountPointEntry.Builder
 
getDescriptor() - Static method in class alluxio.proto.journal.File.AddMountPointEntry
 
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.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.PTtlAction
 
getDescriptor() - Static method in class alluxio.proto.journal.File.ReinitializeFileEntry.Builder
 
getDescriptor() - Static method in class alluxio.proto.journal.File.ReinitializeFileEntry
 
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.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.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.KeyValue.CompletePartitionEntry.Builder
 
getDescriptor() - Static method in class alluxio.proto.journal.KeyValue.CompletePartitionEntry
 
getDescriptor() - Static method in class alluxio.proto.journal.KeyValue.CompleteStoreEntry.Builder
 
getDescriptor() - Static method in class alluxio.proto.journal.KeyValue.CompleteStoreEntry
 
getDescriptor() - Static method in class alluxio.proto.journal.KeyValue.CreateStoreEntry.Builder
 
getDescriptor() - Static method in class alluxio.proto.journal.KeyValue.CreateStoreEntry
 
getDescriptor() - Static method in class alluxio.proto.journal.KeyValue.DeleteStoreEntry.Builder
 
getDescriptor() - Static method in class alluxio.proto.journal.KeyValue.DeleteStoreEntry
 
getDescriptor() - Static method in class alluxio.proto.journal.KeyValue
 
getDescriptor() - Static method in class alluxio.proto.journal.KeyValue.MergeStoreEntry.Builder
 
getDescriptor() - Static method in class alluxio.proto.journal.KeyValue.MergeStoreEntry
 
getDescriptor() - Static method in class alluxio.proto.journal.KeyValue.RenameStoreEntry.Builder
 
getDescriptor() - Static method in class alluxio.proto.journal.KeyValue.RenameStoreEntry
 
getDescriptor() - Static method in class alluxio.proto.journal.Lineage.DeleteLineageEntry.Builder
 
getDescriptor() - Static method in class alluxio.proto.journal.Lineage.DeleteLineageEntry
 
getDescriptor() - Static method in class alluxio.proto.journal.Lineage
 
getDescriptor() - Static method in class alluxio.proto.journal.Lineage.LineageEntry.Builder
 
getDescriptor() - Static method in class alluxio.proto.journal.Lineage.LineageEntry
 
getDescriptor() - Static method in class alluxio.proto.journal.Lineage.LineageIdGeneratorEntry.Builder
 
getDescriptor() - Static method in class alluxio.proto.journal.Lineage.LineageIdGeneratorEntry
 
getDescriptor() - Static method in class alluxio.proto.status.Status
 
getDescriptor() - Static method in enum alluxio.proto.status.Status.PStatus
 
getDescriptorForType() - Method in class alluxio.proto.dataserver.Protocol.AsyncCacheRequest.Builder
 
getDescriptorForType() - Method in class alluxio.proto.dataserver.Protocol.CreateUfsFileOptions.Builder
 
getDescriptorForType() - Method in class alluxio.proto.dataserver.Protocol.Heartbeat.Builder
 
getDescriptorForType() - Method in class alluxio.proto.dataserver.Protocol.LocalBlockCloseRequest.Builder
 
getDescriptorForType() - Method in class alluxio.proto.dataserver.Protocol.LocalBlockCompleteRequest.Builder
 
getDescriptorForType() - Method in class alluxio.proto.dataserver.Protocol.LocalBlockCreateRequest.Builder
 
getDescriptorForType() - Method in class alluxio.proto.dataserver.Protocol.LocalBlockCreateResponse.Builder
 
getDescriptorForType() - Method in class alluxio.proto.dataserver.Protocol.LocalBlockOpenRequest.Builder
 
getDescriptorForType() - Method in class alluxio.proto.dataserver.Protocol.LocalBlockOpenResponse.Builder
 
getDescriptorForType() - Method in class alluxio.proto.dataserver.Protocol.OpenUfsBlockOptions.Builder
 
getDescriptorForType() - Method in class alluxio.proto.dataserver.Protocol.ReadRequest.Builder
 
getDescriptorForType() - Method in class alluxio.proto.dataserver.Protocol.ReadResponse.Builder
 
getDescriptorForType() - Method in enum alluxio.proto.dataserver.Protocol.ReadResponse.Type
 
getDescriptorForType() - Method in enum alluxio.proto.dataserver.Protocol.RequestType
 
getDescriptorForType() - Method in class alluxio.proto.dataserver.Protocol.Response.Builder
 
getDescriptorForType() - Method in class alluxio.proto.dataserver.Protocol.WriteRequest.Builder
 
getDescriptorForType() - Method in class alluxio.proto.journal.Block.BlockContainerIdGeneratorEntry.Builder
 
getDescriptorForType() - Method in class alluxio.proto.journal.Block.BlockInfoEntry.Builder
 
getDescriptorForType() - Method in class alluxio.proto.journal.Block.DeleteBlockEntry.Builder
 
getDescriptorForType() - Method in class alluxio.proto.journal.File.AddMountPointEntry.Builder
 
getDescriptorForType() - Method in class alluxio.proto.journal.File.AsyncPersistRequestEntry.Builder
 
getDescriptorForType() - Method in class alluxio.proto.journal.File.CompleteFileEntry.Builder
 
getDescriptorForType() - Method in class alluxio.proto.journal.File.DeleteFileEntry.Builder
 
getDescriptorForType() - Method in class alluxio.proto.journal.File.DeleteMountPointEntry.Builder
 
getDescriptorForType() - Method in class alluxio.proto.journal.File.InodeDirectoryEntry.Builder
 
getDescriptorForType() - Method in class alluxio.proto.journal.File.InodeDirectoryIdGeneratorEntry.Builder
 
getDescriptorForType() - Method in class alluxio.proto.journal.File.InodeFileEntry.Builder
 
getDescriptorForType() - Method in class alluxio.proto.journal.File.InodeLastModificationTimeEntry.Builder
 
getDescriptorForType() - Method in class alluxio.proto.journal.File.PersistDirectoryEntry.Builder
 
getDescriptorForType() - Method in class alluxio.proto.journal.File.PersistFileEntry.Builder
 
getDescriptorForType() - Method in enum alluxio.proto.journal.File.PTtlAction
 
getDescriptorForType() - Method in class alluxio.proto.journal.File.ReinitializeFileEntry.Builder
 
getDescriptorForType() - Method in class alluxio.proto.journal.File.RenameEntry.Builder
 
getDescriptorForType() - Method in class alluxio.proto.journal.File.SetAttributeEntry.Builder
 
getDescriptorForType() - Method in class alluxio.proto.journal.File.StringPairEntry.Builder
 
getDescriptorForType() - Method in enum alluxio.proto.journal.File.UfsMode
 
getDescriptorForType() - Method in class alluxio.proto.journal.File.UpdateUfsModeEntry.Builder
 
getDescriptorForType() - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
 
getDescriptorForType() - Method in class alluxio.proto.journal.KeyValue.CompletePartitionEntry.Builder
 
getDescriptorForType() - Method in class alluxio.proto.journal.KeyValue.CompleteStoreEntry.Builder
 
getDescriptorForType() - Method in class alluxio.proto.journal.KeyValue.CreateStoreEntry.Builder
 
getDescriptorForType() - Method in class alluxio.proto.journal.KeyValue.DeleteStoreEntry.Builder
 
getDescriptorForType() - Method in class alluxio.proto.journal.KeyValue.MergeStoreEntry.Builder
 
getDescriptorForType() - Method in class alluxio.proto.journal.KeyValue.RenameStoreEntry.Builder
 
getDescriptorForType() - Method in class alluxio.proto.journal.Lineage.DeleteLineageEntry.Builder
 
getDescriptorForType() - Method in class alluxio.proto.journal.Lineage.LineageEntry.Builder
 
getDescriptorForType() - Method in class alluxio.proto.journal.Lineage.LineageIdGeneratorEntry.Builder
 
getDescriptorForType() - Method in enum alluxio.proto.status.Status.PStatus
 
getDeterministicHashPolicyNumShards() - Method in class alluxio.client.block.policy.options.CreateOptions
 
getDeviceSpec() - Method in class alluxio.util.UnixMountInfo
 
getDir(BlockStoreLocation) - Method in class alluxio.worker.block.BlockMetadataManager
Gets the StorageDir given its location in the store.
getDir(int) - Method in class alluxio.worker.block.meta.StorageTier
Returns a directory for the given index.
getDirectChildrenLoaded() - Method in class alluxio.proto.journal.File.InodeDirectoryEntry.Builder
optional bool direct_children_loaded = 12;
getDirectChildrenLoaded() - Method in class alluxio.proto.journal.File.InodeDirectoryEntry
optional bool direct_children_loaded = 12;
getDirectChildrenLoaded() - Method in interface alluxio.proto.journal.File.InodeDirectoryEntryOrBuilder
optional bool direct_children_loaded = 12;
getDirectoryPathsOnTiers() - Method in class alluxio.worker.AlluxioWorkerRestServiceHandler
Deprecated.
since version 1.4 and will be removed in version 2.0
getDirectoryPathsOnTiers() - Method in interface alluxio.worker.block.BlockStoreMeta
 
getDirectoryPathsOnTiers() - Method in class alluxio.worker.block.DefaultBlockStoreMeta
 
getDirectoryStatus(String) - Method in class alluxio.underfs.hdfs.HdfsUnderFileSystem
 
getDirectoryStatus(String) - Method in class alluxio.underfs.local.LocalUnderFileSystem
 
getDirectoryStatus(String) - Method in class alluxio.underfs.ObjectUnderFileSystem
 
getDirectoryStatus(String) - Method in interface alluxio.underfs.UnderFileSystem
Gets the directory status.
getDirectoryStatus(String) - Method in class alluxio.underfs.UnderFileSystemWithLogging
 
getDirIndex() - Method in class alluxio.worker.block.meta.StorageDir
Returns the zero-based index of this dir in its parent StorageTier.
getDirPath() - Method in class alluxio.web.WebInterfaceWorkerGeneralServlet.UIStorageDir
 
getDirPath() - Method in class alluxio.worker.block.meta.StorageDir
 
getDirView(int) - Method in class alluxio.worker.block.meta.StorageTierView
Returns a directory view for the given index.
getDirViewIndex() - Method in class alluxio.worker.block.meta.StorageDirView
Gets the index of this Dir.
getDirViews() - Method in class alluxio.worker.block.meta.StorageTierView
 
getDirWithMaxFreeSpace(long, BlockStoreLocation, BlockMetadataManagerView) - Static method in class alluxio.worker.block.evictor.EvictorUtils
Gets StorageDirView with max free space.
getDisplayMountPointInfo(AlluxioURI) - Method in class alluxio.master.file.DefaultFileSystemMaster
 
getDisplayMountPointInfo(AlluxioURI) - Method in interface alluxio.master.file.FileSystemMaster
Gets the mount point information of an Alluxio path for display purpose.
getDisplayType() - Method in class alluxio.PropertyKey
 
getDomainSocketPath() - Method in class alluxio.thrift.WorkerNetAddress
 
getDomainSocketPath() - Method in class alluxio.wire.WorkerNetAddress
 
getDouble(PropertyKey) - Method in interface alluxio.AlluxioConfiguration
Gets the double representation of the value for the given key.
getDouble(PropertyKey) - Method in class alluxio.conf.InstancedConfiguration
 
getDouble(PropertyKey) - Static method in class alluxio.Configuration
Gets the double representation of the value for the given key.
getDoubleValue() - Method in class alluxio.thrift.MetricValue
 
getDoubleValue() - Method in class alluxio.wire.MetricValue
 
getDstLocation() - Method in class alluxio.worker.block.evictor.BlockTransferInfo
 
getDstPath() - Method in class alluxio.proto.journal.File.RenameEntry.Builder
optional string dst_path = 2;
getDstPath() - Method in class alluxio.proto.journal.File.RenameEntry
optional string dst_path = 2;
getDstPath() - Method in interface alluxio.proto.journal.File.RenameEntryOrBuilder
optional string dst_path = 2;
getDstPath() - Method in class alluxio.thrift.FileSystemMasterClientService.rename_args
the desination path of the file
getDstPathBytes() - Method in class alluxio.proto.journal.File.RenameEntry.Builder
optional string dst_path = 2;
getDstPathBytes() - Method in class alluxio.proto.journal.File.RenameEntry
optional string dst_path = 2;
getDstPathBytes() - Method in interface alluxio.proto.journal.File.RenameEntryOrBuilder
optional string dst_path = 2;
getDuration(PropertyKey) - Method in interface alluxio.AlluxioConfiguration
Gets the time of the key as a duration.
getDuration(PropertyKey) - Method in class alluxio.conf.InstancedConfiguration
 
getDuration(PropertyKey) - Static method in class alluxio.Configuration
Gets the time of the key as a duration.
getE() - Method in class alluxio.thrift.AlluxioService.getServiceVersion_result
 
getE() - Method in class alluxio.thrift.BlockMasterClientService.getBlockInfo_result
 
getE() - Method in class alluxio.thrift.BlockMasterClientService.getBlockMasterInfo_result
 
getE() - Method in class alluxio.thrift.BlockMasterClientService.getCapacityBytes_result
 
getE() - Method in class alluxio.thrift.BlockMasterClientService.getUsedBytes_result
 
getE() - Method in class alluxio.thrift.BlockMasterClientService.getWorkerInfoList_result
 
getE() - Method in class alluxio.thrift.BlockMasterClientService.getWorkerReport_result
 
getE() - Method in class alluxio.thrift.BlockMasterWorkerService.blockHeartbeat_result
 
getE() - Method in class alluxio.thrift.BlockMasterWorkerService.commitBlock_result
 
getE() - Method in class alluxio.thrift.BlockMasterWorkerService.getWorkerId_result
 
getE() - Method in class alluxio.thrift.BlockMasterWorkerService.registerWorker_result
 
getE() - Method in class alluxio.thrift.BlockWorkerClientService.accessBlock_result
 
getE() - Method in class alluxio.thrift.BlockWorkerClientService.cacheBlock_result
 
getE() - Method in class alluxio.thrift.BlockWorkerClientService.cancelBlock_result
 
getE() - Method in class alluxio.thrift.BlockWorkerClientService.lockBlock_result
 
getE() - Method in class alluxio.thrift.BlockWorkerClientService.promoteBlock_result
 
getE() - Method in class alluxio.thrift.BlockWorkerClientService.removeBlock_result
 
getE() - Method in class alluxio.thrift.BlockWorkerClientService.requestBlockLocation_result
 
getE() - Method in class alluxio.thrift.BlockWorkerClientService.requestSpace_result
 
getE() - Method in class alluxio.thrift.BlockWorkerClientService.sessionBlockHeartbeat_result
 
getE() - Method in class alluxio.thrift.BlockWorkerClientService.unlockBlock_result
 
getE() - Method in class alluxio.thrift.FileSystemMasterClientService.checkConsistency_result
 
getE() - Method in class alluxio.thrift.FileSystemMasterClientService.completeFile_result
 
getE() - Method in class alluxio.thrift.FileSystemMasterClientService.createDirectory_result
 
getE() - Method in class alluxio.thrift.FileSystemMasterClientService.createFile_result
 
getE() - Method in class alluxio.thrift.FileSystemMasterClientService.free_result
 
getE() - Method in class alluxio.thrift.FileSystemMasterClientService.getFilePath_result
 
getE() - Method in class alluxio.thrift.FileSystemMasterClientService.getMountTable_result
 
getE() - Method in class alluxio.thrift.FileSystemMasterClientService.getNewBlockIdForFile_result
 
getE() - Method in class alluxio.thrift.FileSystemMasterClientService.getStatus_result
 
getE() - Method in class alluxio.thrift.FileSystemMasterClientService.listStatus_result
 
getE() - Method in class alluxio.thrift.FileSystemMasterClientService.loadMetadata_result
 
getE() - Method in class alluxio.thrift.FileSystemMasterClientService.mount_result
 
getE() - Method in class alluxio.thrift.FileSystemMasterClientService.remove_result
 
getE() - Method in class alluxio.thrift.FileSystemMasterClientService.rename_result
 
getE() - Method in class alluxio.thrift.FileSystemMasterClientService.scheduleAsyncPersistence_result
 
getE() - Method in class alluxio.thrift.FileSystemMasterClientService.setAttribute_result
 
getE() - Method in class alluxio.thrift.FileSystemMasterClientService.unmount_result
 
getE() - Method in class alluxio.thrift.FileSystemMasterClientService.updateUfsMode_result
 
getE() - Method in class alluxio.thrift.FileSystemMasterWorkerService.fileSystemHeartbeat_result
 
getE() - Method in class alluxio.thrift.FileSystemMasterWorkerService.getFileInfo_result
 
getE() - Method in class alluxio.thrift.FileSystemMasterWorkerService.getPinnedFileIds_result
 
getE() - Method in class alluxio.thrift.FileSystemMasterWorkerService.getUfsInfo_result
 
getE() - Method in class alluxio.thrift.FileSystemWorkerClientService.cancelUfsFile_result
 
getE() - Method in class alluxio.thrift.FileSystemWorkerClientService.closeUfsFile_result
 
getE() - Method in class alluxio.thrift.FileSystemWorkerClientService.completeUfsFile_result
 
getE() - Method in class alluxio.thrift.FileSystemWorkerClientService.createUfsFile_result
 
getE() - Method in class alluxio.thrift.FileSystemWorkerClientService.openUfsFile_result
 
getE() - Method in class alluxio.thrift.FileSystemWorkerClientService.sessionFileSystemHeartbeat_result
 
getE() - Method in class alluxio.thrift.KeyValueMasterClientService.completePartition_result
 
getE() - Method in class alluxio.thrift.KeyValueMasterClientService.completeStore_result
 
getE() - Method in class alluxio.thrift.KeyValueMasterClientService.createStore_result
 
getE() - Method in class alluxio.thrift.KeyValueMasterClientService.deleteStore_result
 
getE() - Method in class alluxio.thrift.KeyValueMasterClientService.getPartitionInfo_result
 
getE() - Method in class alluxio.thrift.KeyValueMasterClientService.mergeStore_result
 
getE() - Method in class alluxio.thrift.KeyValueMasterClientService.renameStore_result
 
getE() - Method in class alluxio.thrift.KeyValueWorkerClientService.get_result
 
getE() - Method in class alluxio.thrift.KeyValueWorkerClientService.getNextKeys_result
 
getE() - Method in class alluxio.thrift.KeyValueWorkerClientService.getSize_result
 
getE() - Method in class alluxio.thrift.LineageMasterClientService.createLineage_result
 
getE() - Method in class alluxio.thrift.LineageMasterClientService.deleteLineage_result
 
getE() - Method in class alluxio.thrift.LineageMasterClientService.getLineageInfoList_result
 
getE() - Method in class alluxio.thrift.LineageMasterClientService.reinitializeFile_result
 
getE() - Method in class alluxio.thrift.LineageMasterClientService.reportLostFile_result
 
getE() - Method in class alluxio.thrift.MetaMasterClientService.backup_result
 
getE() - Method in class alluxio.thrift.MetaMasterClientService.getConfigReport_result
 
getE() - Method in class alluxio.thrift.MetaMasterClientService.getConfiguration_result
 
getE() - Method in class alluxio.thrift.MetaMasterClientService.getMasterInfo_result
 
getE() - Method in class alluxio.thrift.MetaMasterClientService.getMetrics_result
 
getE() - Method in class alluxio.thrift.MetaMasterMasterService.getMasterId_result
 
getE() - Method in class alluxio.thrift.MetaMasterMasterService.masterHeartbeat_result
 
getE() - Method in class alluxio.thrift.MetaMasterMasterService.registerMaster_result
 
getE() - Method in class alluxio.thrift.MetricsMasterClientService.metricsHeartbeat_result
 
getEligibleWorkers() - Method in class alluxio.client.block.AlluxioBlockStore
 
getEmptyArgsInstance() - Method in class alluxio.thrift.AlluxioService.AsyncProcessor.getServiceVersion
 
getEmptyArgsInstance() - Method in class alluxio.thrift.AlluxioService.Processor.getServiceVersion
 
getEmptyArgsInstance() - Method in class alluxio.thrift.BlockMasterClientService.AsyncProcessor.getBlockInfo
 
getEmptyArgsInstance() - Method in class alluxio.thrift.BlockMasterClientService.AsyncProcessor.getBlockMasterInfo
 
getEmptyArgsInstance() - Method in class alluxio.thrift.BlockMasterClientService.AsyncProcessor.getCapacityBytes
 
getEmptyArgsInstance() - Method in class alluxio.thrift.BlockMasterClientService.AsyncProcessor.getUsedBytes
 
getEmptyArgsInstance() - Method in class alluxio.thrift.BlockMasterClientService.AsyncProcessor.getWorkerInfoList
 
getEmptyArgsInstance() - Method in class alluxio.thrift.BlockMasterClientService.AsyncProcessor.getWorkerReport
 
getEmptyArgsInstance() - Method in class alluxio.thrift.BlockMasterClientService.Processor.getBlockInfo
 
getEmptyArgsInstance() - Method in class alluxio.thrift.BlockMasterClientService.Processor.getBlockMasterInfo
 
getEmptyArgsInstance() - Method in class alluxio.thrift.BlockMasterClientService.Processor.getCapacityBytes
 
getEmptyArgsInstance() - Method in class alluxio.thrift.BlockMasterClientService.Processor.getUsedBytes
 
getEmptyArgsInstance() - Method in class alluxio.thrift.BlockMasterClientService.Processor.getWorkerInfoList
 
getEmptyArgsInstance() - Method in class alluxio.thrift.BlockMasterClientService.Processor.getWorkerReport
 
getEmptyArgsInstance() - Method in class alluxio.thrift.BlockMasterWorkerService.AsyncProcessor.blockHeartbeat
 
getEmptyArgsInstance() - Method in class alluxio.thrift.BlockMasterWorkerService.AsyncProcessor.commitBlock
 
getEmptyArgsInstance() - Method in class alluxio.thrift.BlockMasterWorkerService.AsyncProcessor.getWorkerId
 
getEmptyArgsInstance() - Method in class alluxio.thrift.BlockMasterWorkerService.AsyncProcessor.registerWorker
 
getEmptyArgsInstance() - Method in class alluxio.thrift.BlockMasterWorkerService.Processor.blockHeartbeat
 
getEmptyArgsInstance() - Method in class alluxio.thrift.BlockMasterWorkerService.Processor.commitBlock
 
getEmptyArgsInstance() - Method in class alluxio.thrift.BlockMasterWorkerService.Processor.getWorkerId
 
getEmptyArgsInstance() - Method in class alluxio.thrift.BlockMasterWorkerService.Processor.registerWorker
 
getEmptyArgsInstance() - Method in class alluxio.thrift.BlockWorkerClientService.AsyncProcessor.accessBlock
 
getEmptyArgsInstance() - Method in class alluxio.thrift.BlockWorkerClientService.AsyncProcessor.cacheBlock
 
getEmptyArgsInstance() - Method in class alluxio.thrift.BlockWorkerClientService.AsyncProcessor.cancelBlock
 
getEmptyArgsInstance() - Method in class alluxio.thrift.BlockWorkerClientService.AsyncProcessor.lockBlock
 
getEmptyArgsInstance() - Method in class alluxio.thrift.BlockWorkerClientService.AsyncProcessor.promoteBlock
 
getEmptyArgsInstance() - Method in class alluxio.thrift.BlockWorkerClientService.AsyncProcessor.removeBlock
 
getEmptyArgsInstance() - Method in class alluxio.thrift.BlockWorkerClientService.AsyncProcessor.requestBlockLocation
 
getEmptyArgsInstance() - Method in class alluxio.thrift.BlockWorkerClientService.AsyncProcessor.requestSpace
 
getEmptyArgsInstance() - Method in class alluxio.thrift.BlockWorkerClientService.AsyncProcessor.sessionBlockHeartbeat
 
getEmptyArgsInstance() - Method in class alluxio.thrift.BlockWorkerClientService.AsyncProcessor.unlockBlock
 
getEmptyArgsInstance() - Method in class alluxio.thrift.BlockWorkerClientService.Processor.accessBlock
 
getEmptyArgsInstance() - Method in class alluxio.thrift.BlockWorkerClientService.Processor.cacheBlock
 
getEmptyArgsInstance() - Method in class alluxio.thrift.BlockWorkerClientService.Processor.cancelBlock
 
getEmptyArgsInstance() - Method in class alluxio.thrift.BlockWorkerClientService.Processor.lockBlock
 
getEmptyArgsInstance() - Method in class alluxio.thrift.BlockWorkerClientService.Processor.promoteBlock
 
getEmptyArgsInstance() - Method in class alluxio.thrift.BlockWorkerClientService.Processor.removeBlock
 
getEmptyArgsInstance() - Method in class alluxio.thrift.BlockWorkerClientService.Processor.requestBlockLocation
 
getEmptyArgsInstance() - Method in class alluxio.thrift.BlockWorkerClientService.Processor.requestSpace
 
getEmptyArgsInstance() - Method in class alluxio.thrift.BlockWorkerClientService.Processor.sessionBlockHeartbeat
 
getEmptyArgsInstance() - Method in class alluxio.thrift.BlockWorkerClientService.Processor.unlockBlock
 
getEmptyArgsInstance() - Method in class alluxio.thrift.FileSystemMasterClientService.AsyncProcessor.checkConsistency
 
getEmptyArgsInstance() - Method in class alluxio.thrift.FileSystemMasterClientService.AsyncProcessor.completeFile
 
getEmptyArgsInstance() - Method in class alluxio.thrift.FileSystemMasterClientService.AsyncProcessor.createDirectory
 
getEmptyArgsInstance() - Method in class alluxio.thrift.FileSystemMasterClientService.AsyncProcessor.createFile
 
getEmptyArgsInstance() - Method in class alluxio.thrift.FileSystemMasterClientService.AsyncProcessor.free
 
getEmptyArgsInstance() - Method in class alluxio.thrift.FileSystemMasterClientService.AsyncProcessor.getFilePath
 
getEmptyArgsInstance() - Method in class alluxio.thrift.FileSystemMasterClientService.AsyncProcessor.getMountTable
 
getEmptyArgsInstance() - Method in class alluxio.thrift.FileSystemMasterClientService.AsyncProcessor.getNewBlockIdForFile
 
getEmptyArgsInstance() - Method in class alluxio.thrift.FileSystemMasterClientService.AsyncProcessor.getStatus
 
getEmptyArgsInstance() - Method in class alluxio.thrift.FileSystemMasterClientService.AsyncProcessor.listStatus
 
getEmptyArgsInstance() - Method in class alluxio.thrift.FileSystemMasterClientService.AsyncProcessor.loadMetadata
 
getEmptyArgsInstance() - Method in class alluxio.thrift.FileSystemMasterClientService.AsyncProcessor.mount
 
getEmptyArgsInstance() - Method in class alluxio.thrift.FileSystemMasterClientService.AsyncProcessor.remove
 
getEmptyArgsInstance() - Method in class alluxio.thrift.FileSystemMasterClientService.AsyncProcessor.rename
 
getEmptyArgsInstance() - Method in class alluxio.thrift.FileSystemMasterClientService.AsyncProcessor.scheduleAsyncPersistence
 
getEmptyArgsInstance() - Method in class alluxio.thrift.FileSystemMasterClientService.AsyncProcessor.setAttribute
 
getEmptyArgsInstance() - Method in class alluxio.thrift.FileSystemMasterClientService.AsyncProcessor.unmount
 
getEmptyArgsInstance() - Method in class alluxio.thrift.FileSystemMasterClientService.AsyncProcessor.updateUfsMode
 
getEmptyArgsInstance() - Method in class alluxio.thrift.FileSystemMasterClientService.Processor.checkConsistency
 
getEmptyArgsInstance() - Method in class alluxio.thrift.FileSystemMasterClientService.Processor.completeFile
 
getEmptyArgsInstance() - Method in class alluxio.thrift.FileSystemMasterClientService.Processor.createDirectory
 
getEmptyArgsInstance() - Method in class alluxio.thrift.FileSystemMasterClientService.Processor.createFile
 
getEmptyArgsInstance() - Method in class alluxio.thrift.FileSystemMasterClientService.Processor.free
 
getEmptyArgsInstance() - Method in class alluxio.thrift.FileSystemMasterClientService.Processor.getFilePath
 
getEmptyArgsInstance() - Method in class alluxio.thrift.FileSystemMasterClientService.Processor.getMountTable
 
getEmptyArgsInstance() - Method in class alluxio.thrift.FileSystemMasterClientService.Processor.getNewBlockIdForFile
 
getEmptyArgsInstance() - Method in class alluxio.thrift.FileSystemMasterClientService.Processor.getStatus
 
getEmptyArgsInstance() - Method in class alluxio.thrift.FileSystemMasterClientService.Processor.listStatus
 
getEmptyArgsInstance() - Method in class alluxio.thrift.FileSystemMasterClientService.Processor.loadMetadata
 
getEmptyArgsInstance() - Method in class alluxio.thrift.FileSystemMasterClientService.Processor.mount
 
getEmptyArgsInstance() - Method in class alluxio.thrift.FileSystemMasterClientService.Processor.remove
 
getEmptyArgsInstance() - Method in class alluxio.thrift.FileSystemMasterClientService.Processor.rename
 
getEmptyArgsInstance() - Method in class alluxio.thrift.FileSystemMasterClientService.Processor.scheduleAsyncPersistence
 
getEmptyArgsInstance() - Method in class alluxio.thrift.FileSystemMasterClientService.Processor.setAttribute
 
getEmptyArgsInstance() - Method in class alluxio.thrift.FileSystemMasterClientService.Processor.unmount
 
getEmptyArgsInstance() - Method in class alluxio.thrift.FileSystemMasterClientService.Processor.updateUfsMode
 
getEmptyArgsInstance() - Method in class alluxio.thrift.FileSystemMasterWorkerService.AsyncProcessor.fileSystemHeartbeat
 
getEmptyArgsInstance() - Method in class alluxio.thrift.FileSystemMasterWorkerService.AsyncProcessor.getFileInfo
 
getEmptyArgsInstance() - Method in class alluxio.thrift.FileSystemMasterWorkerService.AsyncProcessor.getPinnedFileIds
 
getEmptyArgsInstance() - Method in class alluxio.thrift.FileSystemMasterWorkerService.AsyncProcessor.getUfsInfo
 
getEmptyArgsInstance() - Method in class alluxio.thrift.FileSystemMasterWorkerService.Processor.fileSystemHeartbeat
 
getEmptyArgsInstance() - Method in class alluxio.thrift.FileSystemMasterWorkerService.Processor.getFileInfo
 
getEmptyArgsInstance() - Method in class alluxio.thrift.FileSystemMasterWorkerService.Processor.getPinnedFileIds
 
getEmptyArgsInstance() - Method in class alluxio.thrift.FileSystemMasterWorkerService.Processor.getUfsInfo
 
getEmptyArgsInstance() - Method in class alluxio.thrift.FileSystemWorkerClientService.AsyncProcessor.cancelUfsFile
 
getEmptyArgsInstance() - Method in class alluxio.thrift.FileSystemWorkerClientService.AsyncProcessor.closeUfsFile
 
getEmptyArgsInstance() - Method in class alluxio.thrift.FileSystemWorkerClientService.AsyncProcessor.completeUfsFile
 
getEmptyArgsInstance() - Method in class alluxio.thrift.FileSystemWorkerClientService.AsyncProcessor.createUfsFile
 
getEmptyArgsInstance() - Method in class alluxio.thrift.FileSystemWorkerClientService.AsyncProcessor.openUfsFile
 
getEmptyArgsInstance() - Method in class alluxio.thrift.FileSystemWorkerClientService.AsyncProcessor.sessionFileSystemHeartbeat
 
getEmptyArgsInstance() - Method in class alluxio.thrift.FileSystemWorkerClientService.Processor.cancelUfsFile
 
getEmptyArgsInstance() - Method in class alluxio.thrift.FileSystemWorkerClientService.Processor.closeUfsFile
 
getEmptyArgsInstance() - Method in class alluxio.thrift.FileSystemWorkerClientService.Processor.completeUfsFile
 
getEmptyArgsInstance() - Method in class alluxio.thrift.FileSystemWorkerClientService.Processor.createUfsFile
 
getEmptyArgsInstance() - Method in class alluxio.thrift.FileSystemWorkerClientService.Processor.openUfsFile
 
getEmptyArgsInstance() - Method in class alluxio.thrift.FileSystemWorkerClientService.Processor.sessionFileSystemHeartbeat
 
getEmptyArgsInstance() - Method in class alluxio.thrift.KeyValueMasterClientService.AsyncProcessor.completePartition
 
getEmptyArgsInstance() - Method in class alluxio.thrift.KeyValueMasterClientService.AsyncProcessor.completeStore
 
getEmptyArgsInstance() - Method in class alluxio.thrift.KeyValueMasterClientService.AsyncProcessor.createStore
 
getEmptyArgsInstance() - Method in class alluxio.thrift.KeyValueMasterClientService.AsyncProcessor.deleteStore
 
getEmptyArgsInstance() - Method in class alluxio.thrift.KeyValueMasterClientService.AsyncProcessor.getPartitionInfo
 
getEmptyArgsInstance() - Method in class alluxio.thrift.KeyValueMasterClientService.AsyncProcessor.mergeStore
 
getEmptyArgsInstance() - Method in class alluxio.thrift.KeyValueMasterClientService.AsyncProcessor.renameStore
 
getEmptyArgsInstance() - Method in class alluxio.thrift.KeyValueMasterClientService.Processor.completePartition
 
getEmptyArgsInstance() - Method in class alluxio.thrift.KeyValueMasterClientService.Processor.completeStore
 
getEmptyArgsInstance() - Method in class alluxio.thrift.KeyValueMasterClientService.Processor.createStore
 
getEmptyArgsInstance() - Method in class alluxio.thrift.KeyValueMasterClientService.Processor.deleteStore
 
getEmptyArgsInstance() - Method in class alluxio.thrift.KeyValueMasterClientService.Processor.getPartitionInfo
 
getEmptyArgsInstance() - Method in class alluxio.thrift.KeyValueMasterClientService.Processor.mergeStore
 
getEmptyArgsInstance() - Method in class alluxio.thrift.KeyValueMasterClientService.Processor.renameStore
 
getEmptyArgsInstance() - Method in class alluxio.thrift.KeyValueWorkerClientService.AsyncProcessor.get
 
getEmptyArgsInstance() - Method in class alluxio.thrift.KeyValueWorkerClientService.AsyncProcessor.getNextKeys
 
getEmptyArgsInstance() - Method in class alluxio.thrift.KeyValueWorkerClientService.AsyncProcessor.getSize
 
getEmptyArgsInstance() - Method in class alluxio.thrift.KeyValueWorkerClientService.Processor.get
 
getEmptyArgsInstance() - Method in class alluxio.thrift.KeyValueWorkerClientService.Processor.getNextKeys
 
getEmptyArgsInstance() - Method in class alluxio.thrift.KeyValueWorkerClientService.Processor.getSize
 
getEmptyArgsInstance() - Method in class alluxio.thrift.LineageMasterClientService.AsyncProcessor.createLineage
 
getEmptyArgsInstance() - Method in class alluxio.thrift.LineageMasterClientService.AsyncProcessor.deleteLineage
 
getEmptyArgsInstance() - Method in class alluxio.thrift.LineageMasterClientService.AsyncProcessor.getLineageInfoList
 
getEmptyArgsInstance() - Method in class alluxio.thrift.LineageMasterClientService.AsyncProcessor.reinitializeFile
 
getEmptyArgsInstance() - Method in class alluxio.thrift.LineageMasterClientService.AsyncProcessor.reportLostFile
 
getEmptyArgsInstance() - Method in class alluxio.thrift.LineageMasterClientService.Processor.createLineage
 
getEmptyArgsInstance() - Method in class alluxio.thrift.LineageMasterClientService.Processor.deleteLineage
 
getEmptyArgsInstance() - Method in class alluxio.thrift.LineageMasterClientService.Processor.getLineageInfoList
 
getEmptyArgsInstance() - Method in class alluxio.thrift.LineageMasterClientService.Processor.reinitializeFile
 
getEmptyArgsInstance() - Method in class alluxio.thrift.LineageMasterClientService.Processor.reportLostFile
 
getEmptyArgsInstance() - Method in class alluxio.thrift.MetaMasterClientService.AsyncProcessor.backup
 
getEmptyArgsInstance() - Method in class alluxio.thrift.MetaMasterClientService.AsyncProcessor.getConfigReport
 
getEmptyArgsInstance() - Method in class alluxio.thrift.MetaMasterClientService.AsyncProcessor.getConfiguration
 
getEmptyArgsInstance() - Method in class alluxio.thrift.MetaMasterClientService.AsyncProcessor.getMasterInfo
 
getEmptyArgsInstance() - Method in class alluxio.thrift.MetaMasterClientService.AsyncProcessor.getMetrics
 
getEmptyArgsInstance() - Method in class alluxio.thrift.MetaMasterClientService.Processor.backup
 
getEmptyArgsInstance() - Method in class alluxio.thrift.MetaMasterClientService.Processor.getConfigReport
 
getEmptyArgsInstance() - Method in class alluxio.thrift.MetaMasterClientService.Processor.getConfiguration
 
getEmptyArgsInstance() - Method in class alluxio.thrift.MetaMasterClientService.Processor.getMasterInfo
 
getEmptyArgsInstance() - Method in class alluxio.thrift.MetaMasterClientService.Processor.getMetrics
 
getEmptyArgsInstance() - Method in class alluxio.thrift.MetaMasterMasterService.AsyncProcessor.getMasterId
 
getEmptyArgsInstance() - Method in class alluxio.thrift.MetaMasterMasterService.AsyncProcessor.masterHeartbeat
 
getEmptyArgsInstance() - Method in class alluxio.thrift.MetaMasterMasterService.AsyncProcessor.registerMaster
 
getEmptyArgsInstance() - Method in class alluxio.thrift.MetaMasterMasterService.Processor.getMasterId
 
getEmptyArgsInstance() - Method in class alluxio.thrift.MetaMasterMasterService.Processor.masterHeartbeat
 
getEmptyArgsInstance() - Method in class alluxio.thrift.MetaMasterMasterService.Processor.registerMaster
 
getEmptyArgsInstance() - Method in class alluxio.thrift.MetricsMasterClientService.AsyncProcessor.metricsHeartbeat
 
getEmptyArgsInstance() - Method in class alluxio.thrift.MetricsMasterClientService.Processor.metricsHeartbeat
 
getEncodedLength() - Method in interface alluxio.network.protocol.EncodedMessage
Returns the number bytes for the message when it is encoded.
getEncodedLength() - Method in enum alluxio.network.protocol.RPCMessage.Type
 
getEncodedLength() - Method in class alluxio.network.protocol.RPCProtoMessage
 
getEntryCount() - Method in class alluxio.thrift.BackupTResponse
 
getEntryCount() - Method in class alluxio.wire.BackupResponse
 
getEnum(PropertyKey, Class<T>) - Method in interface alluxio.AlluxioConfiguration
Gets the value for the given key as an enum value.
getEnum(PropertyKey, Class<T>) - Method in class alluxio.conf.InstancedConfiguration
 
getEnum(PropertyKey, Class<T>) - Static method in class alluxio.Configuration
Gets the value for the given key as an enum value.
getEof() - Method in class alluxio.proto.dataserver.Protocol.WriteRequest.Builder
optional bool eof = 5;
getEof() - Method in class alluxio.proto.dataserver.Protocol.WriteRequest
optional bool eof = 5;
getEof() - Method in interface alluxio.proto.dataserver.Protocol.WriteRequestOrBuilder
optional bool eof = 5;
getError() - Method in class alluxio.worker.netty.ReadRequestContext
 
getError() - Method in class alluxio.worker.netty.WriteRequestContext
 
getErrorCode() - Method in exception alluxio.proxy.s3.S3Exception
 
getErrors() - Method in class alluxio.thrift.ConfigCheckReport
 
getErrorsSize() - Method in class alluxio.thrift.ConfigCheckReport
 
getETag() - Method in class alluxio.proxy.s3.CompleteMultipartUploadResult
 
getETag() - Method in class alluxio.proxy.s3.ListBucketResult.Content
 
getETag() - Method in class alluxio.proxy.s3.ListPartsResult.Part
 
getEvictableBlocks() - Method in class alluxio.worker.block.meta.StorageDirView
Gets a filtered list of block metadata, for blocks that are neither pinned or being blocked.
getEvitableBytes() - Method in class alluxio.worker.block.meta.StorageDirView
Gets evictable bytes for this dir, i.e., the total bytes of total evictable blocks.
getExecutorService() - Method in class alluxio.master.AbstractMaster
 
getExecutorService() - Method in class alluxio.worker.AbstractWorker
 
getExitCode() - Method in exception alluxio.util.ShellUtils.ExitCodeException
Gets the exit code.
getExpiredBuckets(long) - Method in class alluxio.master.file.meta.TtlBucketList
Retrieves buckets whose ttl interval has expired before the specified time, that is, the bucket's interval start time should be less than or equal to (specified time - ttl interval).
getFieldDesc(FileSystemCommandOptions._Fields) - Method in class alluxio.thrift.FileSystemCommandOptions
 
getFieldName() - Method in enum alluxio.thrift.AccessBlockTOptions._Fields
 
getFieldName() - Method in enum alluxio.thrift.AccessBlockTResponse._Fields
 
getFieldName() - Method in enum alluxio.thrift.AlluxioService.getServiceVersion_args._Fields
 
getFieldName() - Method in enum alluxio.thrift.AlluxioService.getServiceVersion_result._Fields
 
getFieldName() - Method in enum alluxio.thrift.AlluxioTException._Fields
 
getFieldName() - Method in enum alluxio.thrift.BackupTOptions._Fields
 
getFieldName() - Method in enum alluxio.thrift.BackupTResponse._Fields
 
getFieldName() - Method in enum alluxio.thrift.BlockHeartbeatTOptions._Fields
 
getFieldName() - Method in enum alluxio.thrift.BlockHeartbeatTResponse._Fields
 
getFieldName() - Method in enum alluxio.thrift.BlockInfo._Fields
 
getFieldName() - Method in enum alluxio.thrift.BlockLocation._Fields
 
getFieldName() - Method in enum alluxio.thrift.BlockMasterClientService.getBlockInfo_args._Fields
 
getFieldName() - Method in enum alluxio.thrift.BlockMasterClientService.getBlockInfo_result._Fields
 
getFieldName() - Method in enum alluxio.thrift.BlockMasterClientService.getBlockMasterInfo_args._Fields
 
getFieldName() - Method in enum alluxio.thrift.BlockMasterClientService.getBlockMasterInfo_result._Fields
 
getFieldName() - Method in enum alluxio.thrift.BlockMasterClientService.getCapacityBytes_args._Fields
 
getFieldName() - Method in enum alluxio.thrift.BlockMasterClientService.getCapacityBytes_result._Fields
 
getFieldName() - Method in enum alluxio.thrift.BlockMasterClientService.getUsedBytes_args._Fields
 
getFieldName() - Method in enum alluxio.thrift.BlockMasterClientService.getUsedBytes_result._Fields
 
getFieldName() - Method in enum alluxio.thrift.BlockMasterClientService.getWorkerInfoList_args._Fields
 
getFieldName() - Method in enum alluxio.thrift.BlockMasterClientService.getWorkerInfoList_result._Fields
 
getFieldName() - Method in enum alluxio.thrift.BlockMasterClientService.getWorkerReport_args._Fields
 
getFieldName() - Method in enum alluxio.thrift.BlockMasterClientService.getWorkerReport_result._Fields
 
getFieldName() - Method in enum alluxio.thrift.BlockMasterInfo._Fields
 
getFieldName() - Method in enum alluxio.thrift.BlockMasterWorkerService.blockHeartbeat_args._Fields
 
getFieldName() - Method in enum alluxio.thrift.BlockMasterWorkerService.blockHeartbeat_result._Fields
 
getFieldName() - Method in enum alluxio.thrift.BlockMasterWorkerService.commitBlock_args._Fields
 
getFieldName() - Method in enum alluxio.thrift.BlockMasterWorkerService.commitBlock_result._Fields
 
getFieldName() - Method in enum alluxio.thrift.BlockMasterWorkerService.getWorkerId_args._Fields
 
getFieldName() - Method in enum alluxio.thrift.BlockMasterWorkerService.getWorkerId_result._Fields
 
getFieldName() - Method in enum alluxio.thrift.BlockMasterWorkerService.registerWorker_args._Fields
 
getFieldName() - Method in enum alluxio.thrift.BlockMasterWorkerService.registerWorker_result._Fields
 
getFieldName() - Method in enum alluxio.thrift.BlockWorkerClientService.accessBlock_args._Fields
 
getFieldName() - Method in enum alluxio.thrift.BlockWorkerClientService.accessBlock_result._Fields
 
getFieldName() - Method in enum alluxio.thrift.BlockWorkerClientService.cacheBlock_args._Fields
 
getFieldName() - Method in enum alluxio.thrift.BlockWorkerClientService.cacheBlock_result._Fields
 
getFieldName() - Method in enum alluxio.thrift.BlockWorkerClientService.cancelBlock_args._Fields
 
getFieldName() - Method in enum alluxio.thrift.BlockWorkerClientService.cancelBlock_result._Fields
 
getFieldName() - Method in enum alluxio.thrift.BlockWorkerClientService.lockBlock_args._Fields
 
getFieldName() - Method in enum alluxio.thrift.BlockWorkerClientService.lockBlock_result._Fields
 
getFieldName() - Method in enum alluxio.thrift.BlockWorkerClientService.promoteBlock_args._Fields
 
getFieldName() - Method in enum alluxio.thrift.BlockWorkerClientService.promoteBlock_result._Fields
 
getFieldName() - Method in enum alluxio.thrift.BlockWorkerClientService.removeBlock_args._Fields
 
getFieldName() - Method in enum alluxio.thrift.BlockWorkerClientService.removeBlock_result._Fields
 
getFieldName() - Method in enum alluxio.thrift.BlockWorkerClientService.requestBlockLocation_args._Fields
 
getFieldName() - Method in enum alluxio.thrift.BlockWorkerClientService.requestBlockLocation_result._Fields
 
getFieldName() - Method in enum alluxio.thrift.BlockWorkerClientService.requestSpace_args._Fields
 
getFieldName() - Method in enum alluxio.thrift.BlockWorkerClientService.requestSpace_result._Fields
 
getFieldName() - Method in enum alluxio.thrift.BlockWorkerClientService.sessionBlockHeartbeat_args._Fields
 
getFieldName() - Method in enum alluxio.thrift.BlockWorkerClientService.sessionBlockHeartbeat_result._Fields
 
getFieldName() - Method in enum alluxio.thrift.BlockWorkerClientService.unlockBlock_args._Fields
 
getFieldName() - Method in enum alluxio.thrift.BlockWorkerClientService.unlockBlock_result._Fields
 
getFieldName() - Method in enum alluxio.thrift.CacheBlockTOptions._Fields
 
getFieldName() - Method in enum alluxio.thrift.CacheBlockTResponse._Fields
 
getFieldName() - Method in enum alluxio.thrift.CancelBlockTOptions._Fields
 
getFieldName() - Method in enum alluxio.thrift.CancelBlockTResponse._Fields
 
getFieldName() - Method in enum alluxio.thrift.CancelUfsFileTOptions._Fields
 
getFieldName() - Method in enum alluxio.thrift.CancelUfsFileTResponse._Fields
 
getFieldName() - Method in enum alluxio.thrift.CheckConsistencyTOptions._Fields
 
getFieldName() - Method in enum alluxio.thrift.CheckConsistencyTResponse._Fields
 
getFieldName() - Method in enum alluxio.thrift.CloseUfsFileTOptions._Fields
 
getFieldName() - Method in enum alluxio.thrift.CloseUfsFileTResponse._Fields
 
getFieldName() - Method in enum alluxio.thrift.Command._Fields
 
getFieldName() - Method in enum alluxio.thrift.CommandLineJobInfo._Fields
 
getFieldName() - Method in enum alluxio.thrift.CommitBlockTOptions._Fields
 
getFieldName() - Method in enum alluxio.thrift.CommitBlockTResponse._Fields
 
getFieldName() - Method in enum alluxio.thrift.CompleteFileTOptions._Fields
 
getFieldName() - Method in enum alluxio.thrift.CompleteFileTResponse._Fields
 
getFieldName() - Method in enum alluxio.thrift.CompletePartitionTOptions._Fields
 
getFieldName() - Method in enum alluxio.thrift.CompletePartitionTResponse._Fields
 
getFieldName() - Method in enum alluxio.thrift.CompleteStoreTOptions._Fields
 
getFieldName() - Method in enum alluxio.thrift.CompleteStoreTResponse._Fields
 
getFieldName() - Method in enum alluxio.thrift.CompleteUfsFileTOptions._Fields
 
getFieldName() - Method in enum alluxio.thrift.CompleteUfsFileTReponse._Fields
 
getFieldName() - Method in enum alluxio.thrift.ConfigCheckReport._Fields
 
getFieldName() - Method in enum alluxio.thrift.ConfigProperty._Fields
 
getFieldName() - Method in enum alluxio.thrift.CreateDirectoryTOptions._Fields
 
getFieldName() - Method in enum alluxio.thrift.CreateDirectoryTResponse._Fields
 
getFieldName() - Method in enum alluxio.thrift.CreateFileTOptions._Fields
 
getFieldName() - Method in enum alluxio.thrift.CreateFileTResponse._Fields
 
getFieldName() - Method in enum alluxio.thrift.CreateLineageTOptions._Fields
 
getFieldName() - Method in enum alluxio.thrift.CreateLineageTResponse._Fields
 
getFieldName() - Method in enum alluxio.thrift.CreateStoreTOptions._Fields
 
getFieldName() - Method in enum alluxio.thrift.CreateStoreTResponse._Fields
 
getFieldName() - Method in enum alluxio.thrift.CreateUfsFileTOptions._Fields
 
getFieldName() - Method in enum alluxio.thrift.CreateUfsFileTResponse._Fields
 
getFieldName() - Method in enum alluxio.thrift.DeleteLineageTOptions._Fields
 
getFieldName() - Method in enum alluxio.thrift.DeleteLineageTResponse._Fields
 
getFieldName() - Method in enum alluxio.thrift.DeleteStoreTOptions._Fields
 
getFieldName() - Method in enum alluxio.thrift.DeleteStoreTResponse._Fields
 
getFieldName() - Method in enum alluxio.thrift.DeleteTOptions._Fields
 
getFieldName() - Method in enum alluxio.thrift.DeleteTResponse._Fields
 
getFieldName() - Method in enum alluxio.thrift.DependencyInfo._Fields
 
getFieldName() - Method in enum alluxio.thrift.FileBlockInfo._Fields
 
getFieldName() - Method in enum alluxio.thrift.FileInfo._Fields
 
getFieldName() - Method in enum alluxio.thrift.FileSystemCommand._Fields
 
getFieldName() - Method in enum alluxio.thrift.FileSystemCommandOptions._Fields
 
getFieldName() - Method in enum alluxio.thrift.FileSystemHeartbeatTOptions._Fields
 
getFieldName() - Method in enum alluxio.thrift.FileSystemHeartbeatTResponse._Fields
 
getFieldName() - Method in enum alluxio.thrift.FileSystemMasterClientService.checkConsistency_args._Fields
 
getFieldName() - Method in enum alluxio.thrift.FileSystemMasterClientService.checkConsistency_result._Fields
 
getFieldName() - Method in enum alluxio.thrift.FileSystemMasterClientService.completeFile_args._Fields
 
getFieldName() - Method in enum alluxio.thrift.FileSystemMasterClientService.completeFile_result._Fields
 
getFieldName() - Method in enum alluxio.thrift.FileSystemMasterClientService.createDirectory_args._Fields
 
getFieldName() - Method in enum alluxio.thrift.FileSystemMasterClientService.createDirectory_result._Fields
 
getFieldName() - Method in enum alluxio.thrift.FileSystemMasterClientService.createFile_args._Fields
 
getFieldName() - Method in enum alluxio.thrift.FileSystemMasterClientService.createFile_result._Fields
 
getFieldName() - Method in enum alluxio.thrift.FileSystemMasterClientService.free_args._Fields
 
getFieldName() - Method in enum alluxio.thrift.FileSystemMasterClientService.free_result._Fields
 
getFieldName() - Method in enum alluxio.thrift.FileSystemMasterClientService.getFilePath_args._Fields
 
getFieldName() - Method in enum alluxio.thrift.FileSystemMasterClientService.getFilePath_result._Fields
 
getFieldName() - Method in enum alluxio.thrift.FileSystemMasterClientService.getMountTable_args._Fields
 
getFieldName() - Method in enum alluxio.thrift.FileSystemMasterClientService.getMountTable_result._Fields
 
getFieldName() - Method in enum alluxio.thrift.FileSystemMasterClientService.getNewBlockIdForFile_args._Fields
 
getFieldName() - Method in enum alluxio.thrift.FileSystemMasterClientService.getNewBlockIdForFile_result._Fields
 
getFieldName() - Method in enum alluxio.thrift.FileSystemMasterClientService.getStatus_args._Fields
 
getFieldName() - Method in enum alluxio.thrift.FileSystemMasterClientService.getStatus_result._Fields
 
getFieldName() - Method in enum alluxio.thrift.FileSystemMasterClientService.listStatus_args._Fields
 
getFieldName() - Method in enum alluxio.thrift.FileSystemMasterClientService.listStatus_result._Fields
 
getFieldName() - Method in enum alluxio.thrift.FileSystemMasterClientService.loadMetadata_args._Fields
 
getFieldName() - Method in enum alluxio.thrift.FileSystemMasterClientService.loadMetadata_result._Fields
 
getFieldName() - Method in enum alluxio.thrift.FileSystemMasterClientService.mount_args._Fields
 
getFieldName() - Method in enum alluxio.thrift.FileSystemMasterClientService.mount_result._Fields
 
getFieldName() - Method in enum alluxio.thrift.FileSystemMasterClientService.remove_args._Fields
 
getFieldName() - Method in enum alluxio.thrift.FileSystemMasterClientService.remove_result._Fields
 
getFieldName() - Method in enum alluxio.thrift.FileSystemMasterClientService.rename_args._Fields
 
getFieldName() - Method in enum alluxio.thrift.FileSystemMasterClientService.rename_result._Fields
 
getFieldName() - Method in enum alluxio.thrift.FileSystemMasterClientService.scheduleAsyncPersistence_args._Fields
 
getFieldName() - Method in enum alluxio.thrift.FileSystemMasterClientService.scheduleAsyncPersistence_result._Fields
 
getFieldName() - Method in enum alluxio.thrift.FileSystemMasterClientService.setAttribute_args._Fields
 
getFieldName() - Method in enum alluxio.thrift.FileSystemMasterClientService.setAttribute_result._Fields
 
getFieldName() - Method in enum alluxio.thrift.FileSystemMasterClientService.unmount_args._Fields
 
getFieldName() - Method in enum alluxio.thrift.FileSystemMasterClientService.unmount_result._Fields
 
getFieldName() - Method in enum alluxio.thrift.FileSystemMasterClientService.updateUfsMode_args._Fields
 
getFieldName() - Method in enum alluxio.thrift.FileSystemMasterClientService.updateUfsMode_result._Fields
 
getFieldName() - Method in enum alluxio.thrift.FileSystemMasterCommonTOptions._Fields
 
getFieldName() - Method in enum alluxio.thrift.FileSystemMasterWorkerService.fileSystemHeartbeat_args._Fields
 
getFieldName() - Method in enum alluxio.thrift.FileSystemMasterWorkerService.fileSystemHeartbeat_result._Fields
 
getFieldName() - Method in enum alluxio.thrift.FileSystemMasterWorkerService.getFileInfo_args._Fields
 
getFieldName() - Method in enum alluxio.thrift.FileSystemMasterWorkerService.getFileInfo_result._Fields
 
getFieldName() - Method in enum alluxio.thrift.FileSystemMasterWorkerService.getPinnedFileIds_args._Fields
 
getFieldName() - Method in enum alluxio.thrift.FileSystemMasterWorkerService.getPinnedFileIds_result._Fields
 
getFieldName() - Method in enum alluxio.thrift.FileSystemMasterWorkerService.getUfsInfo_args._Fields
 
getFieldName() - Method in enum alluxio.thrift.FileSystemMasterWorkerService.getUfsInfo_result._Fields
 
getFieldName() - Method in enum alluxio.thrift.FileSystemWorkerClientService.cancelUfsFile_args._Fields
 
getFieldName() - Method in enum alluxio.thrift.FileSystemWorkerClientService.cancelUfsFile_result._Fields
 
getFieldName() - Method in enum alluxio.thrift.FileSystemWorkerClientService.closeUfsFile_args._Fields
 
getFieldName() - Method in enum alluxio.thrift.FileSystemWorkerClientService.closeUfsFile_result._Fields
 
getFieldName() - Method in enum alluxio.thrift.FileSystemWorkerClientService.completeUfsFile_args._Fields
 
getFieldName() - Method in enum alluxio.thrift.FileSystemWorkerClientService.completeUfsFile_result._Fields
 
getFieldName() - Method in enum alluxio.thrift.FileSystemWorkerClientService.createUfsFile_args._Fields
 
getFieldName() - Method in enum alluxio.thrift.FileSystemWorkerClientService.createUfsFile_result._Fields
 
getFieldName() - Method in enum alluxio.thrift.FileSystemWorkerClientService.openUfsFile_args._Fields
 
getFieldName() - Method in enum alluxio.thrift.FileSystemWorkerClientService.openUfsFile_result._Fields
 
getFieldName() - Method in enum alluxio.thrift.FileSystemWorkerClientService.sessionFileSystemHeartbeat_args._Fields
 
getFieldName() - Method in enum alluxio.thrift.FileSystemWorkerClientService.sessionFileSystemHeartbeat_result._Fields
 
getFieldName() - Method in enum alluxio.thrift.FreeTOptions._Fields
 
getFieldName() - Method in enum alluxio.thrift.FreeTResponse._Fields
 
getFieldName() - Method in enum alluxio.thrift.GetBlockInfoTOptions._Fields
 
getFieldName() - Method in enum alluxio.thrift.GetBlockInfoTResponse._Fields
 
getFieldName() - Method in enum alluxio.thrift.GetBlockMasterInfoTOptions._Fields
 
getFieldName() - Method in enum alluxio.thrift.GetBlockMasterInfoTResponse._Fields
 
getFieldName() - Method in enum alluxio.thrift.GetCapacityBytesTOptions._Fields
 
getFieldName() - Method in enum alluxio.thrift.GetCapacityBytesTResponse._Fields
 
getFieldName() - Method in enum alluxio.thrift.GetConfigReportTOptions._Fields
 
getFieldName() - Method in enum alluxio.thrift.GetConfigReportTResponse._Fields
 
getFieldName() - Method in enum alluxio.thrift.GetConfigurationTOptions._Fields
 
getFieldName() - Method in enum alluxio.thrift.GetConfigurationTResponse._Fields
 
getFieldName() - Method in enum alluxio.thrift.GetFileInfoTOptions._Fields
 
getFieldName() - Method in enum alluxio.thrift.GetFileInfoTResponse._Fields
 
getFieldName() - Method in enum alluxio.thrift.GetFilePathTOptions._Fields
 
getFieldName() - Method in enum alluxio.thrift.GetFilePathTResponse._Fields
 
getFieldName() - Method in enum alluxio.thrift.GetLineageInfoListTOptions._Fields
 
getFieldName() - Method in enum alluxio.thrift.GetLineageInfoListTResponse._Fields
 
getFieldName() - Method in enum alluxio.thrift.GetMasterIdTOptions._Fields
 
getFieldName() - Method in enum alluxio.thrift.GetMasterIdTResponse._Fields
 
getFieldName() - Method in enum alluxio.thrift.GetMasterInfoTOptions._Fields
 
getFieldName() - Method in enum alluxio.thrift.GetMasterInfoTResponse._Fields
 
getFieldName() - Method in enum alluxio.thrift.GetMetricsTOptions._Fields
 
getFieldName() - Method in enum alluxio.thrift.GetMetricsTResponse._Fields
 
getFieldName() - Method in enum alluxio.thrift.GetMountTableTResponse._Fields
 
getFieldName() - Method in enum alluxio.thrift.GetNewBlockIdForFileTOptions._Fields
 
getFieldName() - Method in enum alluxio.thrift.GetNewBlockIdForFileTResponse._Fields
 
getFieldName() - Method in enum alluxio.thrift.GetNextKeysTOptions._Fields
 
getFieldName() - Method in enum alluxio.thrift.GetNextKeysTResponse._Fields
 
getFieldName() - Method in enum alluxio.thrift.GetPartitionInfoTOptions._Fields
 
getFieldName() - Method in enum alluxio.thrift.GetPartitionInfoTResponse._Fields
 
getFieldName() - Method in enum alluxio.thrift.GetPinnedFileIdsTOptions._Fields
 
getFieldName() - Method in enum alluxio.thrift.GetPinnedFileIdsTResponse._Fields
 
getFieldName() - Method in enum alluxio.thrift.GetServiceVersionTOptions._Fields
 
getFieldName() - Method in enum alluxio.thrift.GetServiceVersionTResponse._Fields
 
getFieldName() - Method in enum alluxio.thrift.GetSizeTOptions._Fields
 
getFieldName() - Method in enum alluxio.thrift.GetSizeTResponse._Fields
 
getFieldName() - Method in enum alluxio.thrift.GetStatusTOptions._Fields
 
getFieldName() - Method in enum alluxio.thrift.GetStatusTResponse._Fields
 
getFieldName() - Method in enum alluxio.thrift.GetTOptions._Fields
 
getFieldName() - Method in enum alluxio.thrift.GetTResponse._Fields
 
getFieldName() - Method in enum alluxio.thrift.GetUfsInfoTOptions._Fields
 
getFieldName() - Method in enum alluxio.thrift.GetUfsInfoTResponse._Fields
 
getFieldName() - Method in enum alluxio.thrift.GetUsedBytesTOptions._Fields
 
getFieldName() - Method in enum alluxio.thrift.GetUsedBytesTResponse._Fields
 
getFieldName() - Method in enum alluxio.thrift.GetWorkerIdTOptions._Fields
 
getFieldName() - Method in enum alluxio.thrift.GetWorkerIdTResponse._Fields
 
getFieldName() - Method in enum alluxio.thrift.GetWorkerInfoListTOptions._Fields
 
getFieldName() - Method in enum alluxio.thrift.GetWorkerInfoListTResponse._Fields
 
getFieldName() - Method in enum alluxio.thrift.GetWorkerReportTOptions._Fields
 
getFieldName() - Method in enum alluxio.thrift.InconsistentProperty._Fields
 
getFieldName() - Method in enum alluxio.thrift.JobConfInfo._Fields
 
getFieldName() - Method in enum alluxio.thrift.KeyValueMasterClientService.completePartition_args._Fields
 
getFieldName() - Method in enum alluxio.thrift.KeyValueMasterClientService.completePartition_result._Fields
 
getFieldName() - Method in enum alluxio.thrift.KeyValueMasterClientService.completeStore_args._Fields
 
getFieldName() - Method in enum alluxio.thrift.KeyValueMasterClientService.completeStore_result._Fields
 
getFieldName() - Method in enum alluxio.thrift.KeyValueMasterClientService.createStore_args._Fields
 
getFieldName() - Method in enum alluxio.thrift.KeyValueMasterClientService.createStore_result._Fields
 
getFieldName() - Method in enum alluxio.thrift.KeyValueMasterClientService.deleteStore_args._Fields
 
getFieldName() - Method in enum alluxio.thrift.KeyValueMasterClientService.deleteStore_result._Fields
 
getFieldName() - Method in enum alluxio.thrift.KeyValueMasterClientService.getPartitionInfo_args._Fields
 
getFieldName() - Method in enum alluxio.thrift.KeyValueMasterClientService.getPartitionInfo_result._Fields
 
getFieldName() - Method in enum alluxio.thrift.KeyValueMasterClientService.mergeStore_args._Fields
 
getFieldName() - Method in enum alluxio.thrift.KeyValueMasterClientService.mergeStore_result._Fields
 
getFieldName() - Method in enum alluxio.thrift.KeyValueMasterClientService.renameStore_args._Fields
 
getFieldName() - Method in enum alluxio.thrift.KeyValueMasterClientService.renameStore_result._Fields
 
getFieldName() - Method in enum alluxio.thrift.KeyValueWorkerClientService.get_args._Fields
 
getFieldName() - Method in enum alluxio.thrift.KeyValueWorkerClientService.get_result._Fields
 
getFieldName() - Method in enum alluxio.thrift.KeyValueWorkerClientService.getNextKeys_args._Fields
 
getFieldName() - Method in enum alluxio.thrift.KeyValueWorkerClientService.getNextKeys_result._Fields
 
getFieldName() - Method in enum alluxio.thrift.KeyValueWorkerClientService.getSize_args._Fields
 
getFieldName() - Method in enum alluxio.thrift.KeyValueWorkerClientService.getSize_result._Fields
 
getFieldName() - Method in enum alluxio.thrift.LineageInfo._Fields
 
getFieldName() - Method in enum alluxio.thrift.LineageMasterClientService.createLineage_args._Fields
 
getFieldName() - Method in enum alluxio.thrift.LineageMasterClientService.createLineage_result._Fields
 
getFieldName() - Method in enum alluxio.thrift.LineageMasterClientService.deleteLineage_args._Fields
 
getFieldName() - Method in enum alluxio.thrift.LineageMasterClientService.deleteLineage_result._Fields
 
getFieldName() - Method in enum alluxio.thrift.LineageMasterClientService.getLineageInfoList_args._Fields
 
getFieldName() - Method in enum alluxio.thrift.LineageMasterClientService.getLineageInfoList_result._Fields
 
getFieldName() - Method in enum alluxio.thrift.LineageMasterClientService.reinitializeFile_args._Fields
 
getFieldName() - Method in enum alluxio.thrift.LineageMasterClientService.reinitializeFile_result._Fields
 
getFieldName() - Method in enum alluxio.thrift.LineageMasterClientService.reportLostFile_args._Fields
 
getFieldName() - Method in enum alluxio.thrift.LineageMasterClientService.reportLostFile_result._Fields
 
getFieldName() - Method in enum alluxio.thrift.ListStatusTOptions._Fields
 
getFieldName() - Method in enum alluxio.thrift.ListStatusTResponse._Fields
 
getFieldName() - Method in enum alluxio.thrift.LoadMetadataTOptions._Fields
 
getFieldName() - Method in enum alluxio.thrift.LoadMetadataTResponse._Fields
 
getFieldName() - Method in enum alluxio.thrift.LocalityTier._Fields
 
getFieldName() - Method in enum alluxio.thrift.LockBlockTOptions._Fields
 
getFieldName() - Method in enum alluxio.thrift.LockBlockTResponse._Fields
 
getFieldName() - Method in enum alluxio.thrift.MasterHeartbeatTOptions._Fields
 
getFieldName() - Method in enum alluxio.thrift.MasterHeartbeatTResponse._Fields
 
getFieldName() - Method in enum alluxio.thrift.MasterInfo._Fields
 
getFieldName() - Method in enum alluxio.thrift.MasterNetAddress._Fields
 
getFieldName() - Method in enum alluxio.thrift.MergeStoreTOptions._Fields
 
getFieldName() - Method in enum alluxio.thrift.MergeStoreTResponse._Fields
 
getFieldName() - Method in enum alluxio.thrift.MetaMasterClientService.backup_args._Fields
 
getFieldName() - Method in enum alluxio.thrift.MetaMasterClientService.backup_result._Fields
 
getFieldName() - Method in enum alluxio.thrift.MetaMasterClientService.getConfigReport_args._Fields
 
getFieldName() - Method in enum alluxio.thrift.MetaMasterClientService.getConfigReport_result._Fields
 
getFieldName() - Method in enum alluxio.thrift.MetaMasterClientService.getConfiguration_args._Fields
 
getFieldName() - Method in enum alluxio.thrift.MetaMasterClientService.getConfiguration_result._Fields
 
getFieldName() - Method in enum alluxio.thrift.MetaMasterClientService.getMasterInfo_args._Fields
 
getFieldName() - Method in enum alluxio.thrift.MetaMasterClientService.getMasterInfo_result._Fields
 
getFieldName() - Method in enum alluxio.thrift.MetaMasterClientService.getMetrics_args._Fields
 
getFieldName() - Method in enum alluxio.thrift.MetaMasterClientService.getMetrics_result._Fields
 
getFieldName() - Method in enum alluxio.thrift.MetaMasterMasterService.getMasterId_args._Fields
 
getFieldName() - Method in enum alluxio.thrift.MetaMasterMasterService.getMasterId_result._Fields
 
getFieldName() - Method in enum alluxio.thrift.MetaMasterMasterService.masterHeartbeat_args._Fields
 
getFieldName() - Method in enum alluxio.thrift.MetaMasterMasterService.masterHeartbeat_result._Fields
 
getFieldName() - Method in enum alluxio.thrift.MetaMasterMasterService.registerMaster_args._Fields
 
getFieldName() - Method in enum alluxio.thrift.MetaMasterMasterService.registerMaster_result._Fields
 
getFieldName() - Method in enum alluxio.thrift.Metric._Fields
 
getFieldName() - Method in enum alluxio.thrift.MetricsHeartbeatTOptions._Fields
 
getFieldName() - Method in enum alluxio.thrift.MetricsHeartbeatTResponse._Fields
 
getFieldName() - Method in enum alluxio.thrift.MetricsMasterClientService.metricsHeartbeat_args._Fields
 
getFieldName() - Method in enum alluxio.thrift.MetricsMasterClientService.metricsHeartbeat_result._Fields
 
getFieldName() - Method in enum alluxio.thrift.MetricValue._Fields
 
getFieldName() - Method in enum alluxio.thrift.MountPointInfo._Fields
 
getFieldName() - Method in enum alluxio.thrift.MountTOptions._Fields
 
getFieldName() - Method in enum alluxio.thrift.MountTResponse._Fields
 
getFieldName() - Method in enum alluxio.thrift.OpenUfsFileTOptions._Fields
 
getFieldName() - Method in enum alluxio.thrift.OpenUfsFileTResponse._Fields
 
getFieldName() - Method in enum alluxio.thrift.OptionalString._Fields
 
getFieldName() - Method in enum alluxio.thrift.PartitionInfo._Fields
 
getFieldName() - Method in enum alluxio.thrift.PersistCommandOptions._Fields
 
getFieldName() - Method in enum alluxio.thrift.PersistFile._Fields
 
getFieldName() - Method in enum alluxio.thrift.PromoteBlockTOptions._Fields
 
getFieldName() - Method in enum alluxio.thrift.PromoteBlockTResponse._Fields
 
getFieldName() - Method in enum alluxio.thrift.RegisterMasterTOptions._Fields
 
getFieldName() - Method in enum alluxio.thrift.RegisterMasterTResponse._Fields
 
getFieldName() - Method in enum alluxio.thrift.RegisterWorkerTOptions._Fields
 
getFieldName() - Method in enum alluxio.thrift.RegisterWorkerTResponse._Fields
 
getFieldName() - Method in enum alluxio.thrift.ReinitializeFileTOptions._Fields
 
getFieldName() - Method in enum alluxio.thrift.ReinitializeFileTResponse._Fields
 
getFieldName() - Method in enum alluxio.thrift.RemoveBlockTOptions._Fields
 
getFieldName() - Method in enum alluxio.thrift.RemoveBlockTResponse._Fields
 
getFieldName() - Method in enum alluxio.thrift.RenameStoreTOptions._Fields
 
getFieldName() - Method in enum alluxio.thrift.RenameStoreTResponse._Fields
 
getFieldName() - Method in enum alluxio.thrift.RenameTOptions._Fields
 
getFieldName() - Method in enum alluxio.thrift.RenameTResponse._Fields
 
getFieldName() - Method in enum alluxio.thrift.ReportLostFileTOptions._Fields
 
getFieldName() - Method in enum alluxio.thrift.ReportLostFileTResponse._Fields
 
getFieldName() - Method in enum alluxio.thrift.RequestBlockLocationTOptions._Fields
 
getFieldName() - Method in enum alluxio.thrift.RequestBlockLocationTResponse._Fields
 
getFieldName() - Method in enum alluxio.thrift.RequestSpaceTOptions._Fields
 
getFieldName() - Method in enum alluxio.thrift.RequestSpaceTResponse._Fields
 
getFieldName() - Method in enum alluxio.thrift.ScheduleAsyncPersistenceTOptions._Fields
 
getFieldName() - Method in enum alluxio.thrift.ScheduleAsyncPersistenceTResponse._Fields
 
getFieldName() - Method in enum alluxio.thrift.SessionBlockHeartbeatTOptions._Fields
 
getFieldName() - Method in enum alluxio.thrift.SessionBlockHeartbeatTResponse._Fields
 
getFieldName() - Method in enum alluxio.thrift.SessionFileSystemHeartbeatTOptions._Fields
 
getFieldName() - Method in enum alluxio.thrift.SessionFileSystemHeartbeatTResponse._Fields
 
getFieldName() - Method in enum alluxio.thrift.SetAttributeTOptions._Fields
 
getFieldName() - Method in enum alluxio.thrift.SetAttributeTResponse._Fields
 
getFieldName() - Method in enum alluxio.thrift.SyncMetadataTOptions._Fields
 
getFieldName() - Method in enum alluxio.thrift.SyncMetadataTResponse._Fields
 
getFieldName() - Method in enum alluxio.thrift.TieredIdentity._Fields
 
getFieldName() - Method in enum alluxio.thrift.UfsInfo._Fields
 
getFieldName() - Method in enum alluxio.thrift.UnlockBlockTOptions._Fields
 
getFieldName() - Method in enum alluxio.thrift.UnlockBlockTResponse._Fields
 
getFieldName() - Method in enum alluxio.thrift.UnmountTOptions._Fields
 
getFieldName() - Method in enum alluxio.thrift.UnmountTResponse._Fields
 
getFieldName() - Method in enum alluxio.thrift.UpdateUfsModeTOptions._Fields
 
getFieldName() - Method in enum alluxio.thrift.UpdateUfsModeTResponse._Fields
 
getFieldName() - Method in enum alluxio.thrift.WorkerInfo._Fields
 
getFieldName() - Method in enum alluxio.thrift.WorkerNetAddress._Fields
 
getFieldRange() - Method in class alluxio.client.block.options.GetWorkerReportOptions
 
getFieldRange() - Method in class alluxio.thrift.GetWorkerReportTOptions
 
getFieldRangeIterator() - Method in class alluxio.thrift.GetWorkerReportTOptions
 
getFieldRangeSize() - Method in class alluxio.thrift.GetWorkerReportTOptions
 
getFieldValue(T) - Method in class alluxio.collections.IndexDefinition
Gets the value of the field that serves as index.
getFieldValue(AccessBlockTOptions._Fields) - Method in class alluxio.thrift.AccessBlockTOptions
 
getFieldValue(AccessBlockTResponse._Fields) - Method in class alluxio.thrift.AccessBlockTResponse
 
getFieldValue(AlluxioService.getServiceVersion_args._Fields) - Method in class alluxio.thrift.AlluxioService.getServiceVersion_args
 
getFieldValue(AlluxioService.getServiceVersion_result._Fields) - Method in class alluxio.thrift.AlluxioService.getServiceVersion_result
 
getFieldValue(AlluxioTException._Fields) - Method in exception alluxio.thrift.AlluxioTException
 
getFieldValue(BackupTOptions._Fields) - Method in class alluxio.thrift.BackupTOptions
 
getFieldValue(BackupTResponse._Fields) - Method in class alluxio.thrift.BackupTResponse
 
getFieldValue(BlockHeartbeatTOptions._Fields) - Method in class alluxio.thrift.BlockHeartbeatTOptions
 
getFieldValue(BlockHeartbeatTResponse._Fields) - Method in class alluxio.thrift.BlockHeartbeatTResponse
 
getFieldValue(BlockInfo._Fields) - Method in class alluxio.thrift.BlockInfo
 
getFieldValue(BlockLocation._Fields) - Method in class alluxio.thrift.BlockLocation
 
getFieldValue(BlockMasterClientService.getBlockInfo_args._Fields) - Method in class alluxio.thrift.BlockMasterClientService.getBlockInfo_args
 
getFieldValue(BlockMasterClientService.getBlockInfo_result._Fields) - Method in class alluxio.thrift.BlockMasterClientService.getBlockInfo_result
 
getFieldValue(BlockMasterClientService.getBlockMasterInfo_args._Fields) - Method in class alluxio.thrift.BlockMasterClientService.getBlockMasterInfo_args
 
getFieldValue(BlockMasterClientService.getBlockMasterInfo_result._Fields) - Method in class alluxio.thrift.BlockMasterClientService.getBlockMasterInfo_result
 
getFieldValue(BlockMasterClientService.getCapacityBytes_args._Fields) - Method in class alluxio.thrift.BlockMasterClientService.getCapacityBytes_args
 
getFieldValue(BlockMasterClientService.getCapacityBytes_result._Fields) - Method in class alluxio.thrift.BlockMasterClientService.getCapacityBytes_result
 
getFieldValue(BlockMasterClientService.getUsedBytes_args._Fields) - Method in class alluxio.thrift.BlockMasterClientService.getUsedBytes_args
 
getFieldValue(BlockMasterClientService.getUsedBytes_result._Fields) - Method in class alluxio.thrift.BlockMasterClientService.getUsedBytes_result
 
getFieldValue(BlockMasterClientService.getWorkerInfoList_args._Fields) - Method in class alluxio.thrift.BlockMasterClientService.getWorkerInfoList_args
 
getFieldValue(BlockMasterClientService.getWorkerInfoList_result._Fields) - Method in class alluxio.thrift.BlockMasterClientService.getWorkerInfoList_result
 
getFieldValue(BlockMasterClientService.getWorkerReport_args._Fields) - Method in class alluxio.thrift.BlockMasterClientService.getWorkerReport_args
 
getFieldValue(BlockMasterClientService.getWorkerReport_result._Fields) - Method in class alluxio.thrift.BlockMasterClientService.getWorkerReport_result
 
getFieldValue(BlockMasterInfo._Fields) - Method in class alluxio.thrift.BlockMasterInfo
 
getFieldValue(BlockMasterWorkerService.blockHeartbeat_args._Fields) - Method in class alluxio.thrift.BlockMasterWorkerService.blockHeartbeat_args
 
getFieldValue(BlockMasterWorkerService.blockHeartbeat_result._Fields) - Method in class alluxio.thrift.BlockMasterWorkerService.blockHeartbeat_result
 
getFieldValue(BlockMasterWorkerService.commitBlock_args._Fields) - Method in class alluxio.thrift.BlockMasterWorkerService.commitBlock_args
 
getFieldValue(BlockMasterWorkerService.commitBlock_result._Fields) - Method in class alluxio.thrift.BlockMasterWorkerService.commitBlock_result
 
getFieldValue(BlockMasterWorkerService.getWorkerId_args._Fields) - Method in class alluxio.thrift.BlockMasterWorkerService.getWorkerId_args
 
getFieldValue(BlockMasterWorkerService.getWorkerId_result._Fields) - Method in class alluxio.thrift.BlockMasterWorkerService.getWorkerId_result
 
getFieldValue(BlockMasterWorkerService.registerWorker_args._Fields) - Method in class alluxio.thrift.BlockMasterWorkerService.registerWorker_args
 
getFieldValue(BlockMasterWorkerService.registerWorker_result._Fields) - Method in class alluxio.thrift.BlockMasterWorkerService.registerWorker_result
 
getFieldValue(BlockWorkerClientService.accessBlock_args._Fields) - Method in class alluxio.thrift.BlockWorkerClientService.accessBlock_args
 
getFieldValue(BlockWorkerClientService.accessBlock_result._Fields) - Method in class alluxio.thrift.BlockWorkerClientService.accessBlock_result
 
getFieldValue(BlockWorkerClientService.cacheBlock_args._Fields) - Method in class alluxio.thrift.BlockWorkerClientService.cacheBlock_args
 
getFieldValue(BlockWorkerClientService.cacheBlock_result._Fields) - Method in class alluxio.thrift.BlockWorkerClientService.cacheBlock_result
 
getFieldValue(BlockWorkerClientService.cancelBlock_args._Fields) - Method in class alluxio.thrift.BlockWorkerClientService.cancelBlock_args
 
getFieldValue(BlockWorkerClientService.cancelBlock_result._Fields) - Method in class alluxio.thrift.BlockWorkerClientService.cancelBlock_result
 
getFieldValue(BlockWorkerClientService.lockBlock_args._Fields) - Method in class alluxio.thrift.BlockWorkerClientService.lockBlock_args
 
getFieldValue(BlockWorkerClientService.lockBlock_result._Fields) - Method in class alluxio.thrift.BlockWorkerClientService.lockBlock_result
 
getFieldValue(BlockWorkerClientService.promoteBlock_args._Fields) - Method in class alluxio.thrift.BlockWorkerClientService.promoteBlock_args
 
getFieldValue(BlockWorkerClientService.promoteBlock_result._Fields) - Method in class alluxio.thrift.BlockWorkerClientService.promoteBlock_result
 
getFieldValue(BlockWorkerClientService.removeBlock_args._Fields) - Method in class alluxio.thrift.BlockWorkerClientService.removeBlock_args
 
getFieldValue(BlockWorkerClientService.removeBlock_result._Fields) - Method in class alluxio.thrift.BlockWorkerClientService.removeBlock_result
 
getFieldValue(BlockWorkerClientService.requestBlockLocation_args._Fields) - Method in class alluxio.thrift.BlockWorkerClientService.requestBlockLocation_args
 
getFieldValue(BlockWorkerClientService.requestBlockLocation_result._Fields) - Method in class alluxio.thrift.BlockWorkerClientService.requestBlockLocation_result
 
getFieldValue(BlockWorkerClientService.requestSpace_args._Fields) - Method in class alluxio.thrift.BlockWorkerClientService.requestSpace_args
 
getFieldValue(BlockWorkerClientService.requestSpace_result._Fields) - Method in class alluxio.thrift.BlockWorkerClientService.requestSpace_result
 
getFieldValue(BlockWorkerClientService.sessionBlockHeartbeat_args._Fields) - Method in class alluxio.thrift.BlockWorkerClientService.sessionBlockHeartbeat_args
 
getFieldValue(BlockWorkerClientService.sessionBlockHeartbeat_result._Fields) - Method in class alluxio.thrift.BlockWorkerClientService.sessionBlockHeartbeat_result
 
getFieldValue(BlockWorkerClientService.unlockBlock_args._Fields) - Method in class alluxio.thrift.BlockWorkerClientService.unlockBlock_args
 
getFieldValue(BlockWorkerClientService.unlockBlock_result._Fields) - Method in class alluxio.thrift.BlockWorkerClientService.unlockBlock_result
 
getFieldValue(CacheBlockTOptions._Fields) - Method in class alluxio.thrift.CacheBlockTOptions
 
getFieldValue(CacheBlockTResponse._Fields) - Method in class alluxio.thrift.CacheBlockTResponse
 
getFieldValue(CancelBlockTOptions._Fields) - Method in class alluxio.thrift.CancelBlockTOptions
 
getFieldValue(CancelBlockTResponse._Fields) - Method in class alluxio.thrift.CancelBlockTResponse
 
getFieldValue(CancelUfsFileTOptions._Fields) - Method in class alluxio.thrift.CancelUfsFileTOptions
 
getFieldValue(CancelUfsFileTResponse._Fields) - Method in class alluxio.thrift.CancelUfsFileTResponse
 
getFieldValue(CheckConsistencyTOptions._Fields) - Method in class alluxio.thrift.CheckConsistencyTOptions
 
getFieldValue(CheckConsistencyTResponse._Fields) - Method in class alluxio.thrift.CheckConsistencyTResponse
 
getFieldValue(CloseUfsFileTOptions._Fields) - Method in class alluxio.thrift.CloseUfsFileTOptions
 
getFieldValue(CloseUfsFileTResponse._Fields) - Method in class alluxio.thrift.CloseUfsFileTResponse
 
getFieldValue(Command._Fields) - Method in class alluxio.thrift.Command
 
getFieldValue(CommandLineJobInfo._Fields) - Method in class alluxio.thrift.CommandLineJobInfo
 
getFieldValue(CommitBlockTOptions._Fields) - Method in class alluxio.thrift.CommitBlockTOptions
 
getFieldValue(CommitBlockTResponse._Fields) - Method in class alluxio.thrift.CommitBlockTResponse
 
getFieldValue(CompleteFileTOptions._Fields) - Method in class alluxio.thrift.CompleteFileTOptions
 
getFieldValue(CompleteFileTResponse._Fields) - Method in class alluxio.thrift.CompleteFileTResponse
 
getFieldValue(CompletePartitionTOptions._Fields) - Method in class alluxio.thrift.CompletePartitionTOptions
 
getFieldValue(CompletePartitionTResponse._Fields) - Method in class alluxio.thrift.CompletePartitionTResponse
 
getFieldValue(CompleteStoreTOptions._Fields) - Method in class alluxio.thrift.CompleteStoreTOptions
 
getFieldValue(CompleteStoreTResponse._Fields) - Method in class alluxio.thrift.CompleteStoreTResponse
 
getFieldValue(CompleteUfsFileTOptions._Fields) - Method in class alluxio.thrift.CompleteUfsFileTOptions
 
getFieldValue(CompleteUfsFileTReponse._Fields) - Method in class alluxio.thrift.CompleteUfsFileTReponse
 
getFieldValue(ConfigCheckReport._Fields) - Method in class alluxio.thrift.ConfigCheckReport
 
getFieldValue(ConfigProperty._Fields) - Method in class alluxio.thrift.ConfigProperty
 
getFieldValue(CreateDirectoryTOptions._Fields) - Method in class alluxio.thrift.CreateDirectoryTOptions
 
getFieldValue(CreateDirectoryTResponse._Fields) - Method in class alluxio.thrift.CreateDirectoryTResponse
 
getFieldValue(CreateFileTOptions._Fields) - Method in class alluxio.thrift.CreateFileTOptions
 
getFieldValue(CreateFileTResponse._Fields) - Method in class alluxio.thrift.CreateFileTResponse
 
getFieldValue(CreateLineageTOptions._Fields) - Method in class alluxio.thrift.CreateLineageTOptions
 
getFieldValue(CreateLineageTResponse._Fields) - Method in class alluxio.thrift.CreateLineageTResponse
 
getFieldValue(CreateStoreTOptions._Fields) - Method in class alluxio.thrift.CreateStoreTOptions
 
getFieldValue(CreateStoreTResponse._Fields) - Method in class alluxio.thrift.CreateStoreTResponse
 
getFieldValue(CreateUfsFileTOptions._Fields) - Method in class alluxio.thrift.CreateUfsFileTOptions
 
getFieldValue(CreateUfsFileTResponse._Fields) - Method in class alluxio.thrift.CreateUfsFileTResponse
 
getFieldValue(DeleteLineageTOptions._Fields) - Method in class alluxio.thrift.DeleteLineageTOptions
 
getFieldValue(DeleteLineageTResponse._Fields) - Method in class alluxio.thrift.DeleteLineageTResponse
 
getFieldValue(DeleteStoreTOptions._Fields) - Method in class alluxio.thrift.DeleteStoreTOptions
 
getFieldValue(DeleteStoreTResponse._Fields) - Method in class alluxio.thrift.DeleteStoreTResponse
 
getFieldValue(DeleteTOptions._Fields) - Method in class alluxio.thrift.DeleteTOptions
 
getFieldValue(DeleteTResponse._Fields) - Method in class alluxio.thrift.DeleteTResponse
 
getFieldValue(DependencyInfo._Fields) - Method in class alluxio.thrift.DependencyInfo
 
getFieldValue(FileBlockInfo._Fields) - Method in class alluxio.thrift.FileBlockInfo
 
getFieldValue(FileInfo._Fields) - Method in class alluxio.thrift.FileInfo
 
getFieldValue(FileSystemCommand._Fields) - Method in class alluxio.thrift.FileSystemCommand
 
getFieldValue(FileSystemHeartbeatTOptions._Fields) - Method in class alluxio.thrift.FileSystemHeartbeatTOptions
 
getFieldValue(FileSystemHeartbeatTResponse._Fields) - Method in class alluxio.thrift.FileSystemHeartbeatTResponse
 
getFieldValue(FileSystemMasterClientService.checkConsistency_args._Fields) - Method in class alluxio.thrift.FileSystemMasterClientService.checkConsistency_args
 
getFieldValue(FileSystemMasterClientService.checkConsistency_result._Fields) - Method in class alluxio.thrift.FileSystemMasterClientService.checkConsistency_result
 
getFieldValue(FileSystemMasterClientService.completeFile_args._Fields) - Method in class alluxio.thrift.FileSystemMasterClientService.completeFile_args
 
getFieldValue(FileSystemMasterClientService.completeFile_result._Fields) - Method in class alluxio.thrift.FileSystemMasterClientService.completeFile_result
 
getFieldValue(FileSystemMasterClientService.createDirectory_args._Fields) - Method in class alluxio.thrift.FileSystemMasterClientService.createDirectory_args
 
getFieldValue(FileSystemMasterClientService.createDirectory_result._Fields) - Method in class alluxio.thrift.FileSystemMasterClientService.createDirectory_result
 
getFieldValue(FileSystemMasterClientService.createFile_args._Fields) - Method in class alluxio.thrift.FileSystemMasterClientService.createFile_args
 
getFieldValue(FileSystemMasterClientService.createFile_result._Fields) - Method in class alluxio.thrift.FileSystemMasterClientService.createFile_result
 
getFieldValue(FileSystemMasterClientService.free_args._Fields) - Method in class alluxio.thrift.FileSystemMasterClientService.free_args
 
getFieldValue(FileSystemMasterClientService.free_result._Fields) - Method in class alluxio.thrift.FileSystemMasterClientService.free_result
 
getFieldValue(FileSystemMasterClientService.getFilePath_args._Fields) - Method in class alluxio.thrift.FileSystemMasterClientService.getFilePath_args
 
getFieldValue(FileSystemMasterClientService.getFilePath_result._Fields) - Method in class alluxio.thrift.FileSystemMasterClientService.getFilePath_result
 
getFieldValue(FileSystemMasterClientService.getMountTable_args._Fields) - Method in class alluxio.thrift.FileSystemMasterClientService.getMountTable_args
 
getFieldValue(FileSystemMasterClientService.getMountTable_result._Fields) - Method in class alluxio.thrift.FileSystemMasterClientService.getMountTable_result
 
getFieldValue(FileSystemMasterClientService.getNewBlockIdForFile_args._Fields) - Method in class alluxio.thrift.FileSystemMasterClientService.getNewBlockIdForFile_args
 
getFieldValue(FileSystemMasterClientService.getNewBlockIdForFile_result._Fields) - Method in class alluxio.thrift.FileSystemMasterClientService.getNewBlockIdForFile_result
 
getFieldValue(FileSystemMasterClientService.getStatus_args._Fields) - Method in class alluxio.thrift.FileSystemMasterClientService.getStatus_args
 
getFieldValue(FileSystemMasterClientService.getStatus_result._Fields) - Method in class alluxio.thrift.FileSystemMasterClientService.getStatus_result
 
getFieldValue(FileSystemMasterClientService.listStatus_args._Fields) - Method in class alluxio.thrift.FileSystemMasterClientService.listStatus_args
 
getFieldValue(FileSystemMasterClientService.listStatus_result._Fields) - Method in class alluxio.thrift.FileSystemMasterClientService.listStatus_result
 
getFieldValue(FileSystemMasterClientService.loadMetadata_args._Fields) - Method in class alluxio.thrift.FileSystemMasterClientService.loadMetadata_args
 
getFieldValue(FileSystemMasterClientService.loadMetadata_result._Fields) - Method in class alluxio.thrift.FileSystemMasterClientService.loadMetadata_result
 
getFieldValue(FileSystemMasterClientService.mount_args._Fields) - Method in class alluxio.thrift.FileSystemMasterClientService.mount_args
 
getFieldValue(FileSystemMasterClientService.mount_result._Fields) - Method in class alluxio.thrift.FileSystemMasterClientService.mount_result
 
getFieldValue(FileSystemMasterClientService.remove_args._Fields) - Method in class alluxio.thrift.FileSystemMasterClientService.remove_args
 
getFieldValue(FileSystemMasterClientService.remove_result._Fields) - Method in class alluxio.thrift.FileSystemMasterClientService.remove_result
 
getFieldValue(FileSystemMasterClientService.rename_args._Fields) - Method in class alluxio.thrift.FileSystemMasterClientService.rename_args
 
getFieldValue(FileSystemMasterClientService.rename_result._Fields) - Method in class alluxio.thrift.FileSystemMasterClientService.rename_result
 
getFieldValue(FileSystemMasterClientService.scheduleAsyncPersistence_args._Fields) - Method in class alluxio.thrift.FileSystemMasterClientService.scheduleAsyncPersistence_args
 
getFieldValue(FileSystemMasterClientService.scheduleAsyncPersistence_result._Fields) - Method in class alluxio.thrift.FileSystemMasterClientService.scheduleAsyncPersistence_result
 
getFieldValue(FileSystemMasterClientService.setAttribute_args._Fields) - Method in class alluxio.thrift.FileSystemMasterClientService.setAttribute_args
 
getFieldValue(FileSystemMasterClientService.setAttribute_result._Fields) - Method in class alluxio.thrift.FileSystemMasterClientService.setAttribute_result
 
getFieldValue(FileSystemMasterClientService.unmount_args._Fields) - Method in class alluxio.thrift.FileSystemMasterClientService.unmount_args
 
getFieldValue(FileSystemMasterClientService.unmount_result._Fields) - Method in class alluxio.thrift.FileSystemMasterClientService.unmount_result
 
getFieldValue(FileSystemMasterClientService.updateUfsMode_args._Fields) - Method in class alluxio.thrift.FileSystemMasterClientService.updateUfsMode_args
 
getFieldValue(FileSystemMasterClientService.updateUfsMode_result._Fields) - Method in class alluxio.thrift.FileSystemMasterClientService.updateUfsMode_result
 
getFieldValue(FileSystemMasterCommonTOptions._Fields) - Method in class alluxio.thrift.FileSystemMasterCommonTOptions
 
getFieldValue(FileSystemMasterWorkerService.fileSystemHeartbeat_args._Fields) - Method in class alluxio.thrift.FileSystemMasterWorkerService.fileSystemHeartbeat_args
 
getFieldValue(FileSystemMasterWorkerService.fileSystemHeartbeat_result._Fields) - Method in class alluxio.thrift.FileSystemMasterWorkerService.fileSystemHeartbeat_result
 
getFieldValue(FileSystemMasterWorkerService.getFileInfo_args._Fields) - Method in class alluxio.thrift.FileSystemMasterWorkerService.getFileInfo_args
 
getFieldValue(FileSystemMasterWorkerService.getFileInfo_result._Fields) - Method in class alluxio.thrift.FileSystemMasterWorkerService.getFileInfo_result
 
getFieldValue(FileSystemMasterWorkerService.getPinnedFileIds_args._Fields) - Method in class alluxio.thrift.FileSystemMasterWorkerService.getPinnedFileIds_args
 
getFieldValue(FileSystemMasterWorkerService.getPinnedFileIds_result._Fields) - Method in class alluxio.thrift.FileSystemMasterWorkerService.getPinnedFileIds_result
 
getFieldValue(FileSystemMasterWorkerService.getUfsInfo_args._Fields) - Method in class alluxio.thrift.FileSystemMasterWorkerService.getUfsInfo_args
 
getFieldValue(FileSystemMasterWorkerService.getUfsInfo_result._Fields) - Method in class alluxio.thrift.FileSystemMasterWorkerService.getUfsInfo_result
 
getFieldValue(FileSystemWorkerClientService.cancelUfsFile_args._Fields) - Method in class alluxio.thrift.FileSystemWorkerClientService.cancelUfsFile_args
 
getFieldValue(FileSystemWorkerClientService.cancelUfsFile_result._Fields) - Method in class alluxio.thrift.FileSystemWorkerClientService.cancelUfsFile_result
 
getFieldValue(FileSystemWorkerClientService.closeUfsFile_args._Fields) - Method in class alluxio.thrift.FileSystemWorkerClientService.closeUfsFile_args
 
getFieldValue(FileSystemWorkerClientService.closeUfsFile_result._Fields) - Method in class alluxio.thrift.FileSystemWorkerClientService.closeUfsFile_result
 
getFieldValue(FileSystemWorkerClientService.completeUfsFile_args._Fields) - Method in class alluxio.thrift.FileSystemWorkerClientService.completeUfsFile_args
 
getFieldValue(FileSystemWorkerClientService.completeUfsFile_result._Fields) - Method in class alluxio.thrift.FileSystemWorkerClientService.completeUfsFile_result
 
getFieldValue(FileSystemWorkerClientService.createUfsFile_args._Fields) - Method in class alluxio.thrift.FileSystemWorkerClientService.createUfsFile_args
 
getFieldValue(FileSystemWorkerClientService.createUfsFile_result._Fields) - Method in class alluxio.thrift.FileSystemWorkerClientService.createUfsFile_result
 
getFieldValue(FileSystemWorkerClientService.openUfsFile_args._Fields) - Method in class alluxio.thrift.FileSystemWorkerClientService.openUfsFile_args
 
getFieldValue(FileSystemWorkerClientService.openUfsFile_result._Fields) - Method in class alluxio.thrift.FileSystemWorkerClientService.openUfsFile_result
 
getFieldValue(FileSystemWorkerClientService.sessionFileSystemHeartbeat_args._Fields) - Method in class alluxio.thrift.FileSystemWorkerClientService.sessionFileSystemHeartbeat_args
 
getFieldValue(FileSystemWorkerClientService.sessionFileSystemHeartbeat_result._Fields) - Method in class alluxio.thrift.FileSystemWorkerClientService.sessionFileSystemHeartbeat_result
 
getFieldValue(FreeTOptions._Fields) - Method in class alluxio.thrift.FreeTOptions
 
getFieldValue(FreeTResponse._Fields) - Method in class alluxio.thrift.FreeTResponse
 
getFieldValue(GetBlockInfoTOptions._Fields) - Method in class alluxio.thrift.GetBlockInfoTOptions
 
getFieldValue(GetBlockInfoTResponse._Fields) - Method in class alluxio.thrift.GetBlockInfoTResponse
 
getFieldValue(GetBlockMasterInfoTOptions._Fields) - Method in class alluxio.thrift.GetBlockMasterInfoTOptions
 
getFieldValue(GetBlockMasterInfoTResponse._Fields) - Method in class alluxio.thrift.GetBlockMasterInfoTResponse
 
getFieldValue(GetCapacityBytesTOptions._Fields) - Method in class alluxio.thrift.GetCapacityBytesTOptions
 
getFieldValue(GetCapacityBytesTResponse._Fields) - Method in class alluxio.thrift.GetCapacityBytesTResponse
 
getFieldValue(GetConfigReportTOptions._Fields) - Method in class alluxio.thrift.GetConfigReportTOptions
 
getFieldValue(GetConfigReportTResponse._Fields) - Method in class alluxio.thrift.GetConfigReportTResponse
 
getFieldValue(GetConfigurationTOptions._Fields) - Method in class alluxio.thrift.GetConfigurationTOptions
 
getFieldValue(GetConfigurationTResponse._Fields) - Method in class alluxio.thrift.GetConfigurationTResponse
 
getFieldValue(GetFileInfoTOptions._Fields) - Method in class alluxio.thrift.GetFileInfoTOptions
 
getFieldValue(GetFileInfoTResponse._Fields) - Method in class alluxio.thrift.GetFileInfoTResponse
 
getFieldValue(GetFilePathTOptions._Fields) - Method in class alluxio.thrift.GetFilePathTOptions
 
getFieldValue(GetFilePathTResponse._Fields) - Method in class alluxio.thrift.GetFilePathTResponse
 
getFieldValue(GetLineageInfoListTOptions._Fields) - Method in class alluxio.thrift.GetLineageInfoListTOptions
 
getFieldValue(GetLineageInfoListTResponse._Fields) - Method in class alluxio.thrift.GetLineageInfoListTResponse
 
getFieldValue(GetMasterIdTOptions._Fields) - Method in class alluxio.thrift.GetMasterIdTOptions
 
getFieldValue(GetMasterIdTResponse._Fields) - Method in class alluxio.thrift.GetMasterIdTResponse
 
getFieldValue(GetMasterInfoTOptions._Fields) - Method in class alluxio.thrift.GetMasterInfoTOptions
 
getFieldValue(GetMasterInfoTResponse._Fields) - Method in class alluxio.thrift.GetMasterInfoTResponse
 
getFieldValue(GetMetricsTOptions._Fields) - Method in class alluxio.thrift.GetMetricsTOptions
 
getFieldValue(GetMetricsTResponse._Fields) - Method in class alluxio.thrift.GetMetricsTResponse
 
getFieldValue(GetMountTableTResponse._Fields) - Method in class alluxio.thrift.GetMountTableTResponse
 
getFieldValue(GetNewBlockIdForFileTOptions._Fields) - Method in class alluxio.thrift.GetNewBlockIdForFileTOptions
 
getFieldValue(GetNewBlockIdForFileTResponse._Fields) - Method in class alluxio.thrift.GetNewBlockIdForFileTResponse
 
getFieldValue(GetNextKeysTOptions._Fields) - Method in class alluxio.thrift.GetNextKeysTOptions
 
getFieldValue(GetNextKeysTResponse._Fields) - Method in class alluxio.thrift.GetNextKeysTResponse
 
getFieldValue(GetPartitionInfoTOptions._Fields) - Method in class alluxio.thrift.GetPartitionInfoTOptions
 
getFieldValue(GetPartitionInfoTResponse._Fields) - Method in class alluxio.thrift.GetPartitionInfoTResponse
 
getFieldValue(GetPinnedFileIdsTOptions._Fields) - Method in class alluxio.thrift.GetPinnedFileIdsTOptions
 
getFieldValue(GetPinnedFileIdsTResponse._Fields) - Method in class alluxio.thrift.GetPinnedFileIdsTResponse
 
getFieldValue(GetServiceVersionTOptions._Fields) - Method in class alluxio.thrift.GetServiceVersionTOptions
 
getFieldValue(GetServiceVersionTResponse._Fields) - Method in class alluxio.thrift.GetServiceVersionTResponse
 
getFieldValue(GetSizeTOptions._Fields) - Method in class alluxio.thrift.GetSizeTOptions
 
getFieldValue(GetSizeTResponse._Fields) - Method in class alluxio.thrift.GetSizeTResponse
 
getFieldValue(GetStatusTOptions._Fields) - Method in class alluxio.thrift.GetStatusTOptions
 
getFieldValue(GetStatusTResponse._Fields) - Method in class alluxio.thrift.GetStatusTResponse
 
getFieldValue(GetTOptions._Fields) - Method in class alluxio.thrift.GetTOptions
 
getFieldValue(GetTResponse._Fields) - Method in class alluxio.thrift.GetTResponse
 
getFieldValue(GetUfsInfoTOptions._Fields) - Method in class alluxio.thrift.GetUfsInfoTOptions
 
getFieldValue(GetUfsInfoTResponse._Fields) - Method in class alluxio.thrift.GetUfsInfoTResponse
 
getFieldValue(GetUsedBytesTOptions._Fields) - Method in class alluxio.thrift.GetUsedBytesTOptions
 
getFieldValue(GetUsedBytesTResponse._Fields) - Method in class alluxio.thrift.GetUsedBytesTResponse
 
getFieldValue(GetWorkerIdTOptions._Fields) - Method in class alluxio.thrift.GetWorkerIdTOptions
 
getFieldValue(GetWorkerIdTResponse._Fields) - Method in class alluxio.thrift.GetWorkerIdTResponse
 
getFieldValue(GetWorkerInfoListTOptions._Fields) - Method in class alluxio.thrift.GetWorkerInfoListTOptions
 
getFieldValue(GetWorkerInfoListTResponse._Fields) - Method in class alluxio.thrift.GetWorkerInfoListTResponse
 
getFieldValue(GetWorkerReportTOptions._Fields) - Method in class alluxio.thrift.GetWorkerReportTOptions
 
getFieldValue(InconsistentProperty._Fields) - Method in class alluxio.thrift.InconsistentProperty
 
getFieldValue(JobConfInfo._Fields) - Method in class alluxio.thrift.JobConfInfo
 
getFieldValue(KeyValueMasterClientService.completePartition_args._Fields) - Method in class alluxio.thrift.KeyValueMasterClientService.completePartition_args
 
getFieldValue(KeyValueMasterClientService.completePartition_result._Fields) - Method in class alluxio.thrift.KeyValueMasterClientService.completePartition_result
 
getFieldValue(KeyValueMasterClientService.completeStore_args._Fields) - Method in class alluxio.thrift.KeyValueMasterClientService.completeStore_args
 
getFieldValue(KeyValueMasterClientService.completeStore_result._Fields) - Method in class alluxio.thrift.KeyValueMasterClientService.completeStore_result
 
getFieldValue(KeyValueMasterClientService.createStore_args._Fields) - Method in class alluxio.thrift.KeyValueMasterClientService.createStore_args
 
getFieldValue(KeyValueMasterClientService.createStore_result._Fields) - Method in class alluxio.thrift.KeyValueMasterClientService.createStore_result
 
getFieldValue(KeyValueMasterClientService.deleteStore_args._Fields) - Method in class alluxio.thrift.KeyValueMasterClientService.deleteStore_args
 
getFieldValue(KeyValueMasterClientService.deleteStore_result._Fields) - Method in class alluxio.thrift.KeyValueMasterClientService.deleteStore_result
 
getFieldValue(KeyValueMasterClientService.getPartitionInfo_args._Fields) - Method in class alluxio.thrift.KeyValueMasterClientService.getPartitionInfo_args
 
getFieldValue(KeyValueMasterClientService.getPartitionInfo_result._Fields) - Method in class alluxio.thrift.KeyValueMasterClientService.getPartitionInfo_result
 
getFieldValue(KeyValueMasterClientService.mergeStore_args._Fields) - Method in class alluxio.thrift.KeyValueMasterClientService.mergeStore_args
 
getFieldValue(KeyValueMasterClientService.mergeStore_result._Fields) - Method in class alluxio.thrift.KeyValueMasterClientService.mergeStore_result
 
getFieldValue(KeyValueMasterClientService.renameStore_args._Fields) - Method in class alluxio.thrift.KeyValueMasterClientService.renameStore_args
 
getFieldValue(KeyValueMasterClientService.renameStore_result._Fields) - Method in class alluxio.thrift.KeyValueMasterClientService.renameStore_result
 
getFieldValue(KeyValueWorkerClientService.get_args._Fields) - Method in class alluxio.thrift.KeyValueWorkerClientService.get_args
 
getFieldValue(KeyValueWorkerClientService.get_result._Fields) - Method in class alluxio.thrift.KeyValueWorkerClientService.get_result
 
getFieldValue(KeyValueWorkerClientService.getNextKeys_args._Fields) - Method in class alluxio.thrift.KeyValueWorkerClientService.getNextKeys_args
 
getFieldValue(KeyValueWorkerClientService.getNextKeys_result._Fields) - Method in class alluxio.thrift.KeyValueWorkerClientService.getNextKeys_result
 
getFieldValue(KeyValueWorkerClientService.getSize_args._Fields) - Method in class alluxio.thrift.KeyValueWorkerClientService.getSize_args
 
getFieldValue(KeyValueWorkerClientService.getSize_result._Fields) - Method in class alluxio.thrift.KeyValueWorkerClientService.getSize_result
 
getFieldValue(LineageInfo._Fields) - Method in class alluxio.thrift.LineageInfo
 
getFieldValue(LineageMasterClientService.createLineage_args._Fields) - Method in class alluxio.thrift.LineageMasterClientService.createLineage_args
 
getFieldValue(LineageMasterClientService.createLineage_result._Fields) - Method in class alluxio.thrift.LineageMasterClientService.createLineage_result
 
getFieldValue(LineageMasterClientService.deleteLineage_args._Fields) - Method in class alluxio.thrift.LineageMasterClientService.deleteLineage_args
 
getFieldValue(LineageMasterClientService.deleteLineage_result._Fields) - Method in class alluxio.thrift.LineageMasterClientService.deleteLineage_result
 
getFieldValue(LineageMasterClientService.getLineageInfoList_args._Fields) - Method in class alluxio.thrift.LineageMasterClientService.getLineageInfoList_args
 
getFieldValue(LineageMasterClientService.getLineageInfoList_result._Fields) - Method in class alluxio.thrift.LineageMasterClientService.getLineageInfoList_result
 
getFieldValue(LineageMasterClientService.reinitializeFile_args._Fields) - Method in class alluxio.thrift.LineageMasterClientService.reinitializeFile_args
 
getFieldValue(LineageMasterClientService.reinitializeFile_result._Fields) - Method in class alluxio.thrift.LineageMasterClientService.reinitializeFile_result
 
getFieldValue(LineageMasterClientService.reportLostFile_args._Fields) - Method in class alluxio.thrift.LineageMasterClientService.reportLostFile_args
 
getFieldValue(LineageMasterClientService.reportLostFile_result._Fields) - Method in class alluxio.thrift.LineageMasterClientService.reportLostFile_result
 
getFieldValue(ListStatusTOptions._Fields) - Method in class alluxio.thrift.ListStatusTOptions
 
getFieldValue(ListStatusTResponse._Fields) - Method in class alluxio.thrift.ListStatusTResponse
 
getFieldValue(LoadMetadataTOptions._Fields) - Method in class alluxio.thrift.LoadMetadataTOptions
 
getFieldValue(LoadMetadataTResponse._Fields) - Method in class alluxio.thrift.LoadMetadataTResponse
 
getFieldValue(LocalityTier._Fields) - Method in class alluxio.thrift.LocalityTier
 
getFieldValue(LockBlockTOptions._Fields) - Method in class alluxio.thrift.LockBlockTOptions
 
getFieldValue(LockBlockTResponse._Fields) - Method in class alluxio.thrift.LockBlockTResponse
 
getFieldValue(MasterHeartbeatTOptions._Fields) - Method in class alluxio.thrift.MasterHeartbeatTOptions
 
getFieldValue(MasterHeartbeatTResponse._Fields) - Method in class alluxio.thrift.MasterHeartbeatTResponse
 
getFieldValue(MasterInfo._Fields) - Method in class alluxio.thrift.MasterInfo
 
getFieldValue(MasterNetAddress._Fields) - Method in class alluxio.thrift.MasterNetAddress
 
getFieldValue(MergeStoreTOptions._Fields) - Method in class alluxio.thrift.MergeStoreTOptions
 
getFieldValue(MergeStoreTResponse._Fields) - Method in class alluxio.thrift.MergeStoreTResponse
 
getFieldValue(MetaMasterClientService.backup_args._Fields) - Method in class alluxio.thrift.MetaMasterClientService.backup_args
 
getFieldValue(MetaMasterClientService.backup_result._Fields) - Method in class alluxio.thrift.MetaMasterClientService.backup_result
 
getFieldValue(MetaMasterClientService.getConfigReport_args._Fields) - Method in class alluxio.thrift.MetaMasterClientService.getConfigReport_args
 
getFieldValue(MetaMasterClientService.getConfigReport_result._Fields) - Method in class alluxio.thrift.MetaMasterClientService.getConfigReport_result
 
getFieldValue(MetaMasterClientService.getConfiguration_args._Fields) - Method in class alluxio.thrift.MetaMasterClientService.getConfiguration_args
 
getFieldValue(MetaMasterClientService.getConfiguration_result._Fields) - Method in class alluxio.thrift.MetaMasterClientService.getConfiguration_result
 
getFieldValue(MetaMasterClientService.getMasterInfo_args._Fields) - Method in class alluxio.thrift.MetaMasterClientService.getMasterInfo_args
 
getFieldValue(MetaMasterClientService.getMasterInfo_result._Fields) - Method in class alluxio.thrift.MetaMasterClientService.getMasterInfo_result
 
getFieldValue(MetaMasterClientService.getMetrics_args._Fields) - Method in class alluxio.thrift.MetaMasterClientService.getMetrics_args
 
getFieldValue(MetaMasterClientService.getMetrics_result._Fields) - Method in class alluxio.thrift.MetaMasterClientService.getMetrics_result
 
getFieldValue(MetaMasterMasterService.getMasterId_args._Fields) - Method in class alluxio.thrift.MetaMasterMasterService.getMasterId_args
 
getFieldValue(MetaMasterMasterService.getMasterId_result._Fields) - Method in class alluxio.thrift.MetaMasterMasterService.getMasterId_result
 
getFieldValue(MetaMasterMasterService.masterHeartbeat_args._Fields) - Method in class alluxio.thrift.MetaMasterMasterService.masterHeartbeat_args
 
getFieldValue(MetaMasterMasterService.masterHeartbeat_result._Fields) - Method in class alluxio.thrift.MetaMasterMasterService.masterHeartbeat_result
 
getFieldValue(MetaMasterMasterService.registerMaster_args._Fields) - Method in class alluxio.thrift.MetaMasterMasterService.registerMaster_args
 
getFieldValue(MetaMasterMasterService.registerMaster_result._Fields) - Method in class alluxio.thrift.MetaMasterMasterService.registerMaster_result
 
getFieldValue(Metric._Fields) - Method in class alluxio.thrift.Metric
 
getFieldValue(MetricsHeartbeatTOptions._Fields) - Method in class alluxio.thrift.MetricsHeartbeatTOptions
 
getFieldValue(MetricsHeartbeatTResponse._Fields) - Method in class alluxio.thrift.MetricsHeartbeatTResponse
 
getFieldValue(MetricsMasterClientService.metricsHeartbeat_args._Fields) - Method in class alluxio.thrift.MetricsMasterClientService.metricsHeartbeat_args
 
getFieldValue(MetricsMasterClientService.metricsHeartbeat_result._Fields) - Method in class alluxio.thrift.MetricsMasterClientService.metricsHeartbeat_result
 
getFieldValue(MetricValue._Fields) - Method in class alluxio.thrift.MetricValue
 
getFieldValue(MountPointInfo._Fields) - Method in class alluxio.thrift.MountPointInfo
 
getFieldValue(MountTOptions._Fields) - Method in class alluxio.thrift.MountTOptions
 
getFieldValue(MountTResponse._Fields) - Method in class alluxio.thrift.MountTResponse
 
getFieldValue(OpenUfsFileTOptions._Fields) - Method in class alluxio.thrift.OpenUfsFileTOptions
 
getFieldValue(OpenUfsFileTResponse._Fields) - Method in class alluxio.thrift.OpenUfsFileTResponse
 
getFieldValue(OptionalString._Fields) - Method in class alluxio.thrift.OptionalString
 
getFieldValue(PartitionInfo._Fields) - Method in class alluxio.thrift.PartitionInfo
 
getFieldValue(PersistCommandOptions._Fields) - Method in class alluxio.thrift.PersistCommandOptions
 
getFieldValue(PersistFile._Fields) - Method in class alluxio.thrift.PersistFile
 
getFieldValue(PromoteBlockTOptions._Fields) - Method in class alluxio.thrift.PromoteBlockTOptions
 
getFieldValue(PromoteBlockTResponse._Fields) - Method in class alluxio.thrift.PromoteBlockTResponse
 
getFieldValue(RegisterMasterTOptions._Fields) - Method in class alluxio.thrift.RegisterMasterTOptions
 
getFieldValue(RegisterMasterTResponse._Fields) - Method in class alluxio.thrift.RegisterMasterTResponse
 
getFieldValue(RegisterWorkerTOptions._Fields) - Method in class alluxio.thrift.RegisterWorkerTOptions
 
getFieldValue(RegisterWorkerTResponse._Fields) - Method in class alluxio.thrift.RegisterWorkerTResponse
 
getFieldValue(ReinitializeFileTOptions._Fields) - Method in class alluxio.thrift.ReinitializeFileTOptions
 
getFieldValue(ReinitializeFileTResponse._Fields) - Method in class alluxio.thrift.ReinitializeFileTResponse
 
getFieldValue(RemoveBlockTOptions._Fields) - Method in class alluxio.thrift.RemoveBlockTOptions
 
getFieldValue(RemoveBlockTResponse._Fields) - Method in class alluxio.thrift.RemoveBlockTResponse
 
getFieldValue(RenameStoreTOptions._Fields) - Method in class alluxio.thrift.RenameStoreTOptions
 
getFieldValue(RenameStoreTResponse._Fields) - Method in class alluxio.thrift.RenameStoreTResponse
 
getFieldValue(RenameTOptions._Fields) - Method in class alluxio.thrift.RenameTOptions
 
getFieldValue(RenameTResponse._Fields) - Method in class alluxio.thrift.RenameTResponse
 
getFieldValue(ReportLostFileTOptions._Fields) - Method in class alluxio.thrift.ReportLostFileTOptions
 
getFieldValue(ReportLostFileTResponse._Fields) - Method in class alluxio.thrift.ReportLostFileTResponse
 
getFieldValue(RequestBlockLocationTOptions._Fields) - Method in class alluxio.thrift.RequestBlockLocationTOptions
 
getFieldValue(RequestBlockLocationTResponse._Fields) - Method in class alluxio.thrift.RequestBlockLocationTResponse
 
getFieldValue(RequestSpaceTOptions._Fields) - Method in class alluxio.thrift.RequestSpaceTOptions
 
getFieldValue(RequestSpaceTResponse._Fields) - Method in class alluxio.thrift.RequestSpaceTResponse
 
getFieldValue(ScheduleAsyncPersistenceTOptions._Fields) - Method in class alluxio.thrift.ScheduleAsyncPersistenceTOptions
 
getFieldValue(ScheduleAsyncPersistenceTResponse._Fields) - Method in class alluxio.thrift.ScheduleAsyncPersistenceTResponse
 
getFieldValue(SessionBlockHeartbeatTOptions._Fields) - Method in class alluxio.thrift.SessionBlockHeartbeatTOptions
 
getFieldValue(SessionBlockHeartbeatTResponse._Fields) - Method in class alluxio.thrift.SessionBlockHeartbeatTResponse
 
getFieldValue(SessionFileSystemHeartbeatTOptions._Fields) - Method in class alluxio.thrift.SessionFileSystemHeartbeatTOptions
 
getFieldValue(SessionFileSystemHeartbeatTResponse._Fields) - Method in class alluxio.thrift.SessionFileSystemHeartbeatTResponse
 
getFieldValue(SetAttributeTOptions._Fields) - Method in class alluxio.thrift.SetAttributeTOptions
 
getFieldValue(SetAttributeTResponse._Fields) - Method in class alluxio.thrift.SetAttributeTResponse
 
getFieldValue(SyncMetadataTOptions._Fields) - Method in class alluxio.thrift.SyncMetadataTOptions
 
getFieldValue(SyncMetadataTResponse._Fields) - Method in class alluxio.thrift.SyncMetadataTResponse
 
getFieldValue(TieredIdentity._Fields) - Method in class alluxio.thrift.TieredIdentity
 
getFieldValue(UfsInfo._Fields) - Method in class alluxio.thrift.UfsInfo
 
getFieldValue(UnlockBlockTOptions._Fields) - Method in class alluxio.thrift.UnlockBlockTOptions
 
getFieldValue(UnlockBlockTResponse._Fields) - Method in class alluxio.thrift.UnlockBlockTResponse
 
getFieldValue(UnmountTOptions._Fields) - Method in class alluxio.thrift.UnmountTOptions
 
getFieldValue(UnmountTResponse._Fields) - Method in class alluxio.thrift.UnmountTResponse
 
getFieldValue(UpdateUfsModeTOptions._Fields) - Method in class alluxio.thrift.UpdateUfsModeTOptions
 
getFieldValue(UpdateUfsModeTResponse._Fields) - Method in class alluxio.thrift.UpdateUfsModeTResponse
 
getFieldValue(WorkerInfo._Fields) - Method in class alluxio.thrift.WorkerInfo
 
getFieldValue(WorkerNetAddress._Fields) - Method in class alluxio.thrift.WorkerNetAddress
 
getFileBlockInfoList(AlluxioURI) - Method in class alluxio.master.file.DefaultFileSystemMaster
 
getFileBlockInfoList(AlluxioURI) - Method in interface alluxio.master.file.FileSystemMaster
Gets the FileBlockInfo for all blocks of a file.
getFileBlockInfoList(AlluxioURI) - Method in class alluxio.master.file.meta.FileSystemMasterView
 
getFileBlockInfos() - Method in class alluxio.client.file.URIStatus
 
getFileBlockInfos() - Method in class alluxio.thrift.FileInfo
 
getFileBlockInfos() - Method in class alluxio.wire.FileInfo
 
getFileBlockInfosIterator() - Method in class alluxio.thrift.FileInfo
 
getFileBlockInfosSize() - Method in class alluxio.thrift.FileInfo
 
getFileId() - Method in class alluxio.client.file.URIStatus
 
getFileId(long) - Static method in class alluxio.master.block.BlockId
 
getFileId(AlluxioURI) - Method in class alluxio.master.file.DefaultFileSystemMaster
 
getFileId(AlluxioURI) - Method in interface alluxio.master.file.FileSystemMaster
Returns the file id for a given path.
getFileId(AlluxioURI) - Method in class alluxio.master.file.meta.FileSystemMasterView
Returns the file id for a given path.
getFileId() - Method in class alluxio.proto.journal.File.AsyncPersistRequestEntry.Builder
optional int64 file_id = 1;
getFileId() - Method in class alluxio.proto.journal.File.AsyncPersistRequestEntry
optional int64 file_id = 1;
getFileId() - Method in interface alluxio.proto.journal.File.AsyncPersistRequestEntryOrBuilder
optional int64 file_id = 1;
getFileId() - Method in class alluxio.thrift.FileInfo
 
getFileId() - Method in class alluxio.thrift.FileSystemMasterWorkerService.getFileInfo_args
the id of the file
getFileId() - Method in class alluxio.thrift.GetFilePathTOptions
 
getFileId() - Method in class alluxio.thrift.PersistFile
 
getFileId() - Method in class alluxio.wire.FileInfo
 
getFileInfo(long) - Method in class alluxio.master.file.DefaultFileSystemMaster
 
getFileInfo(AlluxioURI, GetStatusOptions) - Method in class alluxio.master.file.DefaultFileSystemMaster
 
getFileInfo(long) - Method in interface alluxio.master.file.FileSystemMaster
Returns the FileInfo for a given file id.
getFileInfo(AlluxioURI, GetStatusOptions) - Method in interface alluxio.master.file.FileSystemMaster
Returns the FileInfo for a given path.
getFileInfo(long, GetFileInfoTOptions) - Method in class alluxio.master.file.FileSystemMasterWorkerServiceHandler
 
getFileInfo(long) - Method in class alluxio.master.file.meta.FileSystemMasterView
Returns the FileInfo for a given path.
getFileInfo(long, GetFileInfoTOptions, AsyncMethodCallback) - Method in class alluxio.thrift.FileSystemMasterWorkerService.AsyncClient
 
getFileInfo(long, GetFileInfoTOptions, AsyncMethodCallback) - Method in interface alluxio.thrift.FileSystemMasterWorkerService.AsyncIface
 
getFileInfo() - Constructor for class alluxio.thrift.FileSystemMasterWorkerService.AsyncProcessor.getFileInfo
 
getFileInfo(long, GetFileInfoTOptions) - Method in class alluxio.thrift.FileSystemMasterWorkerService.Client
 
getFileInfo(long, GetFileInfoTOptions) - Method in interface alluxio.thrift.FileSystemMasterWorkerService.Iface
 
getFileInfo() - Constructor for class alluxio.thrift.FileSystemMasterWorkerService.Processor.getFileInfo
 
getFileInfo() - Method in class alluxio.thrift.GetFileInfoTResponse
 
getFileInfo() - Method in class alluxio.thrift.GetStatusTResponse
 
getFileInfo(long) - Method in interface alluxio.worker.block.BlockWorker
Gets the file information.
getFileInfo(long) - Method in class alluxio.worker.block.DefaultBlockWorker
 
getFileInfo(long) - Method in class alluxio.worker.file.FileSystemMasterClient
 
getFileInfo_args() - Constructor for class alluxio.thrift.FileSystemMasterWorkerService.getFileInfo_args
 
getFileInfo_args(long, GetFileInfoTOptions) - Constructor for class alluxio.thrift.FileSystemMasterWorkerService.getFileInfo_args
 
getFileInfo_args(FileSystemMasterWorkerService.getFileInfo_args) - Constructor for class alluxio.thrift.FileSystemMasterWorkerService.getFileInfo_args
Performs a deep copy on other.
getFileInfo_call(long, GetFileInfoTOptions, AsyncMethodCallback, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class alluxio.thrift.FileSystemMasterWorkerService.AsyncClient.getFileInfo_call
 
getFileInfo_result() - Constructor for class alluxio.thrift.FileSystemMasterWorkerService.getFileInfo_result
 
getFileInfo_result(GetFileInfoTResponse, AlluxioTException) - Constructor for class alluxio.thrift.FileSystemMasterWorkerService.getFileInfo_result
 
getFileInfo_result(FileSystemMasterWorkerService.getFileInfo_result) - Constructor for class alluxio.thrift.FileSystemMasterWorkerService.getFileInfo_result
Performs a deep copy on other.
getFileInfoList() - Method in class alluxio.thrift.ListStatusTResponse
 
getFileInfoListIterator() - Method in class alluxio.thrift.ListStatusTResponse
 
getFileInfoListSize() - Method in class alluxio.thrift.ListStatusTResponse
 
GetFileInfoTOptions - Class in alluxio.thrift
 
GetFileInfoTOptions() - Constructor for class alluxio.thrift.GetFileInfoTOptions
 
GetFileInfoTOptions(GetFileInfoTOptions) - Constructor for class alluxio.thrift.GetFileInfoTOptions
Performs a deep copy on other.
GetFileInfoTOptions._Fields - Enum in alluxio.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
GetFileInfoTResponse - Class in alluxio.thrift
 
GetFileInfoTResponse() - Constructor for class alluxio.thrift.GetFileInfoTResponse
 
GetFileInfoTResponse(FileInfo) - Constructor for class alluxio.thrift.GetFileInfoTResponse
 
GetFileInfoTResponse(GetFileInfoTResponse) - Constructor for class alluxio.thrift.GetFileInfoTResponse
Performs a deep copy on other.
GetFileInfoTResponse._Fields - Enum in alluxio.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
getFileLocations(String) - Method in class alluxio.underfs.hdfs.HdfsUnderFileSystem
 
getFileLocations(String, FileLocationOptions) - Method in class alluxio.underfs.hdfs.HdfsUnderFileSystem
 
getFileLocations(String) - Method in class alluxio.underfs.local.LocalUnderFileSystem
 
getFileLocations(String, FileLocationOptions) - Method in class alluxio.underfs.local.LocalUnderFileSystem
 
getFileLocations(String) - Method in class alluxio.underfs.ObjectUnderFileSystem
 
getFileLocations(String, FileLocationOptions) - Method in class alluxio.underfs.ObjectUnderFileSystem
 
getFileLocations(String) - Method in interface alluxio.underfs.UnderFileSystem
Gets the list of locations of the indicated path.
getFileLocations(String, FileLocationOptions) - Method in interface alluxio.underfs.UnderFileSystem
Gets the list of locations of the indicated path given options.
getFileLocations(String) - Method in class alluxio.underfs.UnderFileSystemWithLogging
 
getFileLocations(String, FileLocationOptions) - Method in class alluxio.underfs.UnderFileSystemWithLogging
 
getFileLocations(String) - Method in class alluxio.underfs.wasb.WasbUnderFileSystem
 
getFileLocations(String, FileLocationOptions) - Method in class alluxio.underfs.wasb.WasbUnderFileSystem
 
getFileLocations() - Method in class alluxio.web.UIFileInfo
 
getFilePath(String) - Static method in class alluxio.cli.fs.FileSystemShellUtils
Removes Constants.HEADER / Constants.HEADER_FT and hostname:port information from a path, leaving only the local file path.
getFilePath(GetFilePathTOptions) - Method in interface alluxio.client.file.FileSystemMasterClient
 
getFilePath(GetFilePathTOptions) - Method in class alluxio.client.file.RetryHandlingFileSystemMasterClient
 
getFilePath(GetFilePathTOptions) - Method in class alluxio.master.file.FileSystemMasterClientServiceHandler
 
getFilePath(GetFilePathTOptions, AsyncMethodCallback) - Method in class alluxio.thrift.FileSystemMasterClientService.AsyncClient
 
getFilePath(GetFilePathTOptions, AsyncMethodCallback) - Method in interface alluxio.thrift.FileSystemMasterClientService.AsyncIface
 
getFilePath() - Constructor for class alluxio.thrift.FileSystemMasterClientService.AsyncProcessor.getFilePath
 
getFilePath(GetFilePathTOptions) - Method in class alluxio.thrift.FileSystemMasterClientService.Client
 
getFilePath(GetFilePathTOptions) - Method in interface alluxio.thrift.FileSystemMasterClientService.Iface
Returns the file path of a file id.
getFilePath() - Constructor for class alluxio.thrift.FileSystemMasterClientService.Processor.getFilePath
 
getFilePath() - Method in class alluxio.worker.block.io.LocalFileBlockReader
 
getFilePath_args() - Constructor for class alluxio.thrift.FileSystemMasterClientService.getFilePath_args
 
getFilePath_args(GetFilePathTOptions) - Constructor for class alluxio.thrift.FileSystemMasterClientService.getFilePath_args
 
getFilePath_args(FileSystemMasterClientService.getFilePath_args) - Constructor for class alluxio.thrift.FileSystemMasterClientService.getFilePath_args
Performs a deep copy on other.
getFilePath_call(GetFilePathTOptions, AsyncMethodCallback, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class alluxio.thrift.FileSystemMasterClientService.AsyncClient.getFilePath_call
 
getFilePath_result() - Constructor for class alluxio.thrift.FileSystemMasterClientService.getFilePath_result
 
getFilePath_result(GetFilePathTResponse, AlluxioTException) - Constructor for class alluxio.thrift.FileSystemMasterClientService.getFilePath_result
 
getFilePath_result(FileSystemMasterClientService.getFilePath_result) - Constructor for class alluxio.thrift.FileSystemMasterClientService.getFilePath_result
Performs a deep copy on other.
GetFilePathTOptions - Class in alluxio.thrift
 
GetFilePathTOptions() - Constructor for class alluxio.thrift.GetFilePathTOptions
 
GetFilePathTOptions(long) - Constructor for class alluxio.thrift.GetFilePathTOptions
 
GetFilePathTOptions(GetFilePathTOptions) - Constructor for class alluxio.thrift.GetFilePathTOptions
Performs a deep copy on other.
GetFilePathTOptions._Fields - Enum in alluxio.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
GetFilePathTResponse - Class in alluxio.thrift
 
GetFilePathTResponse() - Constructor for class alluxio.thrift.GetFilePathTResponse
 
GetFilePathTResponse(String) - Constructor for class alluxio.thrift.GetFilePathTResponse
 
GetFilePathTResponse(GetFilePathTResponse) - Constructor for class alluxio.thrift.GetFilePathTResponse
Performs a deep copy on other.
GetFilePathTResponse._Fields - Enum in alluxio.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
getFilePersistenceState(long) - Method in class alluxio.master.file.meta.FileSystemMasterView
Returns the persistence state of a given file.
getFiles(String) - Static method in class alluxio.cli.fs.FileSystemShellUtils
Gets the files (on the local filesystem) that match the given input path.
getFileStatus(String) - Method in class alluxio.underfs.hdfs.HdfsUnderFileSystem
 
getFileStatus(String) - Method in class alluxio.underfs.local.LocalUnderFileSystem
 
getFileStatus(String) - Method in class alluxio.underfs.ObjectUnderFileSystem
 
getFileStatus(String) - Method in interface alluxio.underfs.UnderFileSystem
Gets the file status.
getFileStatus(String) - Method in class alluxio.underfs.UnderFileSystemWithLogging
 
getFileSystemClient() - Method in class alluxio.multi.process.MultiProcessCluster
 
getFileSystemMasterView() - Method in class alluxio.master.file.DefaultFileSystemMaster
 
getFileSystemMasterView() - Method in interface alluxio.master.file.FileSystemMaster
 
getFilter() - Method in class alluxio.thrift.GetBlockMasterInfoTOptions
 
getFilter() - Method in class alluxio.thrift.GetMasterInfoTOptions
 
getFilterIterator() - Method in class alluxio.thrift.GetBlockMasterInfoTOptions
 
getFilterIterator() - Method in class alluxio.thrift.GetMasterInfoTOptions
 
getFilters() - Method in class alluxio.metrics.aggregator.SingleTagValueAggregator
 
getFilters() - Method in class alluxio.metrics.aggregator.SumInstancesAggregator
 
getFilters() - Method in interface alluxio.metrics.MetricsAggregator
 
getFilters() - Method in interface alluxio.metrics.MultiValueMetricsAggregator
 
getFilterSize() - Method in class alluxio.thrift.GetBlockMasterInfoTOptions
 
getFilterSize() - Method in class alluxio.thrift.GetMasterInfoTOptions
 
getFingerprint(String) - Method in class alluxio.underfs.BaseUnderFileSystem
 
getFingerprint(String) - Method in interface alluxio.underfs.UnderFileSystem
Computes and returns a fingerprint for the path.
getFingerprint(String) - Method in class alluxio.underfs.UnderFileSystemWithLogging
 
getFirst(Object) - Method in interface alluxio.collections.FieldIndex
Gets an object from the set of objects with the specified field value.
getFirst(Object) - Method in class alluxio.collections.NonUniqueFieldIndex
 
getFirst() - Method in class alluxio.collections.Pair
 
getFirst(Object) - Method in class alluxio.collections.UniqueFieldIndex
 
getFirstByField(IndexDefinition<T>, Object) - Method in class alluxio.collections.IndexedSet
Gets the object from the set of objects with the specified field value.
getFloat(PropertyKey) - Method in interface alluxio.AlluxioConfiguration
Gets the float representation of the value for the given key.
getFloat(PropertyKey) - Method in class alluxio.conf.InstancedConfiguration
 
getFloat(PropertyKey) - Static method in class alluxio.Configuration
Gets the float representation of the value for the given key.
getFolderSuffix() - Method in class alluxio.underfs.cos.COSUnderFileSystem
 
getFolderSuffix() - Method in class alluxio.underfs.gcs.GCSUnderFileSystem
 
getFolderSuffix() - Method in class alluxio.underfs.ObjectUnderFileSystem
Get suffix used to encode a directory.
getFolderSuffix() - Method in class alluxio.underfs.oss.OSSUnderFileSystem
 
getFolderSuffix() - Method in class alluxio.underfs.s3a.S3AUnderFileSystem
 
getFolderSuffix() - Method in class alluxio.underfs.swift.SwiftUnderFileSystem
 
getFqdnHost(InetSocketAddress) - Static method in class alluxio.util.network.NetworkAddressUtils
Gets FQDN(Full Qualified Domain Name) from Java representations of network address, except String representation which should be handled by NetworkAddressUtils.resolveHostName(String) which will handle the situation where hostname is null.
getFqdnHost(WorkerNetAddress) - Static method in class alluxio.util.network.NetworkAddressUtils
Gets FQDN(Full Qualified Domain Name) from Alluxio representation of network address.
getFreeBytes() - Method in class alluxio.master.meta.AlluxioMasterRestServiceHandler
Deprecated.
since version 1.4 and will be removed in version 2.0
getFreeBytes() - Method in class alluxio.thrift.BlockMasterInfo
 
getFreeBytes() - Method in class alluxio.wire.BlockMasterInfo
 
getFreeBytesOnTiers() - Method in class alluxio.master.block.meta.MasterWorkerInfo
 
getFreeCapacity() - Method in class alluxio.web.WebInterfaceGeneralServlet.StorageTierInfo
 
getFreeSpacePercent() - Method in class alluxio.web.WebInterfaceGeneralServlet.StorageTierInfo
 
getFreeSpacePercent() - Method in class alluxio.web.WebInterfaceWorkersServlet.NodeInfo
 
getFrom(int) - Method in class alluxio.underfs.swift.MidPartLongRange
 
getFromPath() - Method in class alluxio.thrift.KeyValueMasterClientService.mergeStore_args
the path of the store to be merged
getFromStoreId() - Method in class alluxio.proto.journal.KeyValue.MergeStoreEntry.Builder
optional int64 from_store_id = 1;
getFromStoreId() - Method in class alluxio.proto.journal.KeyValue.MergeStoreEntry
optional int64 from_store_id = 1;
getFromStoreId() - Method in interface alluxio.proto.journal.KeyValue.MergeStoreEntryOrBuilder
optional int64 from_store_id = 1;
getFsClient() - Method in class alluxio.cli.fsadmin.command.Context
 
getFsType() - Method in class alluxio.util.UnixMountInfo
 
getFullMetricName() - Method in class alluxio.metrics.Metric
 
getGcExecutor() - Method in class alluxio.resource.DynamicResourcePool.Options
 
getGcIntervalMs() - Method in class alluxio.resource.DynamicResourcePool.Options
 
getGid(String) - Static method in class alluxio.fuse.AlluxioFuseUtils
Retrieves the primary gid of the given user.
getGidFromGroupName(String) - Static method in class alluxio.fuse.AlluxioFuseUtils
Retrieves the gid of the given group.
getGlobalStorageTierAssoc() - Method in interface alluxio.master.block.BlockMaster
 
getGlobalStorageTierAssoc() - Method in class alluxio.master.block.DefaultBlockMaster
 
getGroup() - Method in class alluxio.client.file.options.CompleteUfsFileOptions
 
getGroup() - Method in class alluxio.client.file.options.CreateUfsFileOptions
 
getGroup() - Method in class alluxio.client.file.options.OutStreamOptions
 
getGroup() - Method in class alluxio.client.file.options.SetAttributeOptions
 
getGroup() - Method in class alluxio.client.file.URIStatus
 
getGroup() - Method in class alluxio.master.file.meta.Inode
 
getGroup() - Method in class alluxio.master.file.options.CreatePathOptions
 
getGroup() - Method in class alluxio.master.file.options.SetAttributeOptions
 
getGroup() - Method in class alluxio.proto.dataserver.Protocol.CreateUfsFileOptions.Builder
optional string group = 3;
getGroup() - Method in class alluxio.proto.dataserver.Protocol.CreateUfsFileOptions
optional string group = 3;
getGroup() - Method in interface alluxio.proto.dataserver.Protocol.CreateUfsFileOptionsOrBuilder
optional string group = 3;
getGroup() - Method in class alluxio.proto.journal.File.InodeDirectoryEntry.Builder
optional string group = 9;
getGroup() - Method in class alluxio.proto.journal.File.InodeDirectoryEntry
optional string group = 9;
getGroup() - Method in interface alluxio.proto.journal.File.InodeDirectoryEntryOrBuilder
optional string group = 9;
getGroup() - Method in class alluxio.proto.journal.File.InodeFileEntry.Builder
optional string group = 15;
getGroup() - Method in class alluxio.proto.journal.File.InodeFileEntry
optional string group = 15;
getGroup() - Method in interface alluxio.proto.journal.File.InodeFileEntryOrBuilder
optional string group = 15;
getGroup() - Method in class alluxio.proto.journal.File.SetAttributeEntry.Builder
optional string group = 7;
getGroup() - Method in class alluxio.proto.journal.File.SetAttributeEntry
optional string group = 7;
getGroup() - Method in interface alluxio.proto.journal.File.SetAttributeEntryOrBuilder
optional string group = 7;
getGroup() - Method in class alluxio.thrift.CompleteUfsFileTOptions
 
getGroup() - Method in class alluxio.thrift.CreateUfsFileTOptions
 
getGroup() - Method in class alluxio.thrift.FileInfo
 
getGroup() - Method in class alluxio.thrift.SetAttributeTOptions
 
getGroup() - Method in class alluxio.underfs.ObjectUnderFileSystem.ObjectPermissions
 
getGroup() - Method in class alluxio.underfs.options.CreateOptions
 
getGroup() - Method in class alluxio.underfs.options.MkdirsOptions
 
getGroup() - Method in class alluxio.underfs.UfsStatus
Gets the group of the given path.
getGroup() - Method in class alluxio.web.UIFileInfo
 
getGroup() - Method in class alluxio.wire.FileInfo
 
getGroupBits() - Method in class alluxio.security.authorization.Mode
 
getGroupBytes() - Method in class alluxio.proto.dataserver.Protocol.CreateUfsFileOptions.Builder
optional string group = 3;
getGroupBytes() - Method in class alluxio.proto.dataserver.Protocol.CreateUfsFileOptions
optional string group = 3;
getGroupBytes() - Method in interface alluxio.proto.dataserver.Protocol.CreateUfsFileOptionsOrBuilder
optional string group = 3;
getGroupBytes() - Method in class alluxio.proto.journal.File.InodeDirectoryEntry.Builder
optional string group = 9;
getGroupBytes() - Method in class alluxio.proto.journal.File.InodeDirectoryEntry
optional string group = 9;
getGroupBytes() - Method in interface alluxio.proto.journal.File.InodeDirectoryEntryOrBuilder
optional string group = 9;
getGroupBytes() - Method in class alluxio.proto.journal.File.InodeFileEntry.Builder
optional string group = 15;
getGroupBytes() - Method in class alluxio.proto.journal.File.InodeFileEntry
optional string group = 15;
getGroupBytes() - Method in interface alluxio.proto.journal.File.InodeFileEntryOrBuilder
optional string group = 15;
getGroupBytes() - Method in class alluxio.proto.journal.File.SetAttributeEntry.Builder
optional string group = 7;
getGroupBytes() - Method in class alluxio.proto.journal.File.SetAttributeEntry
optional string group = 7;
getGroupBytes() - Method in interface alluxio.proto.journal.File.SetAttributeEntryOrBuilder
optional string group = 7;
getGroupFromLoginModule() - Static method in class alluxio.util.SecurityUtils
 
getGroupFromThriftClient() - Static method in class alluxio.util.SecurityUtils
 
getGroupName(String) - Static method in class alluxio.fuse.AlluxioFuseUtils
Gets the primary group name from the user name.
getGroupName(long) - Static method in class alluxio.fuse.AlluxioFuseUtils
Gets the group name from the group id.
getGroups(String) - Method in class alluxio.security.group.CachedGroupMapping
Gets a list of groups for the given user.
getGroups(String) - Method in interface alluxio.security.group.GroupMappingService
Gets all various group memberships of a given user.
getGroups(String) - Method in class alluxio.security.group.provider.IdentityUserGroupsMapping
Returns list of groups for a user.
getGroups(String) - Method in class alluxio.security.group.provider.ShellBasedUnixGroupsMapping
Returns list of groups for a user.
getGroups(String) - Static method in class alluxio.util.CommonUtils
Using CachedGroupMapping to get the group list of a user.
getGroupsForUserCommand(String) - Static method in class alluxio.util.ShellUtils
Gets a Unix command to get a given user's groups list.
getHandler() - Method in class alluxio.metrics.sink.MetricsServlet
Gets the ServletContextHandler of the metrics servlet.
getHandler() - Method in class alluxio.metrics.sink.PrometheusMetricsServlet
Gets the ServletContextHandler of the metrics servlet.
getHeadDelay() - Method in class alluxio.util.executor.ControllableQueue
 
getHeadValue() - Method in class alluxio.util.executor.ControllableQueue
 
getHost() - Method in class alluxio.AlluxioURI
Gets the host of the AlluxioURI.
getHost() - Method in class alluxio.StandardURI
 
getHost() - Method in class alluxio.thrift.MasterNetAddress
 
getHost() - Method in class alluxio.thrift.WorkerNetAddress
 
getHost() - Method in interface alluxio.URI
 
getHost() - Method in class alluxio.web.WebInterfaceWorkersServlet.NodeInfo
 
getHost() - Method in class alluxio.wire.Address
 
getHost() - Method in class alluxio.wire.WorkerNetAddress
 
getHostname() - Method in class alluxio.master.LocalAlluxioCluster
 
getHostname() - Method in class alluxio.metrics.Metric
 
getHostname() - Method in class alluxio.multi.process.MasterNetAddress
 
getHostname() - Method in class alluxio.thrift.BackupTResponse
 
getHostname() - Method in class alluxio.thrift.Metric
 
getHostname() - Method in class alluxio.thrift.MetricsMasterClientService.metricsHeartbeat_args
the client hostname
getHostname() - Method in class alluxio.wire.BackupResponse
 
getHostNameKey() - Method in enum alluxio.util.network.NetworkAddressUtils.ServiceType
Gets the key of connect hostname.
getId() - Method in class alluxio.client.block.stream.BlockInStream
 
getId() - Method in class alluxio.master.block.meta.MasterWorkerInfo
 
getId() - Method in class alluxio.master.file.meta.Inode
 
getId() - Method in class alluxio.master.lineage.meta.Lineage
 
getId() - Method in class alluxio.master.meta.MasterInfo
 
getId(Address) - Method in class alluxio.master.meta.RetryHandlingMetaMasterMasterClient
Returns a master id for a master address.
getId() - Method in enum alluxio.network.protocol.RPCMessage.Type
Returns the int identifier of the type.
getId() - Method in class alluxio.proto.dataserver.Protocol.WriteRequest.Builder
optional int64 id = 2;
getId() - Method in class alluxio.proto.dataserver.Protocol.WriteRequest
optional int64 id = 2;
getId() - Method in interface alluxio.proto.dataserver.Protocol.WriteRequestOrBuilder
optional int64 id = 2;
getId() - Method in class alluxio.proto.journal.File.CompleteFileEntry.Builder
optional int64 id = 2;
getId() - Method in class alluxio.proto.journal.File.CompleteFileEntry
optional int64 id = 2;
getId() - Method in interface alluxio.proto.journal.File.CompleteFileEntryOrBuilder
optional int64 id = 2;
getId() - Method in class alluxio.proto.journal.File.DeleteFileEntry.Builder
optional int64 id = 1;
getId() - Method in class alluxio.proto.journal.File.DeleteFileEntry
optional int64 id = 1;
getId() - Method in interface alluxio.proto.journal.File.DeleteFileEntryOrBuilder
optional int64 id = 1;
getId() - Method in class alluxio.proto.journal.File.InodeDirectoryEntry.Builder
optional int64 id = 1;
getId() - Method in class alluxio.proto.journal.File.InodeDirectoryEntry
optional int64 id = 1;
getId() - Method in interface alluxio.proto.journal.File.InodeDirectoryEntryOrBuilder
optional int64 id = 1;
getId() - Method in class alluxio.proto.journal.File.InodeFileEntry.Builder
optional int64 id = 1;
getId() - Method in class alluxio.proto.journal.File.InodeFileEntry
optional int64 id = 1;
getId() - Method in interface alluxio.proto.journal.File.InodeFileEntryOrBuilder
optional int64 id = 1;
getId() - Method in class alluxio.proto.journal.File.InodeLastModificationTimeEntry.Builder
optional int64 id = 1;
getId() - Method in class alluxio.proto.journal.File.InodeLastModificationTimeEntry
optional int64 id = 1;
getId() - Method in interface alluxio.proto.journal.File.InodeLastModificationTimeEntryOrBuilder
optional int64 id = 1;
getId() - Method in class alluxio.proto.journal.File.PersistDirectoryEntry.Builder
optional int64 id = 1;
getId() - Method in class alluxio.proto.journal.File.PersistDirectoryEntry
optional int64 id = 1;
getId() - Method in interface alluxio.proto.journal.File.PersistDirectoryEntryOrBuilder
optional int64 id = 1;
getId() - Method in class alluxio.proto.journal.File.PersistFileEntry.Builder
optional int64 id = 1;
getId() - Method in class alluxio.proto.journal.File.PersistFileEntry
optional int64 id = 1;
getId() - Method in interface alluxio.proto.journal.File.PersistFileEntryOrBuilder
optional int64 id = 1;
getId() - Method in class alluxio.proto.journal.File.RenameEntry.Builder
optional int64 id = 1;
getId() - Method in class alluxio.proto.journal.File.RenameEntry
optional int64 id = 1;
getId() - Method in interface alluxio.proto.journal.File.RenameEntryOrBuilder
optional int64 id = 1;
getId() - Method in class alluxio.proto.journal.File.SetAttributeEntry.Builder
optional int64 id = 1;
getId() - Method in class alluxio.proto.journal.File.SetAttributeEntry
optional int64 id = 1;
getId() - Method in interface alluxio.proto.journal.File.SetAttributeEntryOrBuilder
optional int64 id = 1;
getId() - Method in class alluxio.proto.journal.Lineage.LineageEntry.Builder
optional int64 id = 1;
getId() - Method in class alluxio.proto.journal.Lineage.LineageEntry
optional int64 id = 1;
getId() - Method in interface alluxio.proto.journal.Lineage.LineageEntryOrBuilder
optional int64 id = 1;
getId() - Method in class alluxio.thrift.CompleteUfsFileTReponse
 
getId() - Method in class alluxio.thrift.CreateLineageTResponse
 
getId() - Method in class alluxio.thrift.CreateUfsFileTResponse
 
getId() - Method in class alluxio.thrift.GetNewBlockIdForFileTResponse
 
getId() - Method in class alluxio.thrift.LineageInfo
 
getId() - Method in class alluxio.thrift.LoadMetadataTResponse
 
getId() - Method in class alluxio.thrift.OpenUfsFileTResponse
 
getId() - Method in class alluxio.thrift.ReinitializeFileTResponse
 
getId() - Method in class alluxio.thrift.WorkerInfo
 
getID() - Method in class alluxio.web.UIFileBlockInfo
 
getId() - Method in class alluxio.web.UIFileInfo
 
getId() - Method in class alluxio.wire.LineageInfo
 
getId() - Method in class alluxio.wire.WorkerInfo
 
getId(WorkerNetAddress) - Method in class alluxio.worker.block.BlockMasterClient
Returns a worker id for a workers net address.
getImpersonationUser(Subject) - Static method in class alluxio.security.authentication.TransportProviderUtils
 
getInAlluxio() - Method in class alluxio.web.UIFileInfo
 
getInAlluxioFiles() - Method in class alluxio.master.file.DefaultFileSystemMaster
 
getInAlluxioFiles() - Method in interface alluxio.master.file.FileSystemMaster
 
getInAlluxioPercentage() - Method in class alluxio.client.file.URIStatus
 
getInAlluxioPercentage() - Method in class alluxio.thrift.FileInfo
 
getInAlluxioPercentage() - Method in class alluxio.web.UIFileInfo
 
getInAlluxioPercentage() - Method in class alluxio.wire.FileInfo
 
getInconsistentPaths() - Method in class alluxio.thrift.CheckConsistencyTResponse
 
getInconsistentPathsIterator() - Method in class alluxio.thrift.CheckConsistencyTResponse
 
getInconsistentPathsSize() - Method in class alluxio.thrift.CheckConsistencyTResponse
 
getInconsistentUris() - Method in class alluxio.master.file.StartupConsistencyCheck
 
getInconsistentUris() - Method in class alluxio.wire.StartupConsistencyCheck
 
getIncreasingByteArray(int) - Static method in class alluxio.util.io.BufferUtils
Gets an increasing sequence of bytes starting at zero.
getIncreasingByteArray(int, int) - Static method in class alluxio.util.io.BufferUtils
Gets an increasing sequence of bytes starting with the given value.
getIncreasingByteBuffer(int) - Static method in class alluxio.util.io.BufferUtils
Gets a ByteBuffer containing an increasing sequence of bytes starting at zero.
getIncreasingByteBuffer(int, int) - Static method in class alluxio.util.io.BufferUtils
Gets a ByteBuffer containing an increasing sequence of bytes starting at the given value.
getIndex() - Method in class alluxio.client.keyvalue.ByteBufferKeyValuePartitionReader
 
getInfo(long) - Method in class alluxio.client.block.AlluxioBlockStore
Gets the block info of a block, if it exists.
getInfo(Boolean) - Method in class alluxio.master.meta.AlluxioMasterRestServiceHandler
 
getInfo(Boolean) - Method in class alluxio.proxy.AlluxioProxyRestServiceHandler
 
getInfo() - Method in class alluxio.thrift.KeyValueMasterClientService.completePartition_args
information about the partition to mark complete
getInfo(Boolean) - Method in class alluxio.worker.AlluxioWorkerRestServiceHandler
 
getInfoTimeExceeded() - Method in class alluxio.util.JvmPauseMonitor
 
getInitialBytes() - Method in class alluxio.thrift.BlockWorkerClientService.requestBlockLocation_args
initial number of bytes requested
getInitialDelayMs() - Method in class alluxio.resource.DynamicResourcePool.Options
 
getInMemoryFiles() - Method in class alluxio.master.file.DefaultFileSystemMaster
 
getInMemoryFiles() - Method in interface alluxio.master.file.FileSystemMaster
 
getInMemoryPercentage() - Method in class alluxio.client.file.URIStatus
 
getInMemoryPercentage() - Method in class alluxio.thrift.FileInfo
 
getInMemoryPercentage() - Method in class alluxio.wire.FileInfo
 
getInode() - Method in class alluxio.master.file.meta.LockedInodePath
 
getInodeDirectory() - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
optional .alluxio.proto.journal.InodeDirectoryEntry inode_directory = 9;
getInodeDirectory() - Method in class alluxio.proto.journal.Journal.JournalEntry
optional .alluxio.proto.journal.InodeDirectoryEntry inode_directory = 9;
getInodeDirectory() - Method in interface alluxio.proto.journal.Journal.JournalEntryOrBuilder
optional .alluxio.proto.journal.InodeDirectoryEntry inode_directory = 9;
getInodeDirectoryBuilder() - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
optional .alluxio.proto.journal.InodeDirectoryEntry inode_directory = 9;
getInodeDirectoryIdGenerator() - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
optional .alluxio.proto.journal.InodeDirectoryIdGeneratorEntry inode_directory_id_generator = 10;
getInodeDirectoryIdGenerator() - Method in class alluxio.proto.journal.Journal.JournalEntry
optional .alluxio.proto.journal.InodeDirectoryIdGeneratorEntry inode_directory_id_generator = 10;
getInodeDirectoryIdGenerator() - Method in interface alluxio.proto.journal.Journal.JournalEntryOrBuilder
optional .alluxio.proto.journal.InodeDirectoryIdGeneratorEntry inode_directory_id_generator = 10;
getInodeDirectoryIdGeneratorBuilder() - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
optional .alluxio.proto.journal.InodeDirectoryIdGeneratorEntry inode_directory_id_generator = 10;
getInodeDirectoryIdGeneratorOrBuilder() - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
optional .alluxio.proto.journal.InodeDirectoryIdGeneratorEntry inode_directory_id_generator = 10;
getInodeDirectoryIdGeneratorOrBuilder() - Method in class alluxio.proto.journal.Journal.JournalEntry
optional .alluxio.proto.journal.InodeDirectoryIdGeneratorEntry inode_directory_id_generator = 10;
getInodeDirectoryIdGeneratorOrBuilder() - Method in interface alluxio.proto.journal.Journal.JournalEntryOrBuilder
optional .alluxio.proto.journal.InodeDirectoryIdGeneratorEntry inode_directory_id_generator = 10;
getInodeDirectoryOrBuilder() - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
optional .alluxio.proto.journal.InodeDirectoryEntry inode_directory = 9;
getInodeDirectoryOrBuilder() - Method in class alluxio.proto.journal.Journal.JournalEntry
optional .alluxio.proto.journal.InodeDirectoryEntry inode_directory = 9;
getInodeDirectoryOrBuilder() - Method in interface alluxio.proto.journal.Journal.JournalEntryOrBuilder
optional .alluxio.proto.journal.InodeDirectoryEntry inode_directory = 9;
getInodeFile() - Method in class alluxio.master.file.meta.LockedInodePath
 
getInodeFile() - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
optional .alluxio.proto.journal.InodeFileEntry inode_file = 11;
getInodeFile() - Method in class alluxio.proto.journal.Journal.JournalEntry
optional .alluxio.proto.journal.InodeFileEntry inode_file = 11;
getInodeFile() - Method in interface alluxio.proto.journal.Journal.JournalEntryOrBuilder
optional .alluxio.proto.journal.InodeFileEntry inode_file = 11;
getInodeFileBuilder() - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
optional .alluxio.proto.journal.InodeFileEntry inode_file = 11;
getInodeFileOrBuilder() - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
optional .alluxio.proto.journal.InodeFileEntry inode_file = 11;
getInodeFileOrBuilder() - Method in class alluxio.proto.journal.Journal.JournalEntry
optional .alluxio.proto.journal.InodeFileEntry inode_file = 11;
getInodeFileOrBuilder() - Method in interface alluxio.proto.journal.Journal.JournalEntryOrBuilder
optional .alluxio.proto.journal.InodeFileEntry inode_file = 11;
getInodeLastModificationTime() - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
optional .alluxio.proto.journal.InodeLastModificationTimeEntry inode_last_modification_time = 12;
getInodeLastModificationTime() - Method in class alluxio.proto.journal.Journal.JournalEntry
optional .alluxio.proto.journal.InodeLastModificationTimeEntry inode_last_modification_time = 12;
getInodeLastModificationTime() - Method in interface alluxio.proto.journal.Journal.JournalEntryOrBuilder
optional .alluxio.proto.journal.InodeLastModificationTimeEntry inode_last_modification_time = 12;
getInodeLastModificationTimeBuilder() - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
optional .alluxio.proto.journal.InodeLastModificationTimeEntry inode_last_modification_time = 12;
getInodeLastModificationTimeOrBuilder() - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
optional .alluxio.proto.journal.InodeLastModificationTimeEntry inode_last_modification_time = 12;
getInodeLastModificationTimeOrBuilder() - Method in class alluxio.proto.journal.Journal.JournalEntry
optional .alluxio.proto.journal.InodeLastModificationTimeEntry inode_last_modification_time = 12;
getInodeLastModificationTimeOrBuilder() - Method in interface alluxio.proto.journal.Journal.JournalEntryOrBuilder
optional .alluxio.proto.journal.InodeLastModificationTimeEntry inode_last_modification_time = 12;
getInodeList() - Method in class alluxio.master.file.meta.LockedInodePath
 
getInodeOrNull() - Method in class alluxio.master.file.meta.LockedInodePath
 
getInodePathList() - Method in class alluxio.master.file.meta.LockedInodePathList
get the associated inodePathList.
getInodes() - Method in class alluxio.master.file.meta.CompositeInodeLockList
 
getInodes() - Method in class alluxio.master.file.meta.InodeLockList
 
getInodes() - Method in class alluxio.master.file.meta.TtlBucket
 
getInputFiles() - Method in class alluxio.master.lineage.meta.Lineage
 
getInputFiles(int) - Method in class alluxio.proto.journal.Lineage.LineageEntry.Builder
repeated int64 input_files = 2;
getInputFiles(int) - Method in class alluxio.proto.journal.Lineage.LineageEntry
repeated int64 input_files = 2;
getInputFiles(int) - Method in interface alluxio.proto.journal.Lineage.LineageEntryOrBuilder
repeated int64 input_files = 2;
getInputFiles() - Method in class alluxio.thrift.LineageInfo
 
getInputFiles() - Method in class alluxio.thrift.LineageMasterClientService.createLineage_args
the list of input files
getInputFiles() - Method in class alluxio.wire.LineageInfo
 
getInputFilesCount() - Method in class alluxio.proto.journal.Lineage.LineageEntry.Builder
repeated int64 input_files = 2;
getInputFilesCount() - Method in class alluxio.proto.journal.Lineage.LineageEntry
repeated int64 input_files = 2;
getInputFilesCount() - Method in interface alluxio.proto.journal.Lineage.LineageEntryOrBuilder
repeated int64 input_files = 2;
getInputFilesIterator() - Method in class alluxio.thrift.LineageInfo
 
getInputFilesIterator() - Method in class alluxio.thrift.LineageMasterClientService.createLineage_args
 
getInputFilesList() - Method in class alluxio.proto.journal.Lineage.LineageEntry.Builder
repeated int64 input_files = 2;
getInputFilesList() - Method in class alluxio.proto.journal.Lineage.LineageEntry
repeated int64 input_files = 2;
getInputFilesList() - Method in interface alluxio.proto.journal.Lineage.LineageEntryOrBuilder
repeated int64 input_files = 2;
getInputFilesSize() - Method in class alluxio.thrift.LineageInfo
 
getInputFilesSize() - Method in class alluxio.thrift.LineageMasterClientService.createLineage_args
 
getInstance() - Method in class alluxio.thrift.Metric
 
getInstanceId() - Method in class alluxio.metrics.Metric
 
getInstanceId() - Method in class alluxio.thrift.Metric
 
getInstanceType() - Method in class alluxio.metrics.aggregator.SumInstancesAggregator
 
getInstanceType() - Method in class alluxio.metrics.Metric
 
getInstanceType() - Method in class alluxio.metrics.MetricsFilter
 
getInStream(long, InStreamOptions) - Method in class alluxio.client.block.AlluxioBlockStore
Gets a stream to read the data of a block.
getInStream(long, InStreamOptions, Map<WorkerNetAddress, Long>) - Method in class alluxio.client.block.AlluxioBlockStore
Gets a stream to read the data of a block.
getInStream(Integer) - Method in class alluxio.StreamCache
 
getInt(PropertyKey) - Method in interface alluxio.AlluxioConfiguration
Gets the integer representation of the value for the given key.
getInt(PropertyKey) - Method in class alluxio.conf.InstancedConfiguration
 
getInt(PropertyKey) - Static method in class alluxio.Configuration
Gets the integer representation of the value for the given key.
getInternalURL() - Method in class alluxio.underfs.swift.KeystoneV3Access
 
getInterval() - Method in class alluxio.util.WaitForOptions
 
getIsDirectory() - Method in class alluxio.web.UIFileInfo
 
getJob() - Method in class alluxio.master.lineage.meta.Lineage
 
getJob() - Method in class alluxio.thrift.LineageInfo
 
getJob() - Method in class alluxio.thrift.LineageMasterClientService.createLineage_args
the command line job info
getJob() - Method in class alluxio.wire.LineageInfo
 
getJobCommand() - Method in class alluxio.proto.journal.Lineage.LineageEntry.Builder
optional string job_command = 4;
getJobCommand() - Method in class alluxio.proto.journal.Lineage.LineageEntry
optional string job_command = 4;
getJobCommand() - Method in interface alluxio.proto.journal.Lineage.LineageEntryOrBuilder
optional string job_command = 4;
getJobCommandBytes() - Method in class alluxio.proto.journal.Lineage.LineageEntry.Builder
optional string job_command = 4;
getJobCommandBytes() - Method in class alluxio.proto.journal.Lineage.LineageEntry
optional string job_command = 4;
getJobCommandBytes() - Method in interface alluxio.proto.journal.Lineage.LineageEntryOrBuilder
optional string job_command = 4;
getJobConf() - Method in class alluxio.job.Job
 
getJobOutputPath() - Method in class alluxio.proto.journal.Lineage.LineageEntry.Builder
optional string job_output_path = 5;
getJobOutputPath() - Method in class alluxio.proto.journal.Lineage.LineageEntry
optional string job_output_path = 5;
getJobOutputPath() - Method in interface alluxio.proto.journal.Lineage.LineageEntryOrBuilder
optional string job_output_path = 5;
getJobOutputPathBytes() - Method in class alluxio.proto.journal.Lineage.LineageEntry.Builder
optional string job_output_path = 5;
getJobOutputPathBytes() - Method in class alluxio.proto.journal.Lineage.LineageEntry
optional string job_output_path = 5;
getJobOutputPathBytes() - Method in interface alluxio.proto.journal.Lineage.LineageEntryOrBuilder
optional string job_output_path = 5;
getJobOutputURI(JobContext) - Static method in class alluxio.hadoop.mapreduce.KeyValueOutputFormat
 
getJournalContext() - Method in class alluxio.master.file.RpcContext
 
getJournalEntryIterator() - Method in class alluxio.master.block.DefaultBlockMaster
 
getJournalEntryIterator() - Method in class alluxio.master.file.DefaultFileSystemMaster
 
getJournalEntryIterator() - Method in class alluxio.master.file.meta.InodeTree
 
getJournalEntryIterator() - Method in class alluxio.master.file.meta.MountTable
 
getJournalEntryIterator() - Method in interface alluxio.master.journal.JournalEntryIterable
 
getJournalEntryIterator() - Method in class alluxio.master.keyvalue.DefaultKeyValueMaster
 
getJournalEntryIterator() - Method in class alluxio.master.lineage.DefaultLineageMaster
 
getJournalEntryIterator() - Method in class alluxio.master.lineage.meta.LineageStore
Note that this method is not threadsafe.
getJournalEntryIterator() - Method in class alluxio.master.meta.DefaultMetaMaster
 
getJournalEntryIterator() - Method in class alluxio.master.metrics.DefaultMetricsMaster
 
getJournalEntryIterator() - Method in class alluxio.master.NoopMaster
 
getJournalEntryIterator() - Method in class alluxio.underfs.MasterUfsManager
 
getJournalFolder() - Method in class alluxio.master.LocalAlluxioMaster
 
getJournalFormatter() - Method in class alluxio.master.journalv0.ufs.UfsJournal
 
getJournalLocation() - Static method in class alluxio.master.journal.JournalUtils
Returns a URI for the configured location for the specified journal.
getJournalSystem() - Method in class alluxio.master.MasterContext
 
getJournalUfsConf() - Static method in class alluxio.master.journal.ufs.UfsJournal
 
getKey() - Method in class alluxio.client.keyvalue.KeyValuePair
 
getKey(int) - Method in interface alluxio.client.keyvalue.PayloadReader
Gets the key given the position of payload buffer.
getKey() - Method in class alluxio.master.meta.checkconf.ConfigRecord
 
getKey() - Method in class alluxio.proto.journal.File.StringPairEntry.Builder
optional string key = 1;
getKey() - Method in class alluxio.proto.journal.File.StringPairEntry
optional string key = 1;
getKey() - Method in interface alluxio.proto.journal.File.StringPairEntryOrBuilder
optional string key = 1;
getKey() - Method in class alluxio.proxy.s3.CompleteMultipartUploadResult
 
getKey() - Method in class alluxio.proxy.s3.InitiateMultipartUploadResult
 
getKey() - Method in class alluxio.proxy.s3.ListBucketResult.Content
 
getKey() - Method in class alluxio.proxy.s3.ListPartsResult
 
getKey() - Method in class alluxio.thrift.KeyValueWorkerClientService.get_args
binary of the key
getKey() - Method in class alluxio.thrift.KeyValueWorkerClientService.getNextKeys_args
current key
getKeyBytes() - Method in class alluxio.proto.journal.File.StringPairEntry.Builder
optional string key = 1;
getKeyBytes() - Method in class alluxio.proto.journal.File.StringPairEntry
optional string key = 1;
getKeyBytes() - Method in interface alluxio.proto.journal.File.StringPairEntryOrBuilder
optional string key = 1;
getKeyCount() - Method in class alluxio.proto.journal.KeyValue.CompletePartitionEntry.Builder
optional int32 key_count = 5;
getKeyCount() - Method in class alluxio.proto.journal.KeyValue.CompletePartitionEntry
optional int32 key_count = 5;
getKeyCount() - Method in interface alluxio.proto.journal.KeyValue.CompletePartitionEntryOrBuilder
optional int32 key_count = 5;
getKeyCount() - Method in class alluxio.proxy.s3.ListBucketResult
 
getKeyCount() - Method in class alluxio.thrift.PartitionInfo
 
getKeyLimit() - Method in class alluxio.proto.journal.KeyValue.CompletePartitionEntry.Builder
optional string key_limit = 3;
getKeyLimit() - Method in class alluxio.proto.journal.KeyValue.CompletePartitionEntry
optional string key_limit = 3;
getKeyLimit() - Method in interface alluxio.proto.journal.KeyValue.CompletePartitionEntryOrBuilder
optional string key_limit = 3;
getKeyLimit() - Method in class alluxio.thrift.PartitionInfo
 
getKeyLimitBytes() - Method in class alluxio.proto.journal.KeyValue.CompletePartitionEntry.Builder
optional string key_limit = 3;
getKeyLimitBytes() - Method in class alluxio.proto.journal.KeyValue.CompletePartitionEntry
optional string key_limit = 3;
getKeyLimitBytes() - Method in interface alluxio.proto.journal.KeyValue.CompletePartitionEntryOrBuilder
optional string key_limit = 3;
getKeys() - Method in class alluxio.thrift.GetNextKeysTResponse
 
getKeysIterator() - Method in class alluxio.thrift.GetNextKeysTResponse
 
getKeysSize() - Method in class alluxio.thrift.GetNextKeysTResponse
 
getKeyStart() - Method in class alluxio.proto.journal.KeyValue.CompletePartitionEntry.Builder
optional string key_start = 2;
getKeyStart() - Method in class alluxio.proto.journal.KeyValue.CompletePartitionEntry
optional string key_start = 2;
getKeyStart() - Method in interface alluxio.proto.journal.KeyValue.CompletePartitionEntryOrBuilder
optional string key_start = 2;
getKeyStart() - Method in class alluxio.thrift.PartitionInfo
 
getKeyStartBytes() - Method in class alluxio.proto.journal.KeyValue.CompletePartitionEntry.Builder
optional string key_start = 2;
getKeyStartBytes() - Method in class alluxio.proto.journal.KeyValue.CompletePartitionEntry
optional string key_start = 2;
getKeyStartBytes() - Method in interface alluxio.proto.journal.KeyValue.CompletePartitionEntryOrBuilder
optional string key_start = 2;
getLastAccessTimeMs() - Method in class alluxio.resource.DynamicResourcePool.ResourceInternal
 
getLastAccessTimeMs() - Method in class alluxio.web.UIFileBlockInfo
 
getLastContactSec() - Method in class alluxio.thrift.WorkerInfo
 
getLastContactSec() - Method in class alluxio.wire.WorkerInfo
 
getLastExistingInode() - Method in class alluxio.master.file.meta.LockedInodePath
 
getLastHeartbeat() - Method in class alluxio.web.WebInterfaceWorkersServlet.NodeInfo
 
getLastModificationTimeMs() - Method in class alluxio.client.file.URIStatus
 
getLastModificationTimeMs() - Method in class alluxio.master.file.meta.Inode
 
getLastModificationTimeMs() - Method in class alluxio.proto.journal.File.InodeDirectoryEntry.Builder
optional int64 last_modification_time_ms = 7;
getLastModificationTimeMs() - Method in class alluxio.proto.journal.File.InodeDirectoryEntry
optional int64 last_modification_time_ms = 7;
getLastModificationTimeMs() - Method in interface alluxio.proto.journal.File.InodeDirectoryEntryOrBuilder
optional int64 last_modification_time_ms = 7;
getLastModificationTimeMs() - Method in class alluxio.proto.journal.File.InodeFileEntry.Builder
optional int64 last_modification_time_ms = 7;
getLastModificationTimeMs() - Method in class alluxio.proto.journal.File.InodeFileEntry
optional int64 last_modification_time_ms = 7;
getLastModificationTimeMs() - Method in interface alluxio.proto.journal.File.InodeFileEntryOrBuilder
optional int64 last_modification_time_ms = 7;
getLastModificationTimeMs() - Method in class alluxio.proto.journal.File.InodeLastModificationTimeEntry.Builder
optional int64 last_modification_time_ms = 2;
getLastModificationTimeMs() - Method in class alluxio.proto.journal.File.InodeLastModificationTimeEntry
optional int64 last_modification_time_ms = 2;
getLastModificationTimeMs() - Method in interface alluxio.proto.journal.File.InodeLastModificationTimeEntryOrBuilder
optional int64 last_modification_time_ms = 2;
getLastModificationTimeMs() - Method in class alluxio.thrift.FileInfo
 
getLastModificationTimeMs() - Method in class alluxio.wire.FileInfo
 
getLastModified() - Method in class alluxio.proxy.s3.ListBucketResult.Content
 
getLastModified() - Method in class alluxio.proxy.s3.ListPartsResult.Part
 
getLastModifiedTime() - Method in class alluxio.underfs.UfsStatus
Gets the UTC time of when the indicated path was modified recently in ms, or null if the last modified time is not available.
getLastModifiedTimeMs() - Method in class alluxio.underfs.ObjectUnderFileSystem.ObjectStatus
Gets the last modified epoch time in ms.
getLastUpdatedTimeMs() - Method in class alluxio.master.block.meta.MasterWorkerInfo
 
getLastUpdatedTimeMs() - Method in class alluxio.master.meta.MasterInfo
 
getLatestCheckpoint() - Method in class alluxio.master.journal.ufs.UfsJournalSnapshot
 
getLatestSequenceNumber() - Method in interface alluxio.master.journalv0.JournalInputStream
 
getLeaderIndex() - Method in class alluxio.master.MultiMasterLocalAlluxioCluster
 
getLeaderMasterAddress() - Method in class alluxio.thrift.MasterInfo
 
getLeaderMasterAddress() - Method in class alluxio.wire.MasterInfo
 
getLeaderPath() - Method in class alluxio.master.ZkMasterInquireClient.ZkMasterConnectDetails
 
getLeadingPath(int) - Method in class alluxio.AlluxioURI
Gets the first n components of the AlluxioURI path.
getLength() - Method in class alluxio.client.file.URIStatus
 
getLength() - Method in class alluxio.master.block.meta.MasterBlockInfo
 
getLength() - Method in class alluxio.master.file.meta.InodeFile
 
getLength() - Method in interface alluxio.network.protocol.databuffer.DataBuffer
Returns the length of the data.
getLength() - Method in class alluxio.network.protocol.databuffer.DataByteArrayChannel
 
getLength() - Method in class alluxio.network.protocol.databuffer.DataByteBuffer
 
getLength() - Method in class alluxio.network.protocol.databuffer.DataFileChannel
 
getLength() - Method in class alluxio.network.protocol.databuffer.DataNettyBuffer
 
getLength() - Method in class alluxio.network.protocol.databuffer.DataNettyBufferV2
 
getLength() - Method in class alluxio.proto.dataserver.Protocol.AsyncCacheRequest.Builder
optional int64 length = 5;
getLength() - Method in class alluxio.proto.dataserver.Protocol.AsyncCacheRequest
optional int64 length = 5;
getLength() - Method in interface alluxio.proto.dataserver.Protocol.AsyncCacheRequestOrBuilder
optional int64 length = 5;
getLength() - Method in class alluxio.proto.dataserver.Protocol.ReadRequest.Builder
optional int64 length = 3;
getLength() - Method in class alluxio.proto.dataserver.Protocol.ReadRequest
optional int64 length = 3;
getLength() - Method in interface alluxio.proto.dataserver.Protocol.ReadRequestOrBuilder
optional int64 length = 3;
getLength() - Method in class alluxio.proto.journal.Block.BlockInfoEntry.Builder
optional int64 length = 2;
getLength() - Method in class alluxio.proto.journal.Block.BlockInfoEntry
optional int64 length = 2;
getLength() - Method in interface alluxio.proto.journal.Block.BlockInfoEntryOrBuilder
optional int64 length = 2;
getLength() - Method in class alluxio.proto.journal.File.CompleteFileEntry.Builder
optional int64 length = 3;
getLength() - Method in class alluxio.proto.journal.File.CompleteFileEntry
optional int64 length = 3;
getLength() - Method in interface alluxio.proto.journal.File.CompleteFileEntryOrBuilder
optional int64 length = 3;
getLength() - Method in class alluxio.proto.journal.File.InodeFileEntry.Builder
optional int64 length = 9;
getLength() - Method in class alluxio.proto.journal.File.InodeFileEntry
optional int64 length = 9;
getLength() - Method in interface alluxio.proto.journal.File.InodeFileEntryOrBuilder
optional int64 length = 9;
getLength() - Method in class alluxio.proto.journal.File.PersistFileEntry.Builder
optional int64 length = 2;
getLength() - Method in class alluxio.proto.journal.File.PersistFileEntry
optional int64 length = 2;
getLength() - Method in interface alluxio.proto.journal.File.PersistFileEntryOrBuilder
optional int64 length = 2;
getLength() - Method in class alluxio.thrift.BlockInfo
 
getLength() - Method in class alluxio.thrift.BlockMasterWorkerService.commitBlock_args
the length of the block being committed
getLength() - Method in class alluxio.thrift.FileInfo
 
getLength() - Method in class alluxio.underfs.options.OpenOptions
 
getLength() - Method in class alluxio.wire.BlockInfo
 
getLength() - Method in class alluxio.wire.FileInfo
 
getLength() - Method in interface alluxio.worker.block.io.BlockReader
Gets the length of the block in bytes.
getLength() - Method in class alluxio.worker.block.io.LocalFileBlockReader
 
getLength() - Method in class alluxio.worker.block.RemoteBlockReader
 
getLength() - Method in class alluxio.worker.block.UnderFileSystemBlockReader
 
getLevel() - Method in class alluxio.wire.LogInfo
 
getLineage(long) - Method in class alluxio.master.lineage.meta.LineageStore
Gets the lineage.
getLineage() - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
optional .alluxio.proto.journal.LineageEntry lineage = 13;
getLineage() - Method in class alluxio.proto.journal.Journal.JournalEntry
optional .alluxio.proto.journal.LineageEntry lineage = 13;
getLineage() - Method in interface alluxio.proto.journal.Journal.JournalEntryOrBuilder
optional .alluxio.proto.journal.LineageEntry lineage = 13;
getLineageBuilder() - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
optional .alluxio.proto.journal.LineageEntry lineage = 13;
getLineageId() - Method in class alluxio.proto.journal.Lineage.DeleteLineageEntry.Builder
optional int64 lineage_id = 1;
getLineageId() - Method in class alluxio.proto.journal.Lineage.DeleteLineageEntry
optional int64 lineage_id = 1;
getLineageId() - Method in interface alluxio.proto.journal.Lineage.DeleteLineageEntryOrBuilder
optional int64 lineage_id = 1;
getLineageId() - Method in class alluxio.thrift.LineageMasterClientService.deleteLineage_args
the lineage id
getLineageIdGenerator() - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
optional .alluxio.proto.journal.LineageIdGeneratorEntry lineage_id_generator = 14;
getLineageIdGenerator() - Method in class alluxio.proto.journal.Journal.JournalEntry
optional .alluxio.proto.journal.LineageIdGeneratorEntry lineage_id_generator = 14;
getLineageIdGenerator() - Method in interface alluxio.proto.journal.Journal.JournalEntryOrBuilder
optional .alluxio.proto.journal.LineageIdGeneratorEntry lineage_id_generator = 14;
getLineageIdGeneratorBuilder() - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
optional .alluxio.proto.journal.LineageIdGeneratorEntry lineage_id_generator = 14;
getLineageIdGeneratorOrBuilder() - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
optional .alluxio.proto.journal.LineageIdGeneratorEntry lineage_id_generator = 14;
getLineageIdGeneratorOrBuilder() - Method in class alluxio.proto.journal.Journal.JournalEntry
optional .alluxio.proto.journal.LineageIdGeneratorEntry lineage_id_generator = 14;
getLineageIdGeneratorOrBuilder() - Method in interface alluxio.proto.journal.Journal.JournalEntryOrBuilder
optional .alluxio.proto.journal.LineageIdGeneratorEntry lineage_id_generator = 14;
getLineageInfoList(GetLineageInfoListOptions) - Method in class alluxio.client.lineage.AbstractLineageClient
 
getLineageInfoList() - Method in class alluxio.client.lineage.AlluxioLineage
Convenience method for AbstractLineageClient.getLineageInfoList(GetLineageInfoListOptions) with default options.
getLineageInfoList() - Method in class alluxio.client.lineage.LineageMasterClient
Retrieves the list of lineage information.
getLineageInfoList() - Method in class alluxio.master.lineage.DefaultLineageMaster
 
getLineageInfoList() - Method in interface alluxio.master.lineage.LineageMaster
 
getLineageInfoList() - Method in class alluxio.master.lineage.LineageMasterClientRestServiceHandler
Deprecated.
 
getLineageInfoList(GetLineageInfoListTOptions) - Method in class alluxio.master.lineage.LineageMasterClientServiceHandler
 
getLineageInfoList() - Method in class alluxio.thrift.GetLineageInfoListTResponse
 
getLineageInfoList(GetLineageInfoListTOptions, AsyncMethodCallback) - Method in class alluxio.thrift.LineageMasterClientService.AsyncClient
 
getLineageInfoList(GetLineageInfoListTOptions, AsyncMethodCallback) - Method in interface alluxio.thrift.LineageMasterClientService.AsyncIface
 
getLineageInfoList() - Constructor for class alluxio.thrift.LineageMasterClientService.AsyncProcessor.getLineageInfoList
 
getLineageInfoList(GetLineageInfoListTOptions) - Method in class alluxio.thrift.LineageMasterClientService.Client
 
getLineageInfoList(GetLineageInfoListTOptions) - Method in interface alluxio.thrift.LineageMasterClientService.Iface
Returns a list of existing lineages.
getLineageInfoList() - Constructor for class alluxio.thrift.LineageMasterClientService.Processor.getLineageInfoList
 
getLineageInfoList_args() - Constructor for class alluxio.thrift.LineageMasterClientService.getLineageInfoList_args
 
getLineageInfoList_args(GetLineageInfoListTOptions) - Constructor for class alluxio.thrift.LineageMasterClientService.getLineageInfoList_args
 
getLineageInfoList_args(LineageMasterClientService.getLineageInfoList_args) - Constructor for class alluxio.thrift.LineageMasterClientService.getLineageInfoList_args
Performs a deep copy on other.
getLineageInfoList_call(GetLineageInfoListTOptions, AsyncMethodCallback, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class alluxio.thrift.LineageMasterClientService.AsyncClient.getLineageInfoList_call
 
getLineageInfoList_result() - Constructor for class alluxio.thrift.LineageMasterClientService.getLineageInfoList_result
 
getLineageInfoList_result(GetLineageInfoListTResponse, AlluxioTException) - Constructor for class alluxio.thrift.LineageMasterClientService.getLineageInfoList_result
 
getLineageInfoList_result(LineageMasterClientService.getLineageInfoList_result) - Constructor for class alluxio.thrift.LineageMasterClientService.getLineageInfoList_result
Performs a deep copy on other.
getLineageInfoListIterator() - Method in class alluxio.thrift.GetLineageInfoListTResponse
 
GetLineageInfoListOptions - Class in alluxio.client.lineage.options
The method option for retrieving a list of lineage information.
getLineageInfoListSize() - Method in class alluxio.thrift.GetLineageInfoListTResponse
 
GetLineageInfoListTOptions - Class in alluxio.thrift
 
GetLineageInfoListTOptions() - Constructor for class alluxio.thrift.GetLineageInfoListTOptions
 
GetLineageInfoListTOptions(GetLineageInfoListTOptions) - Constructor for class alluxio.thrift.GetLineageInfoListTOptions
Performs a deep copy on other.
GetLineageInfoListTOptions._Fields - Enum in alluxio.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
GetLineageInfoListTResponse - Class in alluxio.thrift
 
GetLineageInfoListTResponse() - Constructor for class alluxio.thrift.GetLineageInfoListTResponse
 
GetLineageInfoListTResponse(List<LineageInfo>) - Constructor for class alluxio.thrift.GetLineageInfoListTResponse
 
GetLineageInfoListTResponse(GetLineageInfoListTResponse) - Constructor for class alluxio.thrift.GetLineageInfoListTResponse
Performs a deep copy on other.
GetLineageInfoListTResponse._Fields - Enum in alluxio.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
getLineageOfOutputFile(long) - Method in class alluxio.master.lineage.meta.LineageStore
Gets the lineage that has the given output file.
getLineageOrBuilder() - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
optional .alluxio.proto.journal.LineageEntry lineage = 13;
getLineageOrBuilder() - Method in class alluxio.proto.journal.Journal.JournalEntry
optional .alluxio.proto.journal.LineageEntry lineage = 13;
getLineageOrBuilder() - Method in interface alluxio.proto.journal.Journal.JournalEntryOrBuilder
optional .alluxio.proto.journal.LineageEntry lineage = 13;
getLineagesToCheckpoint() - Method in class alluxio.master.lineage.checkpoint.CheckpointPlan
 
getLineageStoreView() - Method in class alluxio.master.lineage.DefaultLineageMaster
 
getLineageStoreView() - Method in interface alluxio.master.lineage.LineageMaster
 
getLineageToRecompute() - Method in class alluxio.master.lineage.recompute.RecomputePlan
 
getList(PropertyKey, String) - Method in interface alluxio.AlluxioConfiguration
Gets the value for the given key as a list.
getList() - Method in class alluxio.collections.PrefixList
Gets the list of prefixes.
getList(PropertyKey, String) - Method in class alluxio.conf.InstancedConfiguration
 
getList(PropertyKey, String) - Static method in class alluxio.Configuration
Gets the value for the given key as a list.
getListingChunkLength() - Method in class alluxio.underfs.ObjectUnderFileSystem
The number of items to query in a single listing chunk.
getListingChunkLengthMax() - Method in class alluxio.underfs.ObjectUnderFileSystem
Maximum number of items in a single listing chunk supported by the under store.
getLiveNodeAddresses() - Method in class alluxio.master.meta.checkconf.ServerConfigurationStore
 
getLiveWorkerNum() - Method in class alluxio.thrift.BlockMasterInfo
 
getLiveWorkerNum() - Method in class alluxio.wire.BlockMasterInfo
 
getLoadDescendantType() - Method in class alluxio.master.file.options.LoadMetadataOptions
 
getLoadMetadataType() - Method in class alluxio.client.file.options.ExistsOptions
 
getLoadMetadataType() - Method in class alluxio.client.file.options.GetStatusOptions
 
getLoadMetadataType() - Method in class alluxio.client.file.options.ListStatusOptions
 
getLoadMetadataType() - Method in class alluxio.master.file.options.GetStatusOptions
 
getLoadMetadataType() - Method in class alluxio.master.file.options.ListStatusOptions
 
getLoadMetadataType() - Method in class alluxio.thrift.GetStatusTOptions
 
getLoadMetadataType() - Method in class alluxio.thrift.ListStatusTOptions
 
getLocalAddress() - Static method in class alluxio.checker.CheckerUtils
 
getLocalAlluxioMaster() - Method in class alluxio.master.AbstractLocalAlluxioCluster
 
getLocalAlluxioMaster() - Method in class alluxio.master.LocalAlluxioCluster
 
getLocalAlluxioMaster() - Method in class alluxio.master.MultiMasterLocalAlluxioCluster
 
getLocalFileGroup(String) - Static method in class alluxio.util.io.FileUtils
Gets local file's group.
getLocalFileMode(String) - Static method in class alluxio.util.io.FileUtils
Gets local file's permission mode.
getLocalFileOwner(String) - Static method in class alluxio.util.io.FileUtils
Gets local file's owner.
getLocalHostMetricName() - Static method in class alluxio.util.network.NetworkAddressUtils
Gets a local hostname for the host this JVM is running on with '.' replaced with '_' for metrics usage.
getLocalHostName() - Static method in class alluxio.util.network.NetworkAddressUtils
Gets a local hostname for the host this JVM is running on.
getLocalHostName(int) - Static method in class alluxio.util.network.NetworkAddressUtils
Gets a local host name for the host this JVM is running on.
getLocalIpAddress() - Static method in class alluxio.util.network.NetworkAddressUtils
Gets a local IP address for the host this JVM is running on.
getLocalIpAddress(int) - Static method in class alluxio.util.network.NetworkAddressUtils
Gets a local IP address for the host this JVM is running on.
getLocalNodeName() - Static method in class alluxio.util.network.NetworkAddressUtils
Gets a local node name from configuration if it is available, falling back on localhost lookup.
getLocalPort() - Method in class alluxio.web.WebServer
Gets the actual port that the web server is listening on.
getLocalWorker() - Method in class alluxio.client.file.FileSystemContext
 
getLocation() - Method in interface alluxio.master.journal.Journal
 
getLocation() - Method in class alluxio.master.journal.noop.NoopJournal
 
getLocation() - Method in class alluxio.master.journal.ufs.UfsJournal
 
getLocation() - Method in class alluxio.master.journal.ufs.UfsJournalFile
 
getLocation() - Method in interface alluxio.master.journalv0.Journal
 
getLocation() - Method in class alluxio.master.journalv0.ufs.UfsJournal
 
getLocation() - Method in class alluxio.proxy.s3.CompleteMultipartUploadResult
 
getLocation() - Method in class alluxio.thrift.RequestBlockLocationTResponse
 
getLocationPolicy() - Method in class alluxio.client.file.options.CreateFileOptions
 
getLocationPolicy() - Method in class alluxio.client.file.options.OpenFileOptions
Deprecated.
since version 1.5 and will be removed in version 2.0. Use OpenFileOptions.getCacheLocationPolicy().
getLocationPolicy() - Method in class alluxio.client.file.options.OutStreamOptions
 
getLocationPolicyClass() - Method in class alluxio.client.file.options.CreateFileOptions
 
getLocationPolicyClass() - Method in class alluxio.client.file.options.OpenFileOptions
Deprecated.
since version 1.5 and will be removed in version 2.0. Use OpenFileOptions.getCacheLocationPolicyClass().
getLocationPolicyClassName() - Method in class alluxio.client.block.policy.options.CreateOptions
 
getLocations() - Method in class alluxio.thrift.BlockInfo
 
getLocations() - Method in class alluxio.web.UIFileBlockInfo
 
getLocations() - Method in class alluxio.wire.BlockInfo
 
getLocationsIterator() - Method in class alluxio.thrift.BlockInfo
 
getLocationsSize() - Method in class alluxio.thrift.BlockInfo
 
getLockBlockStatus() - Method in class alluxio.thrift.LockBlockTResponse
 
getLockedBlocks() - Method in class alluxio.worker.block.BlockLockManager
Gets a set of currently locked blocks.
getLockId() - Method in class alluxio.thrift.LockBlockTResponse
 
getLockMode() - Method in class alluxio.master.file.meta.LockedInodePath
 
getLogDir() - Method in class alluxio.master.journal.ufs.UfsJournal
 
getLogName() - Method in class alluxio.wire.LogInfo
 
getLogs() - Method in class alluxio.master.journal.ufs.UfsJournalSnapshot
 
getLong(PropertyKey) - Method in interface alluxio.AlluxioConfiguration
Gets the long representation of the value for the given key.
getLong(PropertyKey) - Method in class alluxio.conf.InstancedConfiguration
 
getLong(PropertyKey) - Static method in class alluxio.Configuration
Gets the long representation of the value for the given key.
getLongValue() - Method in class alluxio.thrift.MetricValue
 
getLongValue() - Method in class alluxio.wire.MetricValue
 
getLostBlocks() - Method in interface alluxio.master.block.BlockMaster
 
getLostBlocks() - Method in class alluxio.master.block.DefaultBlockMaster
 
getLostFiles() - Method in class alluxio.master.file.DefaultFileSystemMaster
 
getLostFiles() - Method in interface alluxio.master.file.FileSystemMaster
 
getLostFiles() - Method in class alluxio.master.file.meta.FileSystemMasterView
 
getLostFiles(Lineage, FileSystemMasterView) - Static method in class alluxio.master.lineage.meta.LineageStateUtils
 
getLostWorkerCount() - Method in interface alluxio.master.block.BlockMaster
 
getLostWorkerCount() - Method in class alluxio.master.block.DefaultBlockMaster
 
getLostWorkerNum() - Method in class alluxio.thrift.BlockMasterInfo
 
getLostWorkerNum() - Method in class alluxio.wire.BlockMasterInfo
 
getLostWorkers() - Method in class alluxio.wire.AlluxioMasterInfo
 
getLostWorkersInfoList() - Method in interface alluxio.master.block.BlockMaster
 
getLostWorkersInfoList() - Method in class alluxio.master.block.DefaultBlockMaster
 
getMaster(Class<T>) - Method in class alluxio.master.AlluxioMasterProcess
 
getMaster(Class<T>) - Method in interface alluxio.master.MasterProcess
 
getMasterAddress() - Method in class alluxio.client.file.FileSystemContext
 
getMasterAddress() - Method in class alluxio.thrift.MetaMasterMasterService.getMasterId_args
the master address
getMasterAddresses() - Method in class alluxio.master.meta.DefaultMetaMaster
 
getMasterAddresses() - Method in interface alluxio.master.meta.MetaMaster
 
getMasterAddresses() - Method in class alluxio.multi.process.MultiProcessCluster
 
getMasterAddresses() - Method in class alluxio.thrift.MasterInfo
 
getMasterAddresses() - Method in class alluxio.wire.MasterInfo
 
getMasterAddressesIterator() - Method in class alluxio.thrift.MasterInfo
 
getMasterAddressesSize() - Method in class alluxio.thrift.MasterInfo
 
getMasterForEntry(Journal.JournalEntry) - Static method in class alluxio.master.journal.JournalEntryAssociation
 
getMasterHostnames() - Static method in class alluxio.cli.extensions.ExtensionsShellUtils
Gets list of masters in conf directory.
getMasterId(Address) - Method in class alluxio.master.meta.DefaultMetaMaster
 
getMasterId(Address) - Method in interface alluxio.master.meta.MetaMaster
Returns a master id for the given master, creating one if the master is new.
getMasterId(MasterNetAddress, GetMasterIdTOptions) - Method in class alluxio.master.meta.MetaMasterMasterServiceHandler
 
getMasterId() - Method in class alluxio.thrift.GetMasterIdTResponse
 
getMasterId(MasterNetAddress, GetMasterIdTOptions, AsyncMethodCallback) - Method in class alluxio.thrift.MetaMasterMasterService.AsyncClient
 
getMasterId(MasterNetAddress, GetMasterIdTOptions, AsyncMethodCallback) - Method in interface alluxio.thrift.MetaMasterMasterService.AsyncIface
 
getMasterId() - Constructor for class alluxio.thrift.MetaMasterMasterService.AsyncProcessor.getMasterId
 
getMasterId(MasterNetAddress, GetMasterIdTOptions) - Method in class alluxio.thrift.MetaMasterMasterService.Client
 
getMasterId(MasterNetAddress, GetMasterIdTOptions) - Method in interface alluxio.thrift.MetaMasterMasterService.Iface
Returns a master id for the given master address.
getMasterId() - Method in class alluxio.thrift.MetaMasterMasterService.masterHeartbeat_args
the id of the master
getMasterId() - Constructor for class alluxio.thrift.MetaMasterMasterService.Processor.getMasterId
 
getMasterId() - Method in class alluxio.thrift.MetaMasterMasterService.registerMaster_args
the id of the master
getMasterId_args() - Constructor for class alluxio.thrift.MetaMasterMasterService.getMasterId_args
 
getMasterId_args(MasterNetAddress, GetMasterIdTOptions) - Constructor for class alluxio.thrift.MetaMasterMasterService.getMasterId_args
 
getMasterId_args(MetaMasterMasterService.getMasterId_args) - Constructor for class alluxio.thrift.MetaMasterMasterService.getMasterId_args
Performs a deep copy on other.
getMasterId_call(MasterNetAddress, GetMasterIdTOptions, AsyncMethodCallback, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class alluxio.thrift.MetaMasterMasterService.AsyncClient.getMasterId_call
 
getMasterId_result() - Constructor for class alluxio.thrift.MetaMasterMasterService.getMasterId_result
 
getMasterId_result(GetMasterIdTResponse, AlluxioTException) - Constructor for class alluxio.thrift.MetaMasterMasterService.getMasterId_result
 
getMasterId_result(MetaMasterMasterService.getMasterId_result) - Constructor for class alluxio.thrift.MetaMasterMasterService.getMasterId_result
Performs a deep copy on other.
GetMasterIdTOptions - Class in alluxio.thrift
 
GetMasterIdTOptions() - Constructor for class alluxio.thrift.GetMasterIdTOptions
 
GetMasterIdTOptions(GetMasterIdTOptions) - Constructor for class alluxio.thrift.GetMasterIdTOptions
Performs a deep copy on other.
GetMasterIdTOptions._Fields - Enum in alluxio.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
GetMasterIdTResponse - Class in alluxio.thrift
 
GetMasterIdTResponse() - Constructor for class alluxio.thrift.GetMasterIdTResponse
 
GetMasterIdTResponse(long) - Constructor for class alluxio.thrift.GetMasterIdTResponse
 
GetMasterIdTResponse(GetMasterIdTResponse) - Constructor for class alluxio.thrift.GetMasterIdTResponse
Performs a deep copy on other.
GetMasterIdTResponse._Fields - Enum in alluxio.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
getMasterInfo(Set<MasterInfo.MasterInfoField>) - Method in interface alluxio.client.MetaMasterClient
 
getMasterInfo(Set<MasterInfo.MasterInfoField>) - Method in class alluxio.client.RetryHandlingMetaMasterClient
 
getMasterInfo(GetMasterInfoTOptions) - Method in class alluxio.master.meta.MetaMasterClientServiceHandler
 
getMasterInfo() - Method in class alluxio.thrift.GetMasterInfoTResponse
 
getMasterInfo(GetMasterInfoTOptions, AsyncMethodCallback) - Method in class alluxio.thrift.MetaMasterClientService.AsyncClient
 
getMasterInfo(GetMasterInfoTOptions, AsyncMethodCallback) - Method in interface alluxio.thrift.MetaMasterClientService.AsyncIface
 
getMasterInfo() - Constructor for class alluxio.thrift.MetaMasterClientService.AsyncProcessor.getMasterInfo
 
getMasterInfo(GetMasterInfoTOptions) - Method in class alluxio.thrift.MetaMasterClientService.Client
 
getMasterInfo(GetMasterInfoTOptions) - Method in interface alluxio.thrift.MetaMasterClientService.Iface
Returns information about the master.
getMasterInfo() - Constructor for class alluxio.thrift.MetaMasterClientService.Processor.getMasterInfo
 
getMasterInfo_args() - Constructor for class alluxio.thrift.MetaMasterClientService.getMasterInfo_args
 
getMasterInfo_args(GetMasterInfoTOptions) - Constructor for class alluxio.thrift.MetaMasterClientService.getMasterInfo_args
 
getMasterInfo_args(MetaMasterClientService.getMasterInfo_args) - Constructor for class alluxio.thrift.MetaMasterClientService.getMasterInfo_args
Performs a deep copy on other.
getMasterInfo_call(GetMasterInfoTOptions, AsyncMethodCallback, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class alluxio.thrift.MetaMasterClientService.AsyncClient.getMasterInfo_call
 
getMasterInfo_result() - Constructor for class alluxio.thrift.MetaMasterClientService.getMasterInfo_result
 
getMasterInfo_result(GetMasterInfoTResponse, AlluxioTException) - Constructor for class alluxio.thrift.MetaMasterClientService.getMasterInfo_result
 
getMasterInfo_result(MetaMasterClientService.getMasterInfo_result) - Constructor for class alluxio.thrift.MetaMasterClientService.getMasterInfo_result
Performs a deep copy on other.
GetMasterInfoTOptions - Class in alluxio.thrift
 
GetMasterInfoTOptions() - Constructor for class alluxio.thrift.GetMasterInfoTOptions
 
GetMasterInfoTOptions(Set<MasterInfoField>) - Constructor for class alluxio.thrift.GetMasterInfoTOptions
 
GetMasterInfoTOptions(GetMasterInfoTOptions) - Constructor for class alluxio.thrift.GetMasterInfoTOptions
Performs a deep copy on other.
GetMasterInfoTOptions._Fields - Enum in alluxio.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
GetMasterInfoTResponse - Class in alluxio.thrift
 
GetMasterInfoTResponse() - Constructor for class alluxio.thrift.GetMasterInfoTResponse
 
GetMasterInfoTResponse(MasterInfo) - Constructor for class alluxio.thrift.GetMasterInfoTResponse
 
GetMasterInfoTResponse(GetMasterInfoTResponse) - Constructor for class alluxio.thrift.GetMasterInfoTResponse
Performs a deep copy on other.
GetMasterInfoTResponse._Fields - Enum in alluxio.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
getMasterInquireClient() - Method in class alluxio.client.file.FileSystemContext
 
getMasterInquireClient() - Method in class alluxio.master.MasterClientConfig
 
getMasterInquireClient() - Method in class alluxio.multi.process.MultiProcessCluster
 
getMasterProcess() - Method in class alluxio.master.LocalAlluxioMaster
 
getMasterRpcAddresses() - Method in interface alluxio.master.MasterInquireClient
 
getMasterRpcAddresses() - Method in class alluxio.master.PollingMasterInquireClient
 
getMasterRpcAddresses() - Method in class alluxio.master.SingleMasterInquireClient
 
getMasterRpcAddresses() - Method in class alluxio.master.ZkMasterInquireClient
 
getMasterRpcPort() - Method in class alluxio.master.LocalAlluxioCluster
 
getMasterServiceHandler() - Method in class alluxio.master.metrics.DefaultMetricsMaster
 
getMasterServiceHandler() - Method in interface alluxio.master.metrics.MetricsMaster
 
getMasterServiceLoader() - Static method in class alluxio.ServiceUtils
 
getMasterServiceNames() - Static method in class alluxio.ServiceUtils
 
getMasterURI() - Method in class alluxio.master.LocalAlluxioCluster
 
getMaxCapacity() - Method in class alluxio.resource.DynamicResourcePool.Options
 
getMaxKeys() - Method in class alluxio.proxy.s3.ListBucketOptions
 
getMaxKeys() - Method in class alluxio.proxy.s3.ListBucketResult
 
getMaxSequenceNumber() - Static method in class alluxio.master.block.BlockId
 
getMaxUfsReadConcurrency() - Method in class alluxio.client.block.options.LockBlockOptions
 
getMaxUfsReadConcurrency() - Method in class alluxio.client.file.options.OpenFileOptions
 
getMaxUfsReadConcurrency() - Method in class alluxio.proto.dataserver.Protocol.OpenUfsBlockOptions.Builder
optional int32 maxUfsReadConcurrency = 4;
getMaxUfsReadConcurrency() - Method in class alluxio.proto.dataserver.Protocol.OpenUfsBlockOptions
optional int32 maxUfsReadConcurrency = 4;
getMaxUfsReadConcurrency() - Method in interface alluxio.proto.dataserver.Protocol.OpenUfsBlockOptionsOrBuilder
optional int32 maxUfsReadConcurrency = 4;
getMaxUfsReadConcurrency() - Method in class alluxio.thrift.LockBlockTOptions
 
getMechanismName() - Method in class alluxio.security.authentication.PlainSaslServer
 
getMechanismNames(Map<String, ?>) - Method in class alluxio.security.authentication.PlainSaslServer.Factory
 
getMergeStore() - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
optional .alluxio.proto.journal.MergeStoreEntry merge_store = 26;
getMergeStore() - Method in class alluxio.proto.journal.Journal.JournalEntry
optional .alluxio.proto.journal.MergeStoreEntry merge_store = 26;
getMergeStore() - Method in interface alluxio.proto.journal.Journal.JournalEntryOrBuilder
optional .alluxio.proto.journal.MergeStoreEntry merge_store = 26;
getMergeStoreBuilder() - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
optional .alluxio.proto.journal.MergeStoreEntry merge_store = 26;
getMergeStoreOrBuilder() - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
optional .alluxio.proto.journal.MergeStoreEntry merge_store = 26;
getMergeStoreOrBuilder() - Method in class alluxio.proto.journal.Journal.JournalEntry
optional .alluxio.proto.journal.MergeStoreEntry merge_store = 26;
getMergeStoreOrBuilder() - Method in interface alluxio.proto.journal.Journal.JournalEntryOrBuilder
optional .alluxio.proto.journal.MergeStoreEntry merge_store = 26;
getMessage() - Method in exception alluxio.exception.AggregateException
 
getMessage(Object...) - Method in enum alluxio.exception.ExceptionMessage
Formats the message of the exception.
getMessage() - Method in class alluxio.network.protocol.RPCProtoMessage
 
getMessage() - Method in class alluxio.proto.dataserver.Protocol.Response.Builder
optional string message = 2;
getMessage() - Method in class alluxio.proto.dataserver.Protocol.Response
optional string message = 2;
getMessage() - Method in interface alluxio.proto.dataserver.Protocol.ResponseOrBuilder
optional string message = 2;
getMessage() - Method in class alluxio.proxy.s3.S3Error
 
getMessage() - Method in class alluxio.RestUtils.ErrorResponse
 
getMessage() - Method in exception alluxio.thrift.AlluxioTException
 
getMessage() - Method in class alluxio.wire.LogInfo
 
getMessageBytes() - Method in class alluxio.proto.dataserver.Protocol.Response.Builder
optional string message = 2;
getMessageBytes() - Method in class alluxio.proto.dataserver.Protocol.Response
optional string message = 2;
getMessageBytes() - Method in interface alluxio.proto.dataserver.Protocol.ResponseOrBuilder
optional string message = 2;
getMessageWithUrl(String, Object...) - Method in enum alluxio.exception.ExceptionMessage
Formats the message of the exception with a url to consult.
getMetaClient() - Method in class alluxio.cli.fsadmin.command.Context
 
getMetaMasterClient() - Method in class alluxio.multi.process.MultiProcessCluster
 
getMeter() - Method in class alluxio.worker.netty.ReadRequestContext
 
getMeter() - Method in class alluxio.worker.netty.WriteRequestContext
 
getMetricName(String) - Static method in class alluxio.metrics.MetricsSystem
Converts a simple string to a qualified metric name based on the process type.
getMetricNameWithTags(String, String...) - Static method in class alluxio.metrics.Metric
Gets the metric name with the appendix of tags.
getMetricNameWithUserTag(String, String) - Static method in class alluxio.metrics.Metric
Gets a metric name with a specific user tag.
getMetricRegistry() - Method in class alluxio.metrics.source.JvmSource
 
getMetricRegistry() - Method in interface alluxio.metrics.source.Source
Gets the instance of the MetricRegistry.
getMetrics() - Method in interface alluxio.client.MetaMasterClient
Gets a map of metrics property names and their values from metrics system.
getMetrics() - Method in class alluxio.client.RetryHandlingMetaMasterClient
 
getMetrics() - Method in class alluxio.master.meta.AlluxioMasterRestServiceHandler
Deprecated.
since version 1.4 and will be removed in version 2.0
getMetrics(GetMetricsTOptions) - Method in class alluxio.master.meta.MetaMasterClientServiceHandler
 
getMetrics() - Method in class alluxio.thrift.BlockHeartbeatTOptions
 
getMetrics() - Method in class alluxio.thrift.BlockWorkerClientService.sessionBlockHeartbeat_args
deprecated since 1.3.0 and will be removed in 2.0
getMetrics() - Method in class alluxio.thrift.FileSystemWorkerClientService.sessionFileSystemHeartbeat_args
the client metrics.
getMetrics(GetMetricsTOptions, AsyncMethodCallback) - Method in class alluxio.thrift.MetaMasterClientService.AsyncClient
 
getMetrics(GetMetricsTOptions, AsyncMethodCallback) - Method in interface alluxio.thrift.MetaMasterClientService.AsyncIface
 
getMetrics() - Constructor for class alluxio.thrift.MetaMasterClientService.AsyncProcessor.getMetrics
 
getMetrics(GetMetricsTOptions) - Method in class alluxio.thrift.MetaMasterClientService.Client
 
getMetrics(GetMetricsTOptions) - Method in interface alluxio.thrift.MetaMasterClientService.Iface
Returns a map of metrics property names and their values from Alluxio metrics system.
getMetrics() - Constructor for class alluxio.thrift.MetaMasterClientService.Processor.getMetrics
 
getMetrics() - Method in class alluxio.thrift.MetricsHeartbeatTOptions
 
getMetrics() - Method in class alluxio.wire.AlluxioMasterInfo
 
getMetrics() - Method in class alluxio.wire.AlluxioWorkerInfo
 
getMetrics() - Method in class alluxio.worker.AlluxioWorkerRestServiceHandler
Deprecated.
since version 1.4 and will be removed in version 2.0
getMetrics_args() - Constructor for class alluxio.thrift.MetaMasterClientService.getMetrics_args
 
getMetrics_args(GetMetricsTOptions) - Constructor for class alluxio.thrift.MetaMasterClientService.getMetrics_args
 
getMetrics_args(MetaMasterClientService.getMetrics_args) - Constructor for class alluxio.thrift.MetaMasterClientService.getMetrics_args
Performs a deep copy on other.
getMetrics_call(GetMetricsTOptions, AsyncMethodCallback, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class alluxio.thrift.MetaMasterClientService.AsyncClient.getMetrics_call
 
getMetrics_result() - Constructor for class alluxio.thrift.MetaMasterClientService.getMetrics_result
 
getMetrics_result(GetMetricsTResponse, AlluxioTException) - Constructor for class alluxio.thrift.MetaMasterClientService.getMetrics_result
 
getMetrics_result(MetaMasterClientService.getMetrics_result) - Constructor for class alluxio.thrift.MetaMasterClientService.getMetrics_result
Performs a deep copy on other.
getMetricsByInstanceTypeAndName(MetricsSystem.InstanceType, String) - Method in class alluxio.master.metrics.MetricsStore
Gets all the metrics by instance type and the metric name.
getMetricsIterator() - Method in class alluxio.thrift.BlockHeartbeatTOptions
 
getMetricsIterator() - Method in class alluxio.thrift.BlockWorkerClientService.sessionBlockHeartbeat_args
 
getMetricsIterator() - Method in class alluxio.thrift.FileSystemWorkerClientService.sessionFileSystemHeartbeat_args
 
getMetricsIterator() - Method in class alluxio.thrift.MetricsHeartbeatTOptions
 
getMetricsMap() - Method in class alluxio.thrift.GetMetricsTResponse
 
getMetricsMapSize() - Method in class alluxio.thrift.GetMetricsTResponse
 
getMetricsSize() - Method in class alluxio.thrift.BlockHeartbeatTOptions
 
getMetricsSize() - Method in class alluxio.thrift.BlockWorkerClientService.sessionBlockHeartbeat_args
 
getMetricsSize() - Method in class alluxio.thrift.FileSystemWorkerClientService.sessionFileSystemHeartbeat_args
 
getMetricsSize() - Method in class alluxio.thrift.MetricsHeartbeatTOptions
 
GetMetricsTOptions - Class in alluxio.thrift
 
GetMetricsTOptions() - Constructor for class alluxio.thrift.GetMetricsTOptions
 
GetMetricsTOptions(GetMetricsTOptions) - Constructor for class alluxio.thrift.GetMetricsTOptions
Performs a deep copy on other.
GetMetricsTOptions._Fields - Enum in alluxio.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
GetMetricsTResponse - Class in alluxio.thrift
 
GetMetricsTResponse() - Constructor for class alluxio.thrift.GetMetricsTResponse
 
GetMetricsTResponse(Map<String, MetricValue>) - Constructor for class alluxio.thrift.GetMetricsTResponse
 
GetMetricsTResponse(GetMetricsTResponse) - Constructor for class alluxio.thrift.GetMetricsTResponse
Performs a deep copy on other.
GetMetricsTResponse._Fields - Enum in alluxio.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
getMinCapacity() - Method in class alluxio.resource.DynamicResourcePool.Options
 
getMode() - Method in class alluxio.client.file.options.CompleteUfsFileOptions
 
getMode() - Method in class alluxio.client.file.options.CreateDirectoryOptions
 
getMode() - Method in class alluxio.client.file.options.CreateFileOptions
 
getMode() - Method in class alluxio.client.file.options.CreateUfsFileOptions
 
getMode() - Method in class alluxio.client.file.options.OutStreamOptions
 
getMode() - Method in class alluxio.client.file.options.SetAttributeOptions
 
getMode() - Method in class alluxio.client.file.URIStatus
 
getMode() - Method in class alluxio.master.file.meta.Inode
 
getMode() - Method in class alluxio.master.file.meta.LockingScheme
 
getMode() - Method in class alluxio.master.file.options.CreatePathOptions
 
getMode() - Method in class alluxio.master.file.options.SetAttributeOptions
 
getMode() - Method in class alluxio.proto.dataserver.Protocol.CreateUfsFileOptions.Builder
optional int32 mode = 4;
getMode() - Method in class alluxio.proto.dataserver.Protocol.CreateUfsFileOptions
optional int32 mode = 4;
getMode() - Method in interface alluxio.proto.dataserver.Protocol.CreateUfsFileOptionsOrBuilder
optional int32 mode = 4;
getMode() - Method in class alluxio.proto.journal.File.InodeDirectoryEntry.Builder
optional int32 mode = 10;
getMode() - Method in class alluxio.proto.journal.File.InodeDirectoryEntry
optional int32 mode = 10;
getMode() - Method in interface alluxio.proto.journal.File.InodeDirectoryEntryOrBuilder
optional int32 mode = 10;
getMode() - Method in class alluxio.proto.journal.File.InodeFileEntry.Builder
optional int32 mode = 16;
getMode() - Method in class alluxio.proto.journal.File.InodeFileEntry
optional int32 mode = 16;
getMode() - Method in interface alluxio.proto.journal.File.InodeFileEntryOrBuilder
optional int32 mode = 16;
getMode() - Method in class alluxio.thrift.CompleteUfsFileTOptions
 
getMode() - Method in class alluxio.thrift.CreateDirectoryTOptions
 
getMode() - Method in class alluxio.thrift.CreateFileTOptions
 
getMode() - Method in class alluxio.thrift.CreateUfsFileTOptions
 
getMode() - Method in class alluxio.thrift.FileInfo
 
getMode() - Method in class alluxio.thrift.SetAttributeTOptions
 
getMode() - Method in class alluxio.underfs.ObjectUnderFileSystem.ObjectPermissions
 
getMode() - Method in class alluxio.underfs.options.CreateOptions
 
getMode() - Method in class alluxio.underfs.options.MkdirsOptions
 
getMode() - Method in class alluxio.underfs.UfsStatus
Gets the mode of the given path in short format, e.g 0700.
getMode() - Method in class alluxio.web.UIFileInfo
 
getMode() - Method in class alluxio.wire.FileInfo
 
getModificationTime() - Method in class alluxio.web.UIFileInfo
 
getModified() - Method in class alluxio.master.file.meta.InodeTree.CreatePathResult
 
getMountId() - Method in class alluxio.client.block.options.LockBlockOptions
 
getMountId() - Method in class alluxio.client.file.options.OutStreamOptions
 
getMountId() - Method in class alluxio.client.file.URIStatus
 
getMountId() - Method in class alluxio.master.file.meta.MountTable.Resolution
 
getMountId() - Method in class alluxio.master.file.meta.options.MountInfo
 
getMountId() - Method in class alluxio.proto.dataserver.Protocol.CreateUfsFileOptions.Builder
optional int64 mount_id = 5;
getMountId() - Method in class alluxio.proto.dataserver.Protocol.CreateUfsFileOptions
optional int64 mount_id = 5;
getMountId() - Method in interface alluxio.proto.dataserver.Protocol.CreateUfsFileOptionsOrBuilder
optional int64 mount_id = 5;
getMountId() - Method in class alluxio.proto.dataserver.Protocol.OpenUfsBlockOptions.Builder
optional int64 mountId = 5;
getMountId() - Method in class alluxio.proto.dataserver.Protocol.OpenUfsBlockOptions
optional int64 mountId = 5;
getMountId() - Method in interface alluxio.proto.dataserver.Protocol.OpenUfsBlockOptionsOrBuilder
optional int64 mountId = 5;
getMountId() - Method in class alluxio.proto.journal.File.AddMountPointEntry.Builder
optional int64 mount_id = 6;
getMountId() - Method in class alluxio.proto.journal.File.AddMountPointEntry
optional int64 mount_id = 6;
getMountId() - Method in interface alluxio.proto.journal.File.AddMountPointEntryOrBuilder
optional int64 mount_id = 6;
getMountId() - Method in class alluxio.thrift.FileInfo
 
getMountId() - Method in class alluxio.thrift.FileSystemMasterWorkerService.getUfsInfo_args
the id of the ufs
getMountId() - Method in class alluxio.thrift.LockBlockTOptions
 
getMountId() - Method in class alluxio.wire.FileInfo
 
getMountId() - Method in class alluxio.worker.block.meta.UnderFileSystemBlockMeta
 
getMountInfo(long) - Method in class alluxio.master.file.meta.MountTable
 
getMountPoint(AlluxioURI) - Method in class alluxio.master.file.meta.MountTable
Returns the closest ancestor mount point the given path is nested under.
getMountPoint() - Method in class alluxio.proto.journal.File.InodeDirectoryEntry.Builder
optional bool mount_point = 11;
getMountPoint() - Method in class alluxio.proto.journal.File.InodeDirectoryEntry
optional bool mount_point = 11;
getMountPoint() - Method in interface alluxio.proto.journal.File.InodeDirectoryEntryOrBuilder
optional bool mount_point = 11;
getMountPoint() - Method in class alluxio.util.UnixMountInfo
 
getMountPointInfo(AlluxioURI) - Method in class alluxio.master.file.DefaultFileSystemMaster
 
getMountPointInfo(AlluxioURI) - Method in interface alluxio.master.file.FileSystemMaster
Deprecated.
will be removed after 2.0
getMountPoints() - Method in class alluxio.master.file.FileSystemMasterClientRestServiceHandler
Deprecated.
 
getMountPoints() - Method in class alluxio.wire.AlluxioMasterInfo
 
getMountTable() - Method in class alluxio.client.file.BaseFileSystem
 
getMountTable() - Method in interface alluxio.client.file.FileSystem
Lists all mount points and their corresponding under storage addresses.
getMountTable() - Method in interface alluxio.client.file.FileSystemMasterClient
Lists all mount points and their corresponding under storage addresses.
getMountTable() - Method in class alluxio.client.file.RetryHandlingFileSystemMasterClient
 
getMountTable() - Method in class alluxio.master.file.DefaultFileSystemMaster
 
getMountTable() - Method in interface alluxio.master.file.FileSystemMaster
 
getMountTable() - Method in class alluxio.master.file.FileSystemMasterClientServiceHandler
 
getMountTable() - Method in class alluxio.master.file.meta.MountTable
Returns a copy of the current mount table, the mount table is a map from Alluxio file system URIs to the corresponding mount point information.
getMountTable(AsyncMethodCallback) - Method in class alluxio.thrift.FileSystemMasterClientService.AsyncClient
 
getMountTable(AsyncMethodCallback) - Method in interface alluxio.thrift.FileSystemMasterClientService.AsyncIface
 
getMountTable() - Constructor for class alluxio.thrift.FileSystemMasterClientService.AsyncProcessor.getMountTable
 
getMountTable() - Method in class alluxio.thrift.FileSystemMasterClientService.Client
 
getMountTable() - Method in interface alluxio.thrift.FileSystemMasterClientService.Iface
Returns a map from each Alluxio path to information of corresponding mount point
getMountTable() - Constructor for class alluxio.thrift.FileSystemMasterClientService.Processor.getMountTable
 
getMountTable() - Method in class alluxio.thrift.GetMountTableTResponse
 
getMountTable_args() - Constructor for class alluxio.thrift.FileSystemMasterClientService.getMountTable_args
 
getMountTable_args(FileSystemMasterClientService.getMountTable_args) - Constructor for class alluxio.thrift.FileSystemMasterClientService.getMountTable_args
Performs a deep copy on other.
getMountTable_call(AsyncMethodCallback, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class alluxio.thrift.FileSystemMasterClientService.AsyncClient.getMountTable_call
 
getMountTable_result() - Constructor for class alluxio.thrift.FileSystemMasterClientService.getMountTable_result
 
getMountTable_result(GetMountTableTResponse, AlluxioTException) - Constructor for class alluxio.thrift.FileSystemMasterClientService.getMountTable_result
 
getMountTable_result(FileSystemMasterClientService.getMountTable_result) - Constructor for class alluxio.thrift.FileSystemMasterClientService.getMountTable_result
Performs a deep copy on other.
getMountTableSize() - Method in class alluxio.thrift.GetMountTableTResponse
 
GetMountTableTResponse - Class in alluxio.thrift
 
GetMountTableTResponse() - Constructor for class alluxio.thrift.GetMountTableTResponse
 
GetMountTableTResponse(Map<String, MountPointInfo>) - Constructor for class alluxio.thrift.GetMountTableTResponse
 
GetMountTableTResponse(GetMountTableTResponse) - Constructor for class alluxio.thrift.GetMountTableTResponse
Performs a deep copy on other.
GetMountTableTResponse._Fields - Enum in alluxio.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
getMs(PropertyKey) - Method in interface alluxio.AlluxioConfiguration
Gets the time of key in millisecond unit.
getMs(String) - Static method in class alluxio.cli.fs.FileSystemShellUtils
Converts the input time into millisecond unit.
getMs(PropertyKey) - Method in class alluxio.conf.InstancedConfiguration
 
getMs(PropertyKey) - Static method in class alluxio.Configuration
Gets the time of key in millisecond unit.
getMultipartTemporaryDirForObject(String, String) - Static method in class alluxio.proxy.s3.S3RestUtils
 
getName() - Method in class alluxio.AlluxioURI
Gets the final component of the AlluxioURI.
getName() - Method in class alluxio.client.file.URIStatus
For example for the uri: alluxio://host:1000/foo/bar/baz, baz is the name.
getName() - Method in class alluxio.master.block.BlockMasterFactory
 
getName() - Method in class alluxio.master.block.DefaultBlockMaster
 
getName() - Method in class alluxio.master.file.DefaultFileSystemMaster
 
getName() - Method in class alluxio.master.file.FileSystemMasterFactory
 
getName() - Method in class alluxio.master.file.meta.Inode
 
getName() - Method in interface alluxio.master.journal.JournalEntryStateMachine
 
getName() - Method in class alluxio.master.keyvalue.DefaultKeyValueMaster
 
getName() - Method in class alluxio.master.keyvalue.KeyValueMasterFactory
 
getName() - Method in class alluxio.master.lineage.DefaultLineageMaster
 
getName() - Method in class alluxio.master.lineage.LineageMasterFactory
 
getName() - Method in interface alluxio.master.MasterFactory
 
getName() - Method in class alluxio.master.meta.DefaultMetaMaster
 
getName() - Method in class alluxio.master.meta.MetaMasterFactory
 
getName() - Method in class alluxio.master.metrics.DefaultMetricsMaster
 
getName() - Method in class alluxio.master.metrics.MetricsMasterFactory
 
getName() - Method in class alluxio.master.NoopMaster
 
getName() - Method in class alluxio.master.PrimarySelectorClient
 
getName() - Method in class alluxio.metrics.aggregator.SumInstancesAggregator
 
getName() - Method in class alluxio.metrics.Metric
 
getName() - Method in interface alluxio.metrics.MetricsAggregator
 
getName() - Method in class alluxio.metrics.MetricsFilter
 
getName() - Method in class alluxio.metrics.source.JvmSource
 
getName() - Method in interface alluxio.metrics.source.Source
Gets the name of the Source.
getName() - Method in class alluxio.PropertyKey
 
getName() - Method in class alluxio.proto.journal.File.InodeDirectoryEntry.Builder
optional string name = 3;
getName() - Method in class alluxio.proto.journal.File.InodeDirectoryEntry
optional string name = 3;
getName() - Method in interface alluxio.proto.journal.File.InodeDirectoryEntryOrBuilder
optional string name = 3;
getName() - Method in class alluxio.proto.journal.File.InodeFileEntry.Builder
optional string name = 3;
getName() - Method in class alluxio.proto.journal.File.InodeFileEntry
optional string name = 3;
getName() - Method in interface alluxio.proto.journal.File.InodeFileEntryOrBuilder
optional string name = 3;
getName() - Method in class alluxio.proxy.s3.ListBucketResult
 
getName() - Method in class alluxio.security.User
 
getName() - Method in interface alluxio.Server
 
getName() - Method in class alluxio.thrift.ConfigProperty
 
getName() - Method in class alluxio.thrift.FileInfo
 
getName() - Method in class alluxio.thrift.InconsistentProperty
 
getName() - Method in class alluxio.thrift.Metric
 
getName() - Method in class alluxio.underfs.ObjectUnderFileSystem.ObjectStatus
Gets the name of the object.
getName() - Method in class alluxio.underfs.UfsStatus
 
getName() - Method in class alluxio.util.logging.SamplingLogger
 
getName() - Method in class alluxio.web.UIFileInfo
 
getName() - Method in class alluxio.wire.ConfigProperty
 
getName() - Method in class alluxio.wire.FileInfo
 
getName() - Method in class alluxio.wire.InconsistentProperty
 
getName() - Method in class alluxio.worker.block.DefaultBlockWorker
 
getName() - Method in class alluxio.worker.file.DefaultFileSystemWorker
 
getName() - Method in class alluxio.worker.keyvalue.KeyValueWorker
 
getNameBytes() - Method in class alluxio.proto.journal.File.InodeDirectoryEntry.Builder
optional string name = 3;
getNameBytes() - Method in class alluxio.proto.journal.File.InodeDirectoryEntry
optional string name = 3;
getNameBytes() - Method in interface alluxio.proto.journal.File.InodeDirectoryEntryOrBuilder
optional string name = 3;
getNameBytes() - Method in class alluxio.proto.journal.File.InodeFileEntry.Builder
optional string name = 3;
getNameBytes() - Method in class alluxio.proto.journal.File.InodeFileEntry
optional string name = 3;
getNameBytes() - Method in interface alluxio.proto.journal.File.InodeFileEntryOrBuilder
optional string name = 3;
getNegotiatedProperty(String) - Method in class alluxio.security.authentication.PlainSaslServer
 
getNestedProperties(PropertyKey) - Method in interface alluxio.AlluxioConfiguration
Gets a set of properties that share a given common prefix key as a map.
getNestedProperties(PropertyKey) - Method in class alluxio.conf.InstancedConfiguration
 
getNestedProperties(PropertyKey) - Static method in class alluxio.Configuration
Gets a set of properties that share a given common prefix key as a map.
getNetAddress() - Method in class alluxio.client.block.BlockWorkerInfo
 
getNettyOutput() - Method in interface alluxio.network.protocol.databuffer.DataBuffer
Returns an object for writing to a netty channel.
getNettyOutput() - Method in class alluxio.network.protocol.databuffer.DataByteArrayChannel
 
getNettyOutput() - Method in class alluxio.network.protocol.databuffer.DataByteBuffer
 
getNettyOutput() - Method in class alluxio.network.protocol.databuffer.DataFileChannel
 
getNettyOutput() - Method in class alluxio.network.protocol.databuffer.DataNettyBuffer
We would not support this method in DataNettyBuffer because this class is only for reading netty buffers.
getNettyOutput() - Method in class alluxio.network.protocol.databuffer.DataNettyBufferV2
 
getNewBlockId() - Method in class alluxio.master.file.meta.InodeFile
 
getNewBlockIdForFile(AlluxioURI) - Method in interface alluxio.client.file.FileSystemMasterClient
 
getNewBlockIdForFile(AlluxioURI) - Method in class alluxio.client.file.RetryHandlingFileSystemMasterClient
 
getNewBlockIdForFile(AlluxioURI) - Method in class alluxio.master.file.DefaultFileSystemMaster
 
getNewBlockIdForFile(AlluxioURI) - Method in interface alluxio.master.file.FileSystemMaster
Gets a new block id for the next block of a given file to write to.
getNewBlockIdForFile(String) - Method in class alluxio.master.file.FileSystemMasterClientRestServiceHandler
Deprecated.
 
getNewBlockIdForFile(String, GetNewBlockIdForFileTOptions) - Method in class alluxio.master.file.FileSystemMasterClientServiceHandler
 
getNewBlockIdForFile(String, GetNewBlockIdForFileTOptions, AsyncMethodCallback) - Method in class alluxio.thrift.FileSystemMasterClientService.AsyncClient
 
getNewBlockIdForFile(String, GetNewBlockIdForFileTOptions, AsyncMethodCallback) - Method in interface alluxio.thrift.FileSystemMasterClientService.AsyncIface
 
getNewBlockIdForFile() - Constructor for class alluxio.thrift.FileSystemMasterClientService.AsyncProcessor.getNewBlockIdForFile
 
getNewBlockIdForFile(String, GetNewBlockIdForFileTOptions) - Method in class alluxio.thrift.FileSystemMasterClientService.Client
 
getNewBlockIdForFile(String, GetNewBlockIdForFileTOptions) - Method in interface alluxio.thrift.FileSystemMasterClientService.Iface
Generates a new block id for the given file.
getNewBlockIdForFile() - Constructor for class alluxio.thrift.FileSystemMasterClientService.Processor.getNewBlockIdForFile
 
getNewBlockIdForFile_args() - Constructor for class alluxio.thrift.FileSystemMasterClientService.getNewBlockIdForFile_args
 
getNewBlockIdForFile_args(String, GetNewBlockIdForFileTOptions) - Constructor for class alluxio.thrift.FileSystemMasterClientService.getNewBlockIdForFile_args
 
getNewBlockIdForFile_args(FileSystemMasterClientService.getNewBlockIdForFile_args) - Constructor for class alluxio.thrift.FileSystemMasterClientService.getNewBlockIdForFile_args
Performs a deep copy on other.
getNewBlockIdForFile_call(String, GetNewBlockIdForFileTOptions, AsyncMethodCallback, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class alluxio.thrift.FileSystemMasterClientService.AsyncClient.getNewBlockIdForFile_call
 
getNewBlockIdForFile_result() - Constructor for class alluxio.thrift.FileSystemMasterClientService.getNewBlockIdForFile_result
 
getNewBlockIdForFile_result(GetNewBlockIdForFileTResponse, AlluxioTException) - Constructor for class alluxio.thrift.FileSystemMasterClientService.getNewBlockIdForFile_result
 
getNewBlockIdForFile_result(FileSystemMasterClientService.getNewBlockIdForFile_result) - Constructor for class alluxio.thrift.FileSystemMasterClientService.getNewBlockIdForFile_result
Performs a deep copy on other.
GetNewBlockIdForFileTOptions - Class in alluxio.thrift
 
GetNewBlockIdForFileTOptions() - Constructor for class alluxio.thrift.GetNewBlockIdForFileTOptions
 
GetNewBlockIdForFileTOptions(GetNewBlockIdForFileTOptions) - Constructor for class alluxio.thrift.GetNewBlockIdForFileTOptions
Performs a deep copy on other.
GetNewBlockIdForFileTOptions._Fields - Enum in alluxio.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
GetNewBlockIdForFileTResponse - Class in alluxio.thrift
 
GetNewBlockIdForFileTResponse() - Constructor for class alluxio.thrift.GetNewBlockIdForFileTResponse
 
GetNewBlockIdForFileTResponse(long) - Constructor for class alluxio.thrift.GetNewBlockIdForFileTResponse
 
GetNewBlockIdForFileTResponse(GetNewBlockIdForFileTResponse) - Constructor for class alluxio.thrift.GetNewBlockIdForFileTResponse
Performs a deep copy on other.
GetNewBlockIdForFileTResponse._Fields - Enum in alluxio.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
getNewContainerId() - Method in class alluxio.master.block.BlockContainerIdGenerator
 
getNewContainerId() - Method in interface alluxio.master.block.ContainerIdGenerable
 
getNewContainerId() - Method in class alluxio.master.block.DefaultBlockMaster
 
getNewPath() - Method in class alluxio.thrift.KeyValueMasterClientService.renameStore_args
the new path of the store
getNewStoreId() - Method in class alluxio.proto.journal.KeyValue.RenameStoreEntry.Builder
optional int64 new_store_id = 2;
getNewStoreId() - Method in class alluxio.proto.journal.KeyValue.RenameStoreEntry
optional int64 new_store_id = 2;
getNewStoreId() - Method in interface alluxio.proto.journal.KeyValue.RenameStoreEntryOrBuilder
optional int64 new_store_id = 2;
getNextChunk() - Method in interface alluxio.underfs.ObjectUnderFileSystem.ObjectListingChunk
Gets next chunk of object listings.
getNextContainerId() - Method in class alluxio.proto.journal.Block.BlockContainerIdGeneratorEntry.Builder
optional int64 next_container_id = 1;
getNextContainerId() - Method in class alluxio.proto.journal.Block.BlockContainerIdGeneratorEntry
optional int64 next_container_id = 1;
getNextContainerId() - Method in interface alluxio.proto.journal.Block.BlockContainerIdGeneratorEntryOrBuilder
optional int64 next_container_id = 1;
getNextContinuationToken() - Method in class alluxio.proxy.s3.ListBucketResult
 
getNextInputStream() - Method in interface alluxio.master.journalv0.JournalReader
 
getNextInputStream() - Method in class alluxio.master.journalv0.ufs.UfsJournalReader
 
getNextKeys(long, ByteBuffer, int) - Method in class alluxio.client.keyvalue.KeyValueWorkerClient
Gets a batch of keys next to the current key in the partition.
getNextKeys(long, ByteBuffer, int, GetNextKeysTOptions, AsyncMethodCallback) - Method in class alluxio.thrift.KeyValueWorkerClientService.AsyncClient
 
getNextKeys(long, ByteBuffer, int, GetNextKeysTOptions, AsyncMethodCallback) - Method in interface alluxio.thrift.KeyValueWorkerClientService.AsyncIface
 
getNextKeys() - Constructor for class alluxio.thrift.KeyValueWorkerClientService.AsyncProcessor.getNextKeys
 
getNextKeys(long, ByteBuffer, int, GetNextKeysTOptions) - Method in class alluxio.thrift.KeyValueWorkerClientService.Client
 
getNextKeys(long, ByteBuffer, int, GetNextKeysTOptions) - Method in interface alluxio.thrift.KeyValueWorkerClientService.Iface
Gets a batch of keys next to the given key in the partition.
getNextKeys() - Constructor for class alluxio.thrift.KeyValueWorkerClientService.Processor.getNextKeys
 
getNextKeys(long, ByteBuffer, int, GetNextKeysTOptions) - Method in class alluxio.worker.keyvalue.KeyValueWorkerClientServiceHandler
 
getNextKeys_args() - Constructor for class alluxio.thrift.KeyValueWorkerClientService.getNextKeys_args
 
getNextKeys_args(long, ByteBuffer, int, GetNextKeysTOptions) - Constructor for class alluxio.thrift.KeyValueWorkerClientService.getNextKeys_args
 
getNextKeys_args(KeyValueWorkerClientService.getNextKeys_args) - Constructor for class alluxio.thrift.KeyValueWorkerClientService.getNextKeys_args
Performs a deep copy on other.
getNextKeys_call(long, ByteBuffer, int, GetNextKeysTOptions, AsyncMethodCallback, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class alluxio.thrift.KeyValueWorkerClientService.AsyncClient.getNextKeys_call
 
getNextKeys_result() - Constructor for class alluxio.thrift.KeyValueWorkerClientService.getNextKeys_result
 
getNextKeys_result(GetNextKeysTResponse, AlluxioTException) - Constructor for class alluxio.thrift.KeyValueWorkerClientService.getNextKeys_result
 
getNextKeys_result(KeyValueWorkerClientService.getNextKeys_result) - Constructor for class alluxio.thrift.KeyValueWorkerClientService.getNextKeys_result
Performs a deep copy on other.
GetNextKeysTOptions - Class in alluxio.thrift
 
GetNextKeysTOptions() - Constructor for class alluxio.thrift.GetNextKeysTOptions
 
GetNextKeysTOptions(GetNextKeysTOptions) - Constructor for class alluxio.thrift.GetNextKeysTOptions
Performs a deep copy on other.
GetNextKeysTOptions._Fields - Enum in alluxio.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
GetNextKeysTResponse - Class in alluxio.thrift
 
GetNextKeysTResponse() - Constructor for class alluxio.thrift.GetNextKeysTResponse
 
GetNextKeysTResponse(List<ByteBuffer>) - Constructor for class alluxio.thrift.GetNextKeysTResponse
 
GetNextKeysTResponse(GetNextKeysTResponse) - Constructor for class alluxio.thrift.GetNextKeysTResponse
Performs a deep copy on other.
GetNextKeysTResponse._Fields - Enum in alluxio.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
getNextSequenceNumber() - Method in interface alluxio.master.journal.JournalReader
Gets the the sequence number of the next journal log entry to read.
getNextSequenceNumber() - Method in class alluxio.master.journal.noop.NoopJournalReader
 
getNextSequenceNumber() - Method in class alluxio.master.journal.options.JournalReaderOptions
 
getNextSequenceNumber() - Method in class alluxio.master.journal.options.JournalWriterOptions
 
getNextSequenceNumber() - Method in class alluxio.master.journal.ufs.UfsJournalCheckpointThread
getNextSequenceNumber() - Method in class alluxio.master.journal.ufs.UfsJournalReader
 
getNextSequenceNumber() - Method in interface alluxio.master.journalv0.JournalWriter
 
getNextSequenceNumber() - Method in class alluxio.master.journalv0.ufs.UfsJournalWriter
 
getNextSequenceNumberToCheckpoint() - Method in class alluxio.master.journal.ufs.UfsJournal
 
getNextSequenceNumberToWrite() - Method in class alluxio.master.journal.ufs.UfsJournal
 
getNextTier(StorageTierView) - Method in class alluxio.worker.block.BlockMetadataManagerView
Gets the next storage tier view.
getNoCache() - Method in class alluxio.proto.dataserver.Protocol.OpenUfsBlockOptions.Builder
optional bool no_cache = 6;
getNoCache() - Method in class alluxio.proto.dataserver.Protocol.OpenUfsBlockOptions
optional bool no_cache = 6;
getNoCache() - Method in interface alluxio.proto.dataserver.Protocol.OpenUfsBlockOptionsOrBuilder
optional bool no_cache = 6;
getNumber() - Method in enum alluxio.proto.dataserver.Protocol.ReadResponse.Type
 
getNumber() - Method in enum alluxio.proto.dataserver.Protocol.RequestType
 
getNumber() - Method in enum alluxio.proto.journal.File.PTtlAction
 
getNumber() - Method in enum alluxio.proto.journal.File.UfsMode
 
getNumber() - Method in enum alluxio.proto.status.Status.PStatus
 
getNumberOfBlocks() - Method in interface alluxio.worker.block.BlockStoreMeta
getNumberOfBlocks() - Method in class alluxio.worker.block.DefaultBlockStoreMeta
 
getNumberOfChildren() - Method in class alluxio.master.file.meta.InodeDirectory
 
getNumberOfPaths() - Method in class alluxio.master.file.DefaultFileSystemMaster
 
getNumberOfPaths() - Method in interface alluxio.master.file.FileSystemMaster
 
getNumberOfPinnedFiles() - Method in class alluxio.master.file.DefaultFileSystemMaster
 
getNumberOfPinnedFiles() - Method in interface alluxio.master.file.FileSystemMaster
 
getNumKeys() - Method in class alluxio.thrift.KeyValueWorkerClientService.getNextKeys_args
maximum number of keys to get
getNumLocations() - Method in class alluxio.master.block.meta.MasterBlockInfo
 
getNumSector(String, String) - Static method in class alluxio.util.HFSUtils
Converts the memory size to number of sectors.
getNumSinks() - Static method in class alluxio.metrics.MetricsSystem
 
getObjectListingChunk(String, boolean) - Method in class alluxio.underfs.cos.COSUnderFileSystem
 
getObjectListingChunk(String, boolean) - Method in class alluxio.underfs.gcs.GCSUnderFileSystem
 
getObjectListingChunk(String, boolean) - Method in class alluxio.underfs.ObjectUnderFileSystem
Gets a (partial) object listing result for the given key.
getObjectListingChunk(String, boolean) - Method in class alluxio.underfs.oss.OSSUnderFileSystem
 
getObjectListingChunk(String, boolean) - Method in class alluxio.underfs.s3a.S3AUnderFileSystem
 
getObjectListingChunk(String, boolean) - Method in class alluxio.underfs.swift.SwiftUnderFileSystem
 
getObjectListingChunkForPath(String, boolean) - Method in class alluxio.underfs.ObjectUnderFileSystem
Gets a (partial) object listing for the given path.
getObjectMetadata(String, String) - Method in class alluxio.proxy.s3.S3RestServiceHandler
 
getObjectOrListParts(String, String, Long) - Method in class alluxio.proxy.s3.S3RestServiceHandler
 
getObjectStatus(String) - Method in class alluxio.underfs.cos.COSUnderFileSystem
 
getObjectStatus(String) - Method in class alluxio.underfs.gcs.GCSUnderFileSystem
 
getObjectStatus(String) - Method in class alluxio.underfs.ObjectUnderFileSystem
Get metadata information about object.
getObjectStatus(String) - Method in class alluxio.underfs.oss.OSSUnderFileSystem
 
getObjectStatus(String) - Method in class alluxio.underfs.s3a.S3AUnderFileSystem
 
getObjectStatus(String) - Method in class alluxio.underfs.swift.SwiftUnderFileSystem
 
getObjectStatuses() - Method in interface alluxio.underfs.ObjectUnderFileSystem.ObjectListingChunk
Returns objects in a pseudo-directory which may be a file or a directory.
getOffset() - Method in class alluxio.client.block.options.LockBlockOptions
 
getOffset() - Method in class alluxio.proto.dataserver.Protocol.ReadRequest.Builder
optional int64 offset = 2;
getOffset() - Method in class alluxio.proto.dataserver.Protocol.ReadRequest
optional int64 offset = 2;
getOffset() - Method in interface alluxio.proto.dataserver.Protocol.ReadRequestOrBuilder
optional int64 offset = 2;
getOffset() - Method in class alluxio.proto.dataserver.Protocol.WriteRequest.Builder
optional int64 offset = 3;
getOffset() - Method in class alluxio.proto.dataserver.Protocol.WriteRequest
optional int64 offset = 3;
getOffset() - Method in interface alluxio.proto.dataserver.Protocol.WriteRequestOrBuilder
optional int64 offset = 3;
getOffset() - Method in class alluxio.thrift.FileBlockInfo
 
getOffset() - Method in class alluxio.thrift.LockBlockTOptions
 
getOffset() - Method in class alluxio.underfs.options.FileLocationOptions
 
getOffset() - Method in class alluxio.underfs.options.OpenOptions
 
getOffset() - Method in class alluxio.wire.FileBlockInfo
 
getOffset() - Method in class alluxio.worker.block.meta.UnderFileSystemBlockMeta
 
getOffsetInFile() - Method in class alluxio.proto.dataserver.Protocol.OpenUfsBlockOptions.Builder
optional int64 offset_in_file = 2;
getOffsetInFile() - Method in class alluxio.proto.dataserver.Protocol.OpenUfsBlockOptions
optional int64 offset_in_file = 2;
getOffsetInFile() - Method in interface alluxio.proto.dataserver.Protocol.OpenUfsBlockOptionsOrBuilder
optional int64 offset_in_file = 2;
getOldPath() - Method in class alluxio.thrift.KeyValueMasterClientService.renameStore_args
the old path of the store
getOldStoreId() - Method in class alluxio.proto.journal.KeyValue.RenameStoreEntry.Builder
optional int64 old_store_id = 1;
getOldStoreId() - Method in class alluxio.proto.journal.KeyValue.RenameStoreEntry
optional int64 old_store_id = 1;
getOldStoreId() - Method in interface alluxio.proto.journal.KeyValue.RenameStoreEntryOrBuilder
optional int64 old_store_id = 1;
getOnlyReserveSpace() - Method in class alluxio.proto.dataserver.Protocol.LocalBlockCreateRequest.Builder
optional bool only_reserve_space = 5;
getOnlyReserveSpace() - Method in class alluxio.proto.dataserver.Protocol.LocalBlockCreateRequest
optional bool only_reserve_space = 5;
getOnlyReserveSpace() - Method in interface alluxio.proto.dataserver.Protocol.LocalBlockCreateRequestOrBuilder
optional bool only_reserve_space = 5;
getOnTierPercentage(String) - Method in class alluxio.web.UIFileInfo
 
getOpenUfsBlockOptions(long) - Method in class alluxio.client.file.options.InStreamOptions
 
getOpenUfsBlockOptions() - Method in class alluxio.proto.dataserver.Protocol.AsyncCacheRequest.Builder
optional .alluxio.proto.dataserver.OpenUfsBlockOptions open_ufs_block_options = 4;
getOpenUfsBlockOptions() - Method in class alluxio.proto.dataserver.Protocol.AsyncCacheRequest
optional .alluxio.proto.dataserver.OpenUfsBlockOptions open_ufs_block_options = 4;
getOpenUfsBlockOptions() - Method in interface alluxio.proto.dataserver.Protocol.AsyncCacheRequestOrBuilder
optional .alluxio.proto.dataserver.OpenUfsBlockOptions open_ufs_block_options = 4;
getOpenUfsBlockOptions() - Method in class alluxio.proto.dataserver.Protocol.ReadRequest.Builder
optional .alluxio.proto.dataserver.OpenUfsBlockOptions open_ufs_block_options = 6;
getOpenUfsBlockOptions() - Method in class alluxio.proto.dataserver.Protocol.ReadRequest
optional .alluxio.proto.dataserver.OpenUfsBlockOptions open_ufs_block_options = 6;
getOpenUfsBlockOptions() - Method in interface alluxio.proto.dataserver.Protocol.ReadRequestOrBuilder
optional .alluxio.proto.dataserver.OpenUfsBlockOptions open_ufs_block_options = 6;
getOpenUfsBlockOptions() - Method in class alluxio.worker.netty.BlockReadRequest
 
getOpenUfsBlockOptionsBuilder() - Method in class alluxio.proto.dataserver.Protocol.AsyncCacheRequest.Builder
optional .alluxio.proto.dataserver.OpenUfsBlockOptions open_ufs_block_options = 4;
getOpenUfsBlockOptionsBuilder() - Method in class alluxio.proto.dataserver.Protocol.ReadRequest.Builder
optional .alluxio.proto.dataserver.OpenUfsBlockOptions open_ufs_block_options = 6;
getOpenUfsBlockOptionsOrBuilder() - Method in class alluxio.proto.dataserver.Protocol.AsyncCacheRequest.Builder
optional .alluxio.proto.dataserver.OpenUfsBlockOptions open_ufs_block_options = 4;
getOpenUfsBlockOptionsOrBuilder() - Method in class alluxio.proto.dataserver.Protocol.AsyncCacheRequest
optional .alluxio.proto.dataserver.OpenUfsBlockOptions open_ufs_block_options = 4;
getOpenUfsBlockOptionsOrBuilder() - Method in interface alluxio.proto.dataserver.Protocol.AsyncCacheRequestOrBuilder
optional .alluxio.proto.dataserver.OpenUfsBlockOptions open_ufs_block_options = 4;
getOpenUfsBlockOptionsOrBuilder() - Method in class alluxio.proto.dataserver.Protocol.ReadRequest.Builder
optional .alluxio.proto.dataserver.OpenUfsBlockOptions open_ufs_block_options = 6;
getOpenUfsBlockOptionsOrBuilder() - Method in class alluxio.proto.dataserver.Protocol.ReadRequest
optional .alluxio.proto.dataserver.OpenUfsBlockOptions open_ufs_block_options = 6;
getOpenUfsBlockOptionsOrBuilder() - Method in interface alluxio.proto.dataserver.Protocol.ReadRequestOrBuilder
optional .alluxio.proto.dataserver.OpenUfsBlockOptions open_ufs_block_options = 6;
getOperationMode(Map<String, UnderFileSystem.UfsMode>) - Method in class alluxio.underfs.BaseUnderFileSystem
 
getOperationMode(Map<String, UnderFileSystem.UfsMode>) - Method in interface alluxio.underfs.UnderFileSystem
An UnderFileSystem may be composed of one or more "physical UFS"s.
getOperationMode(Map<String, UnderFileSystem.UfsMode>) - Method in class alluxio.underfs.UnderFileSystemWithLogging
 
getOperationTimeMs() - Method in class alluxio.master.file.options.CompleteFileOptions
 
getOperationTimeMs() - Method in class alluxio.master.file.options.CreatePathOptions
 
getOperationTimeMs() - Method in class alluxio.master.file.options.RenameOptions
 
getOperationTimeMs() - Method in class alluxio.master.file.options.SetAttributeOptions
 
getOpTimeMs() - Method in class alluxio.proto.journal.File.CompleteFileEntry.Builder
optional int64 op_time_ms = 4;
getOpTimeMs() - Method in class alluxio.proto.journal.File.CompleteFileEntry
optional int64 op_time_ms = 4;
getOpTimeMs() - Method in interface alluxio.proto.journal.File.CompleteFileEntryOrBuilder
optional int64 op_time_ms = 4;
getOpTimeMs() - Method in class alluxio.proto.journal.File.DeleteFileEntry.Builder
optional int64 op_time_ms = 3;
getOpTimeMs() - Method in class alluxio.proto.journal.File.DeleteFileEntry
optional int64 op_time_ms = 3;
getOpTimeMs() - Method in interface alluxio.proto.journal.File.DeleteFileEntryOrBuilder
optional int64 op_time_ms = 3;
getOpTimeMs() - Method in class alluxio.proto.journal.File.PersistFileEntry.Builder
optional int64 op_time_ms = 3;
getOpTimeMs() - Method in class alluxio.proto.journal.File.PersistFileEntry
optional int64 op_time_ms = 3;
getOpTimeMs() - Method in interface alluxio.proto.journal.File.PersistFileEntryOrBuilder
optional int64 op_time_ms = 3;
getOpTimeMs() - Method in class alluxio.proto.journal.File.RenameEntry.Builder
optional int64 op_time_ms = 3;
getOpTimeMs() - Method in class alluxio.proto.journal.File.RenameEntry
optional int64 op_time_ms = 3;
getOpTimeMs() - Method in interface alluxio.proto.journal.File.RenameEntryOrBuilder
optional int64 op_time_ms = 3;
getOpTimeMs() - Method in class alluxio.proto.journal.File.SetAttributeEntry.Builder
optional int64 op_time_ms = 2;
getOpTimeMs() - Method in class alluxio.proto.journal.File.SetAttributeEntry
optional int64 op_time_ms = 2;
getOpTimeMs() - Method in interface alluxio.proto.journal.File.SetAttributeEntryOrBuilder
optional int64 op_time_ms = 2;
getOptionList() - Method in class alluxio.cli.validation.AbstractValidationTask
 
getOptionList() - Method in class alluxio.cli.validation.HdfsValidationTask
 
getOptionList() - Method in interface alluxio.cli.validation.ValidationTask
 
getOptions() - Method in interface alluxio.cli.Command
 
getOptions() - Method in class alluxio.cli.fs.command.CheckConsistencyCommand
 
getOptions() - Method in class alluxio.cli.fs.command.ChgrpCommand
 
getOptions() - Method in class alluxio.cli.fs.command.ChmodCommand
 
getOptions() - Method in class alluxio.cli.fs.command.ChownCommand
 
getOptions() - Method in class alluxio.cli.fs.command.CopyFromLocalCommand
 
getOptions() - Method in class alluxio.cli.fs.command.CpCommand
 
getOptions() - Method in class alluxio.cli.fs.command.FreeCommand
 
getOptions() - Method in class alluxio.cli.fs.command.HeadCommand
 
getOptions() - Method in class alluxio.cli.fs.command.LoadCommand
 
getOptions() - Method in class alluxio.cli.fs.command.LsCommand
 
getOptions() - Method in class alluxio.cli.fs.command.MountCommand
 
getOptions() - Method in class alluxio.cli.fs.command.RmCommand
 
getOptions() - Method in class alluxio.cli.fs.command.SetTtlCommand
 
getOptions() - Method in class alluxio.cli.fs.command.StatCommand
 
getOptions() - Method in class alluxio.cli.fs.command.TailCommand
 
getOptions() - Method in class alluxio.cli.fs.command.TestCommand
 
getOptions() - Method in class alluxio.cli.fsadmin.command.BackupCommand
 
getOptions() - Method in class alluxio.cli.fsadmin.command.DoctorCommand
 
getOptions() - Method in class alluxio.cli.fsadmin.command.GetBlockInfoCommand
 
getOptions() - Method in class alluxio.cli.fsadmin.command.ReportCommand
 
getOptions() - Method in class alluxio.cli.fsadmin.command.UfsCommand
 
getOptions() - Method in class alluxio.client.file.options.InStreamOptions
 
getOptions() - Method in class alluxio.master.file.meta.options.MountInfo
 
getOptions() - Method in class alluxio.thrift.AlluxioService.getServiceVersion_args
the method options
getOptions() - Method in class alluxio.thrift.BlockMasterClientService.getBlockInfo_args
the method options
getOptions() - Method in class alluxio.thrift.BlockMasterClientService.getBlockMasterInfo_args
the method options
getOptions() - Method in class alluxio.thrift.BlockMasterClientService.getCapacityBytes_args
the method options
getOptions() - Method in class alluxio.thrift.BlockMasterClientService.getUsedBytes_args
the method options
getOptions() - Method in class alluxio.thrift.BlockMasterClientService.getWorkerInfoList_args
the method options
getOptions() - Method in class alluxio.thrift.BlockMasterClientService.getWorkerReport_args
the method options
getOptions() - Method in class alluxio.thrift.BlockMasterWorkerService.blockHeartbeat_args
the method options
getOptions() - Method in class alluxio.thrift.BlockMasterWorkerService.commitBlock_args
the method options
getOptions() - Method in class alluxio.thrift.BlockMasterWorkerService.getWorkerId_args
the method options
getOptions() - Method in class alluxio.thrift.BlockMasterWorkerService.registerWorker_args
the method options
getOptions() - Method in class alluxio.thrift.BlockWorkerClientService.accessBlock_args
the method options
getOptions() - Method in class alluxio.thrift.BlockWorkerClientService.cacheBlock_args
the method options
getOptions() - Method in class alluxio.thrift.BlockWorkerClientService.cancelBlock_args
the method options
getOptions() - Method in class alluxio.thrift.BlockWorkerClientService.lockBlock_args
the lock method options
getOptions() - Method in class alluxio.thrift.BlockWorkerClientService.promoteBlock_args
the method options
getOptions() - Method in class alluxio.thrift.BlockWorkerClientService.removeBlock_args
the method options
getOptions() - Method in class alluxio.thrift.BlockWorkerClientService.requestBlockLocation_args
the method options
getOptions() - Method in class alluxio.thrift.BlockWorkerClientService.requestSpace_args
the method options
getOptions() - Method in class alluxio.thrift.BlockWorkerClientService.sessionBlockHeartbeat_args
the method options
getOptions() - Method in class alluxio.thrift.BlockWorkerClientService.unlockBlock_args
the method options
getOptions() - Method in class alluxio.thrift.FileSystemMasterClientService.checkConsistency_args
the method options
getOptions() - Method in class alluxio.thrift.FileSystemMasterClientService.completeFile_args
the method options
getOptions() - Method in class alluxio.thrift.FileSystemMasterClientService.createDirectory_args
the method options
getOptions() - Method in class alluxio.thrift.FileSystemMasterClientService.createFile_args
the options for creating the file
getOptions() - Method in class alluxio.thrift.FileSystemMasterClientService.free_args
the options for freeing a path
getOptions() - Method in class alluxio.thrift.FileSystemMasterClientService.getFilePath_args
the file id
getOptions() - Method in class alluxio.thrift.FileSystemMasterClientService.getNewBlockIdForFile_args
the method options
getOptions() - Method in class alluxio.thrift.FileSystemMasterClientService.getStatus_args
the method options
getOptions() - Method in class alluxio.thrift.FileSystemMasterClientService.listStatus_args
listStatus options
getOptions() - Method in class alluxio.thrift.FileSystemMasterClientService.loadMetadata_args
the method options
getOptions() - Method in class alluxio.thrift.FileSystemMasterClientService.mount_args
the options for creating the mount point
getOptions() - Method in class alluxio.thrift.FileSystemMasterClientService.remove_args
the options for deleting the file
getOptions() - Method in class alluxio.thrift.FileSystemMasterClientService.rename_args
the method options
getOptions() - Method in class alluxio.thrift.FileSystemMasterClientService.scheduleAsyncPersistence_args
the method options
getOptions() - Method in class alluxio.thrift.FileSystemMasterClientService.setAttribute_args
the method options
getOptions() - Method in class alluxio.thrift.FileSystemMasterClientService.unmount_args
the method options
getOptions() - Method in class alluxio.thrift.FileSystemMasterClientService.updateUfsMode_args
the method options
getOptions() - Method in class alluxio.thrift.FileSystemMasterWorkerService.fileSystemHeartbeat_args
the method options
getOptions() - Method in class alluxio.thrift.FileSystemMasterWorkerService.getFileInfo_args
the method options
getOptions() - Method in class alluxio.thrift.FileSystemMasterWorkerService.getPinnedFileIds_args
the method options
getOptions() - Method in class alluxio.thrift.FileSystemMasterWorkerService.getUfsInfo_args
the method options
getOptions() - Method in class alluxio.thrift.FileSystemWorkerClientService.cancelUfsFile_args
the options for canceling the file
getOptions() - Method in class alluxio.thrift.FileSystemWorkerClientService.closeUfsFile_args
the options for closing the file
getOptions() - Method in class alluxio.thrift.FileSystemWorkerClientService.completeUfsFile_args
the options for completing the file
getOptions() - Method in class alluxio.thrift.FileSystemWorkerClientService.createUfsFile_args
the options for creating the file
getOptions() - Method in class alluxio.thrift.FileSystemWorkerClientService.openUfsFile_args
the options for opening the file
getOptions() - Method in class alluxio.thrift.FileSystemWorkerClientService.sessionFileSystemHeartbeat_args
the method options
getOptions() - Method in class alluxio.thrift.KeyValueMasterClientService.completePartition_args
the method options
getOptions() - Method in class alluxio.thrift.KeyValueMasterClientService.completeStore_args
the method options
getOptions() - Method in class alluxio.thrift.KeyValueMasterClientService.createStore_args
the method options
getOptions() - Method in class alluxio.thrift.KeyValueMasterClientService.deleteStore_args
the method options
getOptions() - Method in class alluxio.thrift.KeyValueMasterClientService.getPartitionInfo_args
the method options
getOptions() - Method in class alluxio.thrift.KeyValueMasterClientService.mergeStore_args
the method options
getOptions() - Method in class alluxio.thrift.KeyValueMasterClientService.renameStore_args
the method options
getOptions() - Method in class alluxio.thrift.KeyValueWorkerClientService.get_args
the method options
getOptions() - Method in class alluxio.thrift.KeyValueWorkerClientService.getNextKeys_args
the method options
getOptions() - Method in class alluxio.thrift.KeyValueWorkerClientService.getSize_args
the method options
getOptions() - Method in class alluxio.thrift.LineageMasterClientService.createLineage_args
the method options
getOptions() - Method in class alluxio.thrift.LineageMasterClientService.deleteLineage_args
the method options
getOptions() - Method in class alluxio.thrift.LineageMasterClientService.getLineageInfoList_args
the method options
getOptions() - Method in class alluxio.thrift.LineageMasterClientService.reinitializeFile_args
the method options
getOptions() - Method in class alluxio.thrift.LineageMasterClientService.reportLostFile_args
the method options
getOptions() - Method in class alluxio.thrift.MetaMasterClientService.backup_args
the method options
getOptions() - Method in class alluxio.thrift.MetaMasterClientService.getConfigReport_args
the method options
getOptions() - Method in class alluxio.thrift.MetaMasterClientService.getConfiguration_args
the method options
getOptions() - Method in class alluxio.thrift.MetaMasterClientService.getMasterInfo_args
the method options
getOptions() - Method in class alluxio.thrift.MetaMasterClientService.getMetrics_args
the method options
getOptions() - Method in class alluxio.thrift.MetaMasterMasterService.getMasterId_args
the method options
getOptions() - Method in class alluxio.thrift.MetaMasterMasterService.masterHeartbeat_args
the method options
getOptions() - Method in class alluxio.thrift.MetaMasterMasterService.registerMaster_args
the method options
getOptions() - Method in class alluxio.thrift.MetricsMasterClientService.metricsHeartbeat_args
the method options
getOptions() - Method in class alluxio.util.UnixMountInfo
 
getOptionStrings() - Method in class alluxio.AlluxioRemoteLogFilter
Deprecated.
Gets the option strings.
getOrDefault(PropertyKey, String) - Method in interface alluxio.AlluxioConfiguration
 
getOrDefault(PropertyKey, String, ConfigurationValueOptions) - Method in interface alluxio.AlluxioConfiguration
 
getOrDefault(PropertyKey, String) - Static method in class alluxio.Configuration
 
getOrDefault(PropertyKey, String, ConfigurationValueOptions) - Static method in class alluxio.Configuration
 
getOrderedStorageAliases() - Method in class alluxio.StorageTierAssoc
 
getOrdinal(String) - Method in class alluxio.StorageTierAssoc
 
getOrNull() - Static method in class alluxio.security.authentication.AuthenticatedClientUser
 
getOtherBits() - Method in class alluxio.security.authorization.Mode
 
getOutputCommitter(TaskAttemptContext) - Method in class alluxio.hadoop.mapreduce.KeyValueOutputFormat
 
getOutputFile() - Method in class alluxio.thrift.JobConfInfo
 
getOutputFile() - Method in class alluxio.wire.JobConfInfo
 
getOutputFileIds(int) - Method in class alluxio.proto.journal.Lineage.LineageEntry.Builder
repeated int64 output_file_ids = 3;
getOutputFileIds(int) - Method in class alluxio.proto.journal.Lineage.LineageEntry
repeated int64 output_file_ids = 3;
getOutputFileIds(int) - Method in interface alluxio.proto.journal.Lineage.LineageEntryOrBuilder
repeated int64 output_file_ids = 3;
getOutputFileIdsCount() - Method in class alluxio.proto.journal.Lineage.LineageEntry.Builder
repeated int64 output_file_ids = 3;
getOutputFileIdsCount() - Method in class alluxio.proto.journal.Lineage.LineageEntry
repeated int64 output_file_ids = 3;
getOutputFileIdsCount() - Method in interface alluxio.proto.journal.Lineage.LineageEntryOrBuilder
repeated int64 output_file_ids = 3;
getOutputFileIdsList() - Method in class alluxio.proto.journal.Lineage.LineageEntry.Builder
repeated int64 output_file_ids = 3;
getOutputFileIdsList() - Method in class alluxio.proto.journal.Lineage.LineageEntry
repeated int64 output_file_ids = 3;
getOutputFileIdsList() - Method in interface alluxio.proto.journal.Lineage.LineageEntryOrBuilder
repeated int64 output_file_ids = 3;
getOutputFilePath() - Method in class alluxio.job.JobConf
 
getOutputFiles() - Method in class alluxio.master.lineage.meta.Lineage
 
getOutputFiles() - Method in class alluxio.thrift.LineageInfo
 
getOutputFiles() - Method in class alluxio.thrift.LineageMasterClientService.createLineage_args
the list of output files
getOutputFiles() - Method in class alluxio.wire.LineageInfo
 
getOutputFilesIterator() - Method in class alluxio.thrift.LineageInfo
 
getOutputFilesIterator() - Method in class alluxio.thrift.LineageMasterClientService.createLineage_args
 
getOutputFilesSize() - Method in class alluxio.thrift.LineageInfo
 
getOutputFilesSize() - Method in class alluxio.thrift.LineageMasterClientService.createLineage_args
 
getOutputStream() - Method in class alluxio.worker.netty.UfsFileWriteRequestContext
 
getOutStream(long, long, WorkerNetAddress, OutStreamOptions) - Method in class alluxio.client.block.AlluxioBlockStore
Gets a stream to write data to a block.
getOutStream(long, long, OutStreamOptions) - Method in class alluxio.client.block.AlluxioBlockStore
Gets a stream to write data to a block based on the options.
getOutStream(Integer) - Method in class alluxio.StreamCache
 
getOwner() - Method in class alluxio.client.file.options.CompleteUfsFileOptions
 
getOwner() - Method in class alluxio.client.file.options.CreateUfsFileOptions
 
getOwner() - Method in class alluxio.client.file.options.OutStreamOptions
 
getOwner() - Method in class alluxio.client.file.options.SetAttributeOptions
 
getOwner() - Method in class alluxio.client.file.URIStatus
 
getOwner() - Method in class alluxio.master.file.meta.Inode
 
getOwner() - Method in class alluxio.master.file.options.CreatePathOptions
 
getOwner() - Method in class alluxio.master.file.options.SetAttributeOptions
 
getOwner() - Method in class alluxio.proto.dataserver.Protocol.CreateUfsFileOptions.Builder
optional string owner = 2;
getOwner() - Method in class alluxio.proto.dataserver.Protocol.CreateUfsFileOptions
optional string owner = 2;
getOwner() - Method in interface alluxio.proto.dataserver.Protocol.CreateUfsFileOptionsOrBuilder
optional string owner = 2;
getOwner() - Method in class alluxio.proto.journal.File.InodeDirectoryEntry.Builder
optional string owner = 8;
getOwner() - Method in class alluxio.proto.journal.File.InodeDirectoryEntry
optional string owner = 8;
getOwner() - Method in interface alluxio.proto.journal.File.InodeDirectoryEntryOrBuilder
optional string owner = 8;
getOwner() - Method in class alluxio.proto.journal.File.InodeFileEntry.Builder
optional string owner = 14;
getOwner() - Method in class alluxio.proto.journal.File.InodeFileEntry
optional string owner = 14;
getOwner() - Method in interface alluxio.proto.journal.File.InodeFileEntryOrBuilder
optional string owner = 14;
getOwner() - Method in class alluxio.proto.journal.File.SetAttributeEntry.Builder
optional string owner = 6;
getOwner() - Method in class alluxio.proto.journal.File.SetAttributeEntry
optional string owner = 6;
getOwner() - Method in interface alluxio.proto.journal.File.SetAttributeEntryOrBuilder
optional string owner = 6;
getOwner() - Method in class alluxio.thrift.CompleteUfsFileTOptions
 
getOwner() - Method in class alluxio.thrift.CreateUfsFileTOptions
 
getOwner() - Method in class alluxio.thrift.FileInfo
 
getOwner() - Method in class alluxio.thrift.SetAttributeTOptions
 
getOwner() - Method in class alluxio.underfs.ObjectUnderFileSystem.ObjectPermissions
 
getOwner() - Method in class alluxio.underfs.options.CreateOptions
 
getOwner() - Method in class alluxio.underfs.options.MkdirsOptions
 
getOwner() - Method in class alluxio.underfs.UfsStatus
Gets the owner of the given path.
getOwner() - Method in class alluxio.web.UIFileInfo
 
getOwner() - Method in class alluxio.wire.FileInfo
 
getOwnerBits() - Method in class alluxio.security.authorization.Mode
 
getOwnerBytes() - Method in class alluxio.proto.dataserver.Protocol.CreateUfsFileOptions.Builder
optional string owner = 2;
getOwnerBytes() - Method in class alluxio.proto.dataserver.Protocol.CreateUfsFileOptions
optional string owner = 2;
getOwnerBytes() - Method in interface alluxio.proto.dataserver.Protocol.CreateUfsFileOptionsOrBuilder
optional string owner = 2;
getOwnerBytes() - Method in class alluxio.proto.journal.File.InodeDirectoryEntry.Builder
optional string owner = 8;
getOwnerBytes() - Method in class alluxio.proto.journal.File.InodeDirectoryEntry
optional string owner = 8;
getOwnerBytes() - Method in interface alluxio.proto.journal.File.InodeDirectoryEntryOrBuilder
optional string owner = 8;
getOwnerBytes() - Method in class alluxio.proto.journal.File.InodeFileEntry.Builder
optional string owner = 14;
getOwnerBytes() - Method in class alluxio.proto.journal.File.InodeFileEntry
optional string owner = 14;
getOwnerBytes() - Method in interface alluxio.proto.journal.File.InodeFileEntryOrBuilder
optional string owner = 14;
getOwnerBytes() - Method in class alluxio.proto.journal.File.SetAttributeEntry.Builder
optional string owner = 6;
getOwnerBytes() - Method in class alluxio.proto.journal.File.SetAttributeEntry
optional string owner = 6;
getOwnerBytes() - Method in interface alluxio.proto.journal.File.SetAttributeEntryOrBuilder
optional string owner = 6;
getOwnerFromLoginModule() - Static method in class alluxio.util.SecurityUtils
 
getOwnerFromThriftClient() - Static method in class alluxio.util.SecurityUtils
 
getPackets() - Method in class alluxio.worker.netty.WriteRequestContext
 
getPacketSize() - Method in class alluxio.proto.dataserver.Protocol.ReadRequest.Builder
optional int64 packet_size = 5;
getPacketSize() - Method in class alluxio.proto.dataserver.Protocol.ReadRequest
optional int64 packet_size = 5;
getPacketSize() - Method in interface alluxio.proto.dataserver.Protocol.ReadRequestOrBuilder
optional int64 packet_size = 5;
getParent() - Method in class alluxio.AlluxioURI
Get the parent of this AlluxioURI or null if at root.
getParent(String) - Static method in class alluxio.util.io.PathUtils
Gets the parent of the file at a path.
getParentDir() - Method in class alluxio.worker.block.meta.AbstractBlockMeta
 
getParentId() - Method in class alluxio.master.file.meta.Inode
 
getParentId() - Method in class alluxio.proto.journal.File.InodeDirectoryEntry.Builder
optional int64 parent_id = 2;
getParentId() - Method in class alluxio.proto.journal.File.InodeDirectoryEntry
optional int64 parent_id = 2;
getParentId() - Method in interface alluxio.proto.journal.File.InodeDirectoryEntryOrBuilder
optional int64 parent_id = 2;
getParentId() - Method in class alluxio.proto.journal.File.InodeFileEntry.Builder
optional int64 parent_id = 2;
getParentId() - Method in class alluxio.proto.journal.File.InodeFileEntry
optional int64 parent_id = 2;
getParentId() - Method in interface alluxio.proto.journal.File.InodeFileEntryOrBuilder
optional int64 parent_id = 2;
getParentInodeDirectory() - Method in class alluxio.master.file.meta.LockedInodePath
 
getParentInodeOrNull() - Method in class alluxio.master.file.meta.LockedInodePath
 
getParentPath(String) - Method in class alluxio.underfs.ObjectUnderFileSystem
Get parent path.
getParents(T) - Method in class alluxio.collections.DirectedAcyclicGraph
Gets the payloads for the given nodes parents.
getParents() - Method in class alluxio.collections.DirectedAcyclicGraphNode
Gets the parent nodes of the node.
getParents(Lineage) - Method in class alluxio.master.lineage.meta.LineageStore
Gets all the parents of a given lineage.
getParents() - Method in class alluxio.thrift.LineageInfo
 
getParents() - Method in class alluxio.wire.LineageInfo
 
getParentsIterator() - Method in class alluxio.thrift.LineageInfo
 
getParentsSize() - Method in class alluxio.thrift.LineageInfo
 
getParentSubject() - Method in class alluxio.client.file.FileSystemContext
 
getParentTier() - Method in class alluxio.worker.block.meta.StorageDir
Returns the StorageTier containing this StorageDir.
getParentTierView() - Method in class alluxio.worker.block.meta.StorageDirView
 
getParserForType() - Method in class alluxio.proto.dataserver.Protocol.AsyncCacheRequest
 
getParserForType() - Method in class alluxio.proto.dataserver.Protocol.CreateUfsFileOptions
 
getParserForType() - Method in class alluxio.proto.dataserver.Protocol.Heartbeat
 
getParserForType() - Method in class alluxio.proto.dataserver.Protocol.LocalBlockCloseRequest
 
getParserForType() - Method in class alluxio.proto.dataserver.Protocol.LocalBlockCompleteRequest
 
getParserForType() - Method in class alluxio.proto.dataserver.Protocol.LocalBlockCreateRequest
 
getParserForType() - Method in class alluxio.proto.dataserver.Protocol.LocalBlockCreateResponse
 
getParserForType() - Method in class alluxio.proto.dataserver.Protocol.LocalBlockOpenRequest
 
getParserForType() - Method in class alluxio.proto.dataserver.Protocol.LocalBlockOpenResponse
 
getParserForType() - Method in class alluxio.proto.dataserver.Protocol.OpenUfsBlockOptions
 
getParserForType() - Method in class alluxio.proto.dataserver.Protocol.ReadRequest
 
getParserForType() - Method in class alluxio.proto.dataserver.Protocol.ReadResponse
 
getParserForType() - Method in class alluxio.proto.dataserver.Protocol.Response
 
getParserForType() - Method in class alluxio.proto.dataserver.Protocol.WriteRequest
 
getParserForType() - Method in class alluxio.proto.journal.Block.BlockContainerIdGeneratorEntry
 
getParserForType() - Method in class alluxio.proto.journal.Block.BlockInfoEntry
 
getParserForType() - Method in class alluxio.proto.journal.Block.DeleteBlockEntry
 
getParserForType() - Method in class alluxio.proto.journal.File.AddMountPointEntry
 
getParserForType() - Method in class alluxio.proto.journal.File.AsyncPersistRequestEntry
 
getParserForType() - Method in class alluxio.proto.journal.File.CompleteFileEntry
 
getParserForType() - Method in class alluxio.proto.journal.File.DeleteFileEntry
 
getParserForType() - Method in class alluxio.proto.journal.File.DeleteMountPointEntry
 
getParserForType() - Method in class alluxio.proto.journal.File.InodeDirectoryEntry
 
getParserForType() - Method in class alluxio.proto.journal.File.InodeDirectoryIdGeneratorEntry
 
getParserForType() - Method in class alluxio.proto.journal.File.InodeFileEntry
 
getParserForType() - Method in class alluxio.proto.journal.File.InodeLastModificationTimeEntry
 
getParserForType() - Method in class alluxio.proto.journal.File.PersistDirectoryEntry
 
getParserForType() - Method in class alluxio.proto.journal.File.PersistFileEntry
 
getParserForType() - Method in class alluxio.proto.journal.File.ReinitializeFileEntry
 
getParserForType() - Method in class alluxio.proto.journal.File.RenameEntry
 
getParserForType() - Method in class alluxio.proto.journal.File.SetAttributeEntry
 
getParserForType() - Method in class alluxio.proto.journal.File.StringPairEntry
 
getParserForType() - Method in class alluxio.proto.journal.File.UpdateUfsModeEntry
 
getParserForType() - Method in class alluxio.proto.journal.Journal.JournalEntry
 
getParserForType() - Method in class alluxio.proto.journal.KeyValue.CompletePartitionEntry
 
getParserForType() - Method in class alluxio.proto.journal.KeyValue.CompleteStoreEntry
 
getParserForType() - Method in class alluxio.proto.journal.KeyValue.CreateStoreEntry
 
getParserForType() - Method in class alluxio.proto.journal.KeyValue.DeleteStoreEntry
 
getParserForType() - Method in class alluxio.proto.journal.KeyValue.MergeStoreEntry
 
getParserForType() - Method in class alluxio.proto.journal.KeyValue.RenameStoreEntry
 
getParserForType() - Method in class alluxio.proto.journal.Lineage.DeleteLineageEntry
 
getParserForType() - Method in class alluxio.proto.journal.Lineage.LineageEntry
 
getParserForType() - Method in class alluxio.proto.journal.Lineage.LineageIdGeneratorEntry
 
getParticipants() - Method in class alluxio.master.PrimarySelectorClient
 
getPartitionInfo(AlluxioURI) - Method in class alluxio.client.keyvalue.KeyValueMasterClient
Gets a list of partitions of a given key-value store.
getPartitionInfo(AlluxioURI) - Method in class alluxio.master.keyvalue.DefaultKeyValueMaster
 
getPartitionInfo(AlluxioURI) - Method in interface alluxio.master.keyvalue.KeyValueMaster
Gets a list of partitions of a given key-value store.
getPartitionInfo(String, GetPartitionInfoTOptions) - Method in class alluxio.master.keyvalue.KeyValueMasterClientServiceHandler
 
getPartitionInfo() - Method in class alluxio.thrift.GetPartitionInfoTResponse
 
getPartitionInfo(String, GetPartitionInfoTOptions, AsyncMethodCallback) - Method in class alluxio.thrift.KeyValueMasterClientService.AsyncClient
 
getPartitionInfo(String, GetPartitionInfoTOptions, AsyncMethodCallback) - Method in interface alluxio.thrift.KeyValueMasterClientService.AsyncIface
 
getPartitionInfo() - Constructor for class alluxio.thrift.KeyValueMasterClientService.AsyncProcessor.getPartitionInfo
 
getPartitionInfo(String, GetPartitionInfoTOptions) - Method in class alluxio.thrift.KeyValueMasterClientService.Client
 
getPartitionInfo(String, GetPartitionInfoTOptions) - Method in interface alluxio.thrift.KeyValueMasterClientService.Iface
Gets the partition information for the key-value store at the given filesystem path.
getPartitionInfo() - Constructor for class alluxio.thrift.KeyValueMasterClientService.Processor.getPartitionInfo
 
getPartitionInfo_args() - Constructor for class alluxio.thrift.KeyValueMasterClientService.getPartitionInfo_args
 
getPartitionInfo_args(String, GetPartitionInfoTOptions) - Constructor for class alluxio.thrift.KeyValueMasterClientService.getPartitionInfo_args
 
getPartitionInfo_args(KeyValueMasterClientService.getPartitionInfo_args) - Constructor for class alluxio.thrift.KeyValueMasterClientService.getPartitionInfo_args
Performs a deep copy on other.
getPartitionInfo_call(String, GetPartitionInfoTOptions, AsyncMethodCallback, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class alluxio.thrift.KeyValueMasterClientService.AsyncClient.getPartitionInfo_call
 
getPartitionInfo_result() - Constructor for class alluxio.thrift.KeyValueMasterClientService.getPartitionInfo_result
 
getPartitionInfo_result(GetPartitionInfoTResponse, AlluxioTException) - Constructor for class alluxio.thrift.KeyValueMasterClientService.getPartitionInfo_result
 
getPartitionInfo_result(KeyValueMasterClientService.getPartitionInfo_result) - Constructor for class alluxio.thrift.KeyValueMasterClientService.getPartitionInfo_result
Performs a deep copy on other.
getPartitionInfoIterator() - Method in class alluxio.thrift.GetPartitionInfoTResponse
 
getPartitionInfoSize() - Method in class alluxio.thrift.GetPartitionInfoTResponse
 
GetPartitionInfoTOptions - Class in alluxio.thrift
 
GetPartitionInfoTOptions() - Constructor for class alluxio.thrift.GetPartitionInfoTOptions
 
GetPartitionInfoTOptions(GetPartitionInfoTOptions) - Constructor for class alluxio.thrift.GetPartitionInfoTOptions
Performs a deep copy on other.
GetPartitionInfoTOptions._Fields - Enum in alluxio.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
GetPartitionInfoTResponse - Class in alluxio.thrift
 
GetPartitionInfoTResponse() - Constructor for class alluxio.thrift.GetPartitionInfoTResponse
 
GetPartitionInfoTResponse(List<PartitionInfo>) - Constructor for class alluxio.thrift.GetPartitionInfoTResponse
 
GetPartitionInfoTResponse(GetPartitionInfoTResponse) - Constructor for class alluxio.thrift.GetPartitionInfoTResponse
Performs a deep copy on other.
GetPartitionInfoTResponse._Fields - Enum in alluxio.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
getPartNumber() - Method in class alluxio.proxy.s3.ListPartsResult.Part
 
getParts() - Method in class alluxio.proxy.s3.ListPartsResult
 
getPath() - Method in class alluxio.AlluxioURI
Gets the path component of the AlluxioURI.
getPath() - Method in class alluxio.client.file.URIStatus
For example, for the uri: alluxio://host:1000/foo/bar/baz, the path is /foo/bar/baz.
getPath(long) - Method in class alluxio.master.file.DefaultFileSystemMaster
 
getPath(long) - Method in interface alluxio.master.file.FileSystemMaster
Gets the path of a file with the given id.
getPath(long) - Method in class alluxio.master.file.meta.FileSystemMasterView
Gets the path of a file with the given id.
getPath(Inode<?>) - Method in class alluxio.master.file.meta.InodeTree
Returns the path for a particular inode.
getPath() - Method in class alluxio.master.file.meta.LockingScheme
 
getPath() - Method in class alluxio.proto.dataserver.Protocol.LocalBlockCreateResponse.Builder
optional string path = 1;
getPath() - Method in class alluxio.proto.dataserver.Protocol.LocalBlockCreateResponse
optional string path = 1;
getPath() - Method in interface alluxio.proto.dataserver.Protocol.LocalBlockCreateResponseOrBuilder
optional string path = 1;
getPath() - Method in class alluxio.proto.dataserver.Protocol.LocalBlockOpenResponse.Builder
optional string path = 1;
getPath() - Method in class alluxio.proto.dataserver.Protocol.LocalBlockOpenResponse
optional string path = 1;
getPath() - Method in interface alluxio.proto.dataserver.Protocol.LocalBlockOpenResponseOrBuilder
optional string path = 1;
getPath() - Method in class alluxio.proto.journal.File.ReinitializeFileEntry.Builder
optional string path = 1;
getPath() - Method in class alluxio.proto.journal.File.ReinitializeFileEntry
optional string path = 1;
getPath() - Method in interface alluxio.proto.journal.File.ReinitializeFileEntryOrBuilder
optional string path = 1;
getPath() - Method in class alluxio.StandardURI
 
getPath() - Method in class alluxio.thrift.FileInfo
 
getPath() - Method in class alluxio.thrift.FileSystemMasterClientService.checkConsistency_args
the root of the subtree to check
getPath() - Method in class alluxio.thrift.FileSystemMasterClientService.completeFile_args
the path of the file
getPath() - Method in class alluxio.thrift.FileSystemMasterClientService.createDirectory_args
the path of the directory
getPath() - Method in class alluxio.thrift.FileSystemMasterClientService.createFile_args
the path of the file
getPath() - Method in class alluxio.thrift.FileSystemMasterClientService.free_args
the path of the file or directory
getPath() - Method in class alluxio.thrift.FileSystemMasterClientService.getNewBlockIdForFile_args
the path of the file
getPath() - Method in class alluxio.thrift.FileSystemMasterClientService.getStatus_args
the path of the file or directory
getPath() - Method in class alluxio.thrift.FileSystemMasterClientService.listStatus_args
the path of the file or directory
getPath() - Method in class alluxio.thrift.FileSystemMasterClientService.remove_args
the path of the file or directory
getPath() - Method in class alluxio.thrift.FileSystemMasterClientService.rename_args
the source path of the file or directory
getPath() - Method in class alluxio.thrift.FileSystemMasterClientService.scheduleAsyncPersistence_args
the path of the file
getPath() - Method in class alluxio.thrift.FileSystemMasterClientService.setAttribute_args
the path of the file or directory
getPath() - Method in class alluxio.thrift.GetFilePathTResponse
 
getPath() - Method in class alluxio.thrift.KeyValueMasterClientService.completePartition_args
the path of the store
getPath() - Method in class alluxio.thrift.KeyValueMasterClientService.completeStore_args
the path of the store
getPath() - Method in class alluxio.thrift.KeyValueMasterClientService.createStore_args
the path of the store
getPath() - Method in class alluxio.thrift.KeyValueMasterClientService.deleteStore_args
the path of the store
getPath() - Method in class alluxio.thrift.KeyValueMasterClientService.getPartitionInfo_args
the path of the store
getPath() - Method in class alluxio.thrift.LineageMasterClientService.reinitializeFile_args
the path of the file
getPath() - Method in class alluxio.thrift.LineageMasterClientService.reportLostFile_args
the path of the file
getPath() - Method in interface alluxio.URI
 
getPath() - Method in class alluxio.wire.FileInfo
 
getPath() - Method in class alluxio.worker.block.meta.AbstractBlockMeta
 
getPath() - Method in class alluxio.worker.block.meta.BlockMeta
 
getPath() - Method in class alluxio.worker.block.meta.TempBlockMeta
 
getPathBytes() - Method in class alluxio.proto.dataserver.Protocol.LocalBlockCreateResponse.Builder
optional string path = 1;
getPathBytes() - Method in class alluxio.proto.dataserver.Protocol.LocalBlockCreateResponse
optional string path = 1;
getPathBytes() - Method in interface alluxio.proto.dataserver.Protocol.LocalBlockCreateResponseOrBuilder
optional string path = 1;
getPathBytes() - Method in class alluxio.proto.dataserver.Protocol.LocalBlockOpenResponse.Builder
optional string path = 1;
getPathBytes() - Method in class alluxio.proto.dataserver.Protocol.LocalBlockOpenResponse
optional string path = 1;
getPathBytes() - Method in interface alluxio.proto.dataserver.Protocol.LocalBlockOpenResponseOrBuilder
optional string path = 1;
getPathBytes() - Method in class alluxio.proto.journal.File.ReinitializeFileEntry.Builder
optional string path = 1;
getPathBytes() - Method in class alluxio.proto.journal.File.ReinitializeFileEntry
optional string path = 1;
getPathBytes() - Method in interface alluxio.proto.journal.File.ReinitializeFileEntryOrBuilder
optional string path = 1;
getPathComponents(String) - Static method in class alluxio.util.io.PathUtils
Gets the path components of the given path.
getPathWithoutScheme(Path) - Static method in class alluxio.hadoop.HadoopUtils
Given a Path path, it returns the path component of its URI, which has the form scheme://authority/path.
getPayload() - Method in class alluxio.collections.DirectedAcyclicGraphNode
Gets the payload of the node.
getPayloadDataBuffer() - Method in class alluxio.network.protocol.RPCMessage
Returns the data buffer of the payload.
getPayloadDataBuffer() - Method in class alluxio.network.protocol.RPCProtoMessage
 
getPayloadReader() - Method in class alluxio.client.keyvalue.ByteBufferKeyValuePartitionReader
 
getPendingDirName() - Static method in class alluxio.hadoop.mapreduce.KeyValueOutputCommitter
 
getPermanentFileName(String) - Static method in class alluxio.util.io.PathUtils
 
getPermission(String, List<String>, Inode<?>) - Method in class alluxio.master.file.DefaultInodePermissionChecker
 
getPermission(LockedInodePath) - Method in class alluxio.master.file.DefaultPermissionChecker
 
getPermission(String, List<String>, Inode<?>) - Method in interface alluxio.master.file.InodePermissionChecker
Gets the permission the user has for the file or directory at path.
getPermission(LockedInodePath) - Method in interface alluxio.master.file.PermissionChecker
Gets the permission to access inodePath for the current client user.
getPermission() - Method in class alluxio.proto.journal.File.SetAttributeEntry.Builder
optional int32 permission = 8;
getPermission() - Method in class alluxio.proto.journal.File.SetAttributeEntry
optional int32 permission = 8;
getPermission() - Method in interface alluxio.proto.journal.File.SetAttributeEntryOrBuilder
optional int32 permission = 8;
getPermissions() - Method in class alluxio.underfs.cos.COSUnderFileSystem
 
getPermissions() - Method in class alluxio.underfs.gcs.GCSUnderFileSystem
 
getPermissions() - Method in class alluxio.underfs.ObjectUnderFileSystem
Permissions for the mounted bucket.
getPermissions() - Method in class alluxio.underfs.oss.OSSUnderFileSystem
 
getPermissions() - Method in class alluxio.underfs.s3a.S3AUnderFileSystem
 
getPermissions() - Method in class alluxio.underfs.swift.SwiftUnderFileSystem
 
getPersistDirectory() - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
optional .alluxio.proto.journal.PersistDirectoryEntry persist_directory = 15;
getPersistDirectory() - Method in class alluxio.proto.journal.Journal.JournalEntry
optional .alluxio.proto.journal.PersistDirectoryEntry persist_directory = 15;
getPersistDirectory() - Method in interface alluxio.proto.journal.Journal.JournalEntryOrBuilder
optional .alluxio.proto.journal.PersistDirectoryEntry persist_directory = 15;
getPersistDirectoryBuilder() - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
optional .alluxio.proto.journal.PersistDirectoryEntry persist_directory = 15;
getPersistDirectoryOrBuilder() - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
optional .alluxio.proto.journal.PersistDirectoryEntry persist_directory = 15;
getPersistDirectoryOrBuilder() - Method in class alluxio.proto.journal.Journal.JournalEntry
optional .alluxio.proto.journal.PersistDirectoryEntry persist_directory = 15;
getPersistDirectoryOrBuilder() - Method in interface alluxio.proto.journal.Journal.JournalEntryOrBuilder
optional .alluxio.proto.journal.PersistDirectoryEntry persist_directory = 15;
getPersisted() - Method in class alluxio.client.file.options.SetAttributeOptions
Deprecated.
the persisted attribute is deprecated since version 1.4 and will be removed in 2.0
getPersisted() - Method in class alluxio.master.file.options.SetAttributeOptions
 
getPersisted() - Method in class alluxio.proto.journal.File.SetAttributeEntry.Builder
optional bool persisted = 5;
getPersisted() - Method in class alluxio.proto.journal.File.SetAttributeEntry
optional bool persisted = 5;
getPersisted() - Method in interface alluxio.proto.journal.File.SetAttributeEntryOrBuilder
optional bool persisted = 5;
getPersistedFileFingerprints() - Method in class alluxio.thrift.FileSystemHeartbeatTOptions
 
getPersistedFileFingerprintsIterator() - Method in class alluxio.thrift.FileSystemHeartbeatTOptions
 
getPersistedFileFingerprintsSize() - Method in class alluxio.thrift.FileSystemHeartbeatTOptions
 
getPersistedFileInfos() - Method in class alluxio.worker.file.FileDataManager
 
getPersistedFiles() - Method in class alluxio.thrift.FileSystemMasterWorkerService.fileSystemHeartbeat_args
the list of persisted files
getPersistedFilesIterator() - Method in class alluxio.thrift.FileSystemMasterWorkerService.fileSystemHeartbeat_args
 
getPersistedFilesSize() - Method in class alluxio.thrift.FileSystemMasterWorkerService.fileSystemHeartbeat_args
 
getPersistedUfsFingerprintList() - Method in class alluxio.master.file.options.WorkerHeartbeatOptions
 
getPersistenceState() - Method in class alluxio.client.file.URIStatus
 
getPersistenceState(long) - Method in class alluxio.master.file.DefaultFileSystemMaster
 
getPersistenceState(long) - Method in interface alluxio.master.file.FileSystemMaster
Returns the persistence state for a file id.
getPersistenceState() - Method in class alluxio.master.file.meta.Inode
 
getPersistenceState() - Method in class alluxio.proto.journal.File.InodeDirectoryEntry.Builder
optional string persistence_state = 4;
getPersistenceState() - Method in class alluxio.proto.journal.File.InodeDirectoryEntry
optional string persistence_state = 4;
getPersistenceState() - Method in interface alluxio.proto.journal.File.InodeDirectoryEntryOrBuilder
optional string persistence_state = 4;
getPersistenceState() - Method in class alluxio.proto.journal.File.InodeFileEntry.Builder
optional string persistence_state = 4;
getPersistenceState() - Method in class alluxio.proto.journal.File.InodeFileEntry
optional string persistence_state = 4;
getPersistenceState() - Method in interface alluxio.proto.journal.File.InodeFileEntryOrBuilder
optional string persistence_state = 4;
getPersistenceState() - Method in class alluxio.thrift.FileInfo
 
getPersistenceState() - Method in class alluxio.web.UIFileInfo
 
getPersistenceState() - Method in class alluxio.wire.FileInfo
 
getPersistenceStateBytes() - Method in class alluxio.proto.journal.File.InodeDirectoryEntry.Builder
optional string persistence_state = 4;
getPersistenceStateBytes() - Method in class alluxio.proto.journal.File.InodeDirectoryEntry
optional string persistence_state = 4;
getPersistenceStateBytes() - Method in interface alluxio.proto.journal.File.InodeDirectoryEntryOrBuilder
optional string persistence_state = 4;
getPersistenceStateBytes() - Method in class alluxio.proto.journal.File.InodeFileEntry.Builder
optional string persistence_state = 4;
getPersistenceStateBytes() - Method in class alluxio.proto.journal.File.InodeFileEntry
optional string persistence_state = 4;
getPersistenceStateBytes() - Method in interface alluxio.proto.journal.File.InodeFileEntryOrBuilder
optional string persistence_state = 4;
getPersistFiles() - Method in class alluxio.thrift.PersistCommandOptions
 
getPersistFilesIterator() - Method in class alluxio.thrift.PersistCommandOptions
 
getPersistFilesSize() - Method in class alluxio.thrift.PersistCommandOptions
 
getPersistOptions() - Method in class alluxio.thrift.FileSystemCommandOptions
 
getPhysicalStores() - Method in class alluxio.underfs.BaseUnderFileSystem
 
getPhysicalStores() - Method in interface alluxio.underfs.UnderFileSystem
An UnderFileSystem may be composed of one or more "physical UFS"s.
getPhysicalStores() - Method in class alluxio.underfs.UnderFileSystemWithLogging
 
getPhysicalUfsState(List<String>) - Method in class alluxio.underfs.MasterUfsManager
Get the physical ufs operation modes for the UnderFileSystem under the given Mount table resolution.
getPinIdList() - Method in class alluxio.master.file.DefaultFileSystemMaster
 
getPinIdList() - Method in interface alluxio.master.file.FileSystemMaster
 
getPinIdSet() - Method in class alluxio.master.file.meta.InodeTree
 
getPinList() - Method in class alluxio.worker.file.FileSystemMasterClient
 
getPinned() - Method in class alluxio.client.file.options.SetAttributeOptions
 
getPinned() - Method in class alluxio.master.file.options.SetAttributeOptions
 
getPinned() - Method in class alluxio.proto.journal.File.InodeDirectoryEntry.Builder
optional bool pinned = 5;
getPinned() - Method in class alluxio.proto.journal.File.InodeDirectoryEntry
optional bool pinned = 5;
getPinned() - Method in interface alluxio.proto.journal.File.InodeDirectoryEntryOrBuilder
optional bool pinned = 5;
getPinned() - Method in class alluxio.proto.journal.File.InodeFileEntry.Builder
optional bool pinned = 5;
getPinned() - Method in class alluxio.proto.journal.File.InodeFileEntry
optional bool pinned = 5;
getPinned() - Method in interface alluxio.proto.journal.File.InodeFileEntryOrBuilder
optional bool pinned = 5;
getPinned() - Method in class alluxio.proto.journal.File.SetAttributeEntry.Builder
optional bool pinned = 3;
getPinned() - Method in class alluxio.proto.journal.File.SetAttributeEntry
optional bool pinned = 3;
getPinned() - Method in interface alluxio.proto.journal.File.SetAttributeEntryOrBuilder
optional bool pinned = 3;
getPinnedFileIds(GetPinnedFileIdsTOptions) - Method in class alluxio.master.file.FileSystemMasterWorkerServiceHandler
 
getPinnedFileIds(GetPinnedFileIdsTOptions, AsyncMethodCallback) - Method in class alluxio.thrift.FileSystemMasterWorkerService.AsyncClient
 
getPinnedFileIds(GetPinnedFileIdsTOptions, AsyncMethodCallback) - Method in interface alluxio.thrift.FileSystemMasterWorkerService.AsyncIface
 
getPinnedFileIds() - Constructor for class alluxio.thrift.FileSystemMasterWorkerService.AsyncProcessor.getPinnedFileIds
 
getPinnedFileIds(GetPinnedFileIdsTOptions) - Method in class alluxio.thrift.FileSystemMasterWorkerService.Client
 
getPinnedFileIds(GetPinnedFileIdsTOptions) - Method in interface alluxio.thrift.FileSystemMasterWorkerService.Iface
Returns the set of pinned file ids.
getPinnedFileIds() - Constructor for class alluxio.thrift.FileSystemMasterWorkerService.Processor.getPinnedFileIds
 
getPinnedFileIds() - Method in class alluxio.thrift.GetPinnedFileIdsTResponse
 
getPinnedFileIds_args() - Constructor for class alluxio.thrift.FileSystemMasterWorkerService.getPinnedFileIds_args
 
getPinnedFileIds_args(GetPinnedFileIdsTOptions) - Constructor for class alluxio.thrift.FileSystemMasterWorkerService.getPinnedFileIds_args
 
getPinnedFileIds_args(FileSystemMasterWorkerService.getPinnedFileIds_args) - Constructor for class alluxio.thrift.FileSystemMasterWorkerService.getPinnedFileIds_args
Performs a deep copy on other.
getPinnedFileIds_call(GetPinnedFileIdsTOptions, AsyncMethodCallback, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class alluxio.thrift.FileSystemMasterWorkerService.AsyncClient.getPinnedFileIds_call
 
getPinnedFileIds_result() - Constructor for class alluxio.thrift.FileSystemMasterWorkerService.getPinnedFileIds_result
 
getPinnedFileIds_result(GetPinnedFileIdsTResponse, AlluxioTException) - Constructor for class alluxio.thrift.FileSystemMasterWorkerService.getPinnedFileIds_result
 
getPinnedFileIds_result(FileSystemMasterWorkerService.getPinnedFileIds_result) - Constructor for class alluxio.thrift.FileSystemMasterWorkerService.getPinnedFileIds_result
Performs a deep copy on other.
getPinnedFileIdsIterator() - Method in class alluxio.thrift.GetPinnedFileIdsTResponse
 
getPinnedFileIdsSize() - Method in class alluxio.thrift.GetPinnedFileIdsTResponse
 
GetPinnedFileIdsTOptions - Class in alluxio.thrift
 
GetPinnedFileIdsTOptions() - Constructor for class alluxio.thrift.GetPinnedFileIdsTOptions
 
GetPinnedFileIdsTOptions(GetPinnedFileIdsTOptions) - Constructor for class alluxio.thrift.GetPinnedFileIdsTOptions
Performs a deep copy on other.
GetPinnedFileIdsTOptions._Fields - Enum in alluxio.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
GetPinnedFileIdsTResponse - Class in alluxio.thrift
 
GetPinnedFileIdsTResponse() - Constructor for class alluxio.thrift.GetPinnedFileIdsTResponse
 
GetPinnedFileIdsTResponse(Set<Long>) - Constructor for class alluxio.thrift.GetPinnedFileIdsTResponse
 
GetPinnedFileIdsTResponse(GetPinnedFileIdsTResponse) - Constructor for class alluxio.thrift.GetPinnedFileIdsTResponse
Performs a deep copy on other.
GetPinnedFileIdsTResponse._Fields - Enum in alluxio.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
getPinnedSize() - Method in class alluxio.master.file.meta.InodeTree
 
getPort() - Method in class alluxio.AlluxioURI
Gets the port of the AlluxioURI.
getPort() - Method in class alluxio.master.MasterContext
 
getPort() - Method in class alluxio.multi.process.PortCoordination.ReservedPort
 
getPort() - Method in class alluxio.StandardURI
 
getPort() - Method in interface alluxio.URI
 
getPort(NetworkAddressUtils.ServiceType) - Static method in class alluxio.util.network.NetworkAddressUtils
Gets the port number on a given service type.
getPort(NetworkAddressUtils.ServiceType, AlluxioConfiguration) - Static method in class alluxio.util.network.NetworkAddressUtils
Gets the port number on a given service type.
getPortKey() - Method in enum alluxio.util.network.NetworkAddressUtils.ServiceType
Gets the key of service port.
getPos() - Method in class alluxio.client.block.stream.BlockInStream
 
getPos() - Method in class alluxio.client.file.FileInStream
 
getPos() - Method in class alluxio.hadoop.HdfsFileInputStream
 
getPos() - Method in interface alluxio.Positioned
 
getPos() - Method in class alluxio.underfs.hdfs.HdfsUnderFileInputStream
 
getPosition() - Method in interface alluxio.worker.block.io.BlockWriter
 
getPosition() - Method in class alluxio.worker.block.io.LocalFileBlockWriter
 
getPosToQueue() - Method in class alluxio.worker.netty.ReadRequestContext
 
getPosToQueue() - Method in class alluxio.worker.netty.WriteRequestContext
 
getPosToWrite() - Method in class alluxio.worker.netty.ReadRequestContext
 
getPosToWrite() - Method in class alluxio.worker.netty.WriteRequestContext
 
getPrefix() - Method in class alluxio.proxy.s3.ListBucketOptions
 
getPrefix() - Method in class alluxio.proxy.s3.ListBucketResult
 
getPrimaryGroupName(String) - Static method in class alluxio.util.CommonUtils
Gets the primary group name of a user.
getPrimaryMasterIndex(int) - Method in class alluxio.multi.process.MultiProcessCluster
Gets the index of the primary master.
getPrimaryRpcAddress() - Method in interface alluxio.master.MasterInquireClient
 
getPrimaryRpcAddress() - Method in class alluxio.master.PollingMasterInquireClient
 
getPrimaryRpcAddress() - Method in class alluxio.master.SingleMasterInquireClient
 
getPrimaryRpcAddress() - Method in class alluxio.master.ZkMasterInquireClient
 
getPrintStream() - Method in class alluxio.cli.fsadmin.command.Context
 
getProcessType() - Method in class alluxio.AlluxioRemoteLogFilter
Retrieves the string representation of process type.
getPromote() - Method in class alluxio.proto.dataserver.Protocol.LocalBlockOpenRequest.Builder
optional bool promote = 2;
getPromote() - Method in class alluxio.proto.dataserver.Protocol.LocalBlockOpenRequest
optional bool promote = 2;
getPromote() - Method in interface alluxio.proto.dataserver.Protocol.LocalBlockOpenRequestOrBuilder
optional bool promote = 2;
getPromote() - Method in class alluxio.proto.dataserver.Protocol.ReadRequest.Builder
optional bool promote = 7;
getPromote() - Method in class alluxio.proto.dataserver.Protocol.ReadRequest
optional bool promote = 7;
getPromote() - Method in interface alluxio.proto.dataserver.Protocol.ReadRequestOrBuilder
optional bool promote = 7;
getProperties() - Method in class alluxio.client.file.options.MountOptions
 
getProperties() - Method in class alluxio.conf.InstancedConfiguration
 
getProperties() - Method in class alluxio.master.file.options.MountOptions
 
getProperties() - Method in class alluxio.metrics.MetricsConfig
 
getProperties(int) - Method in class alluxio.proto.journal.File.AddMountPointEntry.Builder
repeated .alluxio.proto.journal.StringPairEntry properties = 4;
getProperties(int) - Method in class alluxio.proto.journal.File.AddMountPointEntry
repeated .alluxio.proto.journal.StringPairEntry properties = 4;
getProperties(int) - Method in interface alluxio.proto.journal.File.AddMountPointEntryOrBuilder
repeated .alluxio.proto.journal.StringPairEntry properties = 4;
getProperties() - Method in class alluxio.thrift.MountPointInfo
 
getProperties() - Method in class alluxio.thrift.MountTOptions
 
getProperties() - Method in class alluxio.thrift.UfsInfo
 
getProperties() - Method in class alluxio.wire.MountPointInfo
 
getPropertiesBuilder(int) - Method in class alluxio.proto.journal.File.AddMountPointEntry.Builder
repeated .alluxio.proto.journal.StringPairEntry properties = 4;
getPropertiesBuilderList() - Method in class alluxio.proto.journal.File.AddMountPointEntry.Builder
repeated .alluxio.proto.journal.StringPairEntry properties = 4;
getPropertiesCount() - Method in class alluxio.proto.journal.File.AddMountPointEntry.Builder
repeated .alluxio.proto.journal.StringPairEntry properties = 4;
getPropertiesCount() - Method in class alluxio.proto.journal.File.AddMountPointEntry
repeated .alluxio.proto.journal.StringPairEntry properties = 4;
getPropertiesCount() - Method in interface alluxio.proto.journal.File.AddMountPointEntryOrBuilder
repeated .alluxio.proto.journal.StringPairEntry properties = 4;
getPropertiesList() - Method in class alluxio.proto.journal.File.AddMountPointEntry.Builder
repeated .alluxio.proto.journal.StringPairEntry properties = 4;
getPropertiesList() - Method in class alluxio.proto.journal.File.AddMountPointEntry
repeated .alluxio.proto.journal.StringPairEntry properties = 4;
getPropertiesList() - Method in interface alluxio.proto.journal.File.AddMountPointEntryOrBuilder
repeated .alluxio.proto.journal.StringPairEntry properties = 4;
getPropertiesOrBuilder(int) - Method in class alluxio.proto.journal.File.AddMountPointEntry.Builder
repeated .alluxio.proto.journal.StringPairEntry properties = 4;
getPropertiesOrBuilder(int) - Method in class alluxio.proto.journal.File.AddMountPointEntry
repeated .alluxio.proto.journal.StringPairEntry properties = 4;
getPropertiesOrBuilder(int) - Method in interface alluxio.proto.journal.File.AddMountPointEntryOrBuilder
repeated .alluxio.proto.journal.StringPairEntry properties = 4;
getPropertiesOrBuilderList() - Method in class alluxio.proto.journal.File.AddMountPointEntry.Builder
repeated .alluxio.proto.journal.StringPairEntry properties = 4;
getPropertiesOrBuilderList() - Method in class alluxio.proto.journal.File.AddMountPointEntry
repeated .alluxio.proto.journal.StringPairEntry properties = 4;
getPropertiesOrBuilderList() - Method in interface alluxio.proto.journal.File.AddMountPointEntryOrBuilder
repeated .alluxio.proto.journal.StringPairEntry properties = 4;
getPropertiesSize() - Method in class alluxio.thrift.MountPointInfo
 
getPropertiesSize() - Method in class alluxio.thrift.MountTOptions
 
getProxyProcess() - Method in class alluxio.master.AbstractLocalAlluxioCluster
Gets the proxy process.
getPublicURL() - Method in class alluxio.underfs.swift.KeystoneV3Access
 
getQuery() - Method in class alluxio.StandardURI
 
getQuery() - Method in interface alluxio.URI
 
getQueryMap() - Method in class alluxio.AlluxioURI
Gets the map of query parameters.
getQuietPeriodMs() - Method in class alluxio.master.journal.ufs.UfsJournal
 
getRandomNonNegativeLong() - Static method in class alluxio.util.IdUtils
 
getReader(boolean) - Method in class alluxio.master.journal.ufs.UfsJournal
 
getReader() - Method in interface alluxio.master.journalv0.Journal
 
getReader() - Method in class alluxio.master.journalv0.ufs.UfsJournal
 
getReadOnly() - Method in class alluxio.proto.journal.File.AddMountPointEntry.Builder
optional bool readOnly = 3;
getReadOnly() - Method in class alluxio.proto.journal.File.AddMountPointEntry
optional bool readOnly = 3;
getReadOnly() - Method in interface alluxio.proto.journal.File.AddMountPointEntryOrBuilder
optional bool readOnly = 3;
getReadOnly() - Method in class alluxio.wire.MountPointInfo
 
getReadOnlyByteBuffer() - Method in interface alluxio.network.protocol.databuffer.DataBuffer
Returns a ByteBuffer for read-only access to the data.
getReadOnlyByteBuffer() - Method in class alluxio.network.protocol.databuffer.DataByteArrayChannel
 
getReadOnlyByteBuffer() - Method in class alluxio.network.protocol.databuffer.DataByteBuffer
 
getReadOnlyByteBuffer() - Method in class alluxio.network.protocol.databuffer.DataFileChannel
 
getReadOnlyByteBuffer() - Method in class alluxio.network.protocol.databuffer.DataNettyBuffer
 
getReadOnlyByteBuffer() - Method in class alluxio.network.protocol.databuffer.DataNettyBufferV2
 
getReadType() - Method in class alluxio.client.file.options.OpenFileOptions
 
getRecordWriter(TaskAttemptContext) - Method in class alluxio.hadoop.mapreduce.KeyValueOutputFormat
 
getRecoverFailedOpen() - Method in class alluxio.underfs.options.OpenOptions
 
getRecursive() - Method in class alluxio.proto.journal.File.DeleteFileEntry.Builder
optional bool recursive = 2;
getRecursive() - Method in class alluxio.proto.journal.File.DeleteFileEntry
optional bool recursive = 2;
getRecursive() - Method in interface alluxio.proto.journal.File.DeleteFileEntryOrBuilder
optional bool recursive = 2;
getReferenceCount() - Method in class alluxio.worker.block.ClientRWLock
 
getReinitializeFile() - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
optional .alluxio.proto.journal.ReinitializeFileEntry reinitialize_file = 18;
getReinitializeFile() - Method in class alluxio.proto.journal.Journal.JournalEntry
optional .alluxio.proto.journal.ReinitializeFileEntry reinitialize_file = 18;
getReinitializeFile() - Method in interface alluxio.proto.journal.Journal.JournalEntryOrBuilder
optional .alluxio.proto.journal.ReinitializeFileEntry reinitialize_file = 18;
getReinitializeFileBuilder() - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
optional .alluxio.proto.journal.ReinitializeFileEntry reinitialize_file = 18;
getReinitializeFileOrBuilder() - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
optional .alluxio.proto.journal.ReinitializeFileEntry reinitialize_file = 18;
getReinitializeFileOrBuilder() - Method in class alluxio.proto.journal.Journal.JournalEntry
optional .alluxio.proto.journal.ReinitializeFileEntry reinitialize_file = 18;
getReinitializeFileOrBuilder() - Method in interface alluxio.proto.journal.Journal.JournalEntryOrBuilder
optional .alluxio.proto.journal.ReinitializeFileEntry reinitialize_file = 18;
getRemovedBlockIds() - Method in class alluxio.thrift.BlockMasterWorkerService.blockHeartbeat_args
the list of removed block ids
getRemovedBlockIdsIterator() - Method in class alluxio.thrift.BlockMasterWorkerService.blockHeartbeat_args
 
getRemovedBlockIdsSize() - Method in class alluxio.thrift.BlockMasterWorkerService.blockHeartbeat_args
 
getRemovedBlocks() - Method in class alluxio.worker.block.BlockHeartbeatReport
Gets the list of blocks removed from this worker in the heartbeat this report represents.
getRename() - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
optional .alluxio.proto.journal.RenameEntry rename = 19;
getRename() - Method in class alluxio.proto.journal.Journal.JournalEntry
optional .alluxio.proto.journal.RenameEntry rename = 19;
getRename() - Method in interface alluxio.proto.journal.Journal.JournalEntryOrBuilder
optional .alluxio.proto.journal.RenameEntry rename = 19;
getRenameBuilder() - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
optional .alluxio.proto.journal.RenameEntry rename = 19;
getRenameOrBuilder() - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
optional .alluxio.proto.journal.RenameEntry rename = 19;
getRenameOrBuilder() - Method in class alluxio.proto.journal.Journal.JournalEntry
optional .alluxio.proto.journal.RenameEntry rename = 19;
getRenameOrBuilder() - Method in interface alluxio.proto.journal.Journal.JournalEntryOrBuilder
optional .alluxio.proto.journal.RenameEntry rename = 19;
getRenameStore() - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
optional .alluxio.proto.journal.RenameStoreEntry rename_store = 28;
getRenameStore() - Method in class alluxio.proto.journal.Journal.JournalEntry
optional .alluxio.proto.journal.RenameStoreEntry rename_store = 28;
getRenameStore() - Method in interface alluxio.proto.journal.Journal.JournalEntryOrBuilder
optional .alluxio.proto.journal.RenameStoreEntry rename_store = 28;
getRenameStoreBuilder() - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
optional .alluxio.proto.journal.RenameStoreEntry rename_store = 28;
getRenameStoreOrBuilder() - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
optional .alluxio.proto.journal.RenameStoreEntry rename_store = 28;
getRenameStoreOrBuilder() - Method in class alluxio.proto.journal.Journal.JournalEntry
optional .alluxio.proto.journal.RenameStoreEntry rename_store = 28;
getRenameStoreOrBuilder() - Method in interface alluxio.proto.journal.Journal.JournalEntryOrBuilder
optional .alluxio.proto.journal.RenameStoreEntry rename_store = 28;
getReport() - Method in class alluxio.thrift.GetConfigReportTResponse
 
getReport() - Method in interface alluxio.worker.block.BlockWorker
Gets a report for the periodic heartbeat to master.
getReport() - Method in class alluxio.worker.block.DefaultBlockWorker
 
getRequest() - Method in class alluxio.worker.netty.ReadRequestContext
 
getRequest() - Method in class alluxio.worker.netty.WriteRequestContext
 
getRequestBytes() - Method in class alluxio.thrift.BlockWorkerClientService.requestSpace_args
the number of bytes requested
getRequestId() - Method in class alluxio.proxy.s3.S3Error
 
getResource() - Method in class alluxio.proxy.s3.S3Error
 
getResource() - Method in exception alluxio.proxy.s3.S3Exception
 
getResult() - Method in class alluxio.thrift.AlluxioService.AsyncClient.getServiceVersion_call
 
getResult(I, AlluxioService.getServiceVersion_args) - Method in class alluxio.thrift.AlluxioService.Processor.getServiceVersion
 
getResult() - Method in class alluxio.thrift.BlockMasterClientService.AsyncClient.getBlockInfo_call
 
getResult() - Method in class alluxio.thrift.BlockMasterClientService.AsyncClient.getBlockMasterInfo_call
 
getResult() - Method in class alluxio.thrift.BlockMasterClientService.AsyncClient.getCapacityBytes_call
 
getResult() - Method in class alluxio.thrift.BlockMasterClientService.AsyncClient.getUsedBytes_call
 
getResult() - Method in class alluxio.thrift.BlockMasterClientService.AsyncClient.getWorkerInfoList_call
 
getResult() - Method in class alluxio.thrift.BlockMasterClientService.AsyncClient.getWorkerReport_call
 
getResult(I, BlockMasterClientService.getBlockInfo_args) - Method in class alluxio.thrift.BlockMasterClientService.Processor.getBlockInfo
 
getResult(I, BlockMasterClientService.getBlockMasterInfo_args) - Method in class alluxio.thrift.BlockMasterClientService.Processor.getBlockMasterInfo
 
getResult(I, BlockMasterClientService.getCapacityBytes_args) - Method in class alluxio.thrift.BlockMasterClientService.Processor.getCapacityBytes
 
getResult(I, BlockMasterClientService.getUsedBytes_args) - Method in class alluxio.thrift.BlockMasterClientService.Processor.getUsedBytes
 
getResult(I, BlockMasterClientService.getWorkerInfoList_args) - Method in class alluxio.thrift.BlockMasterClientService.Processor.getWorkerInfoList
 
getResult(I, BlockMasterClientService.getWorkerReport_args) - Method in class alluxio.thrift.BlockMasterClientService.Processor.getWorkerReport
 
getResult() - Method in class alluxio.thrift.BlockMasterWorkerService.AsyncClient.blockHeartbeat_call
 
getResult() - Method in class alluxio.thrift.BlockMasterWorkerService.AsyncClient.commitBlock_call
 
getResult() - Method in class alluxio.thrift.BlockMasterWorkerService.AsyncClient.getWorkerId_call
 
getResult() - Method in class alluxio.thrift.BlockMasterWorkerService.AsyncClient.registerWorker_call
 
getResult(I, BlockMasterWorkerService.blockHeartbeat_args) - Method in class alluxio.thrift.BlockMasterWorkerService.Processor.blockHeartbeat
 
getResult(I, BlockMasterWorkerService.commitBlock_args) - Method in class alluxio.thrift.BlockMasterWorkerService.Processor.commitBlock
 
getResult(I, BlockMasterWorkerService.getWorkerId_args) - Method in class alluxio.thrift.BlockMasterWorkerService.Processor.getWorkerId
 
getResult(I, BlockMasterWorkerService.registerWorker_args) - Method in class alluxio.thrift.BlockMasterWorkerService.Processor.registerWorker
 
getResult() - Method in class alluxio.thrift.BlockWorkerClientService.AsyncClient.accessBlock_call
 
getResult() - Method in class alluxio.thrift.BlockWorkerClientService.AsyncClient.cacheBlock_call
 
getResult() - Method in class alluxio.thrift.BlockWorkerClientService.AsyncClient.cancelBlock_call
 
getResult() - Method in class alluxio.thrift.BlockWorkerClientService.AsyncClient.lockBlock_call
 
getResult() - Method in class alluxio.thrift.BlockWorkerClientService.AsyncClient.promoteBlock_call
 
getResult() - Method in class alluxio.thrift.BlockWorkerClientService.AsyncClient.removeBlock_call
 
getResult() - Method in class alluxio.thrift.BlockWorkerClientService.AsyncClient.requestBlockLocation_call
 
getResult() - Method in class alluxio.thrift.BlockWorkerClientService.AsyncClient.requestSpace_call
 
getResult() - Method in class alluxio.thrift.BlockWorkerClientService.AsyncClient.sessionBlockHeartbeat_call
 
getResult() - Method in class alluxio.thrift.BlockWorkerClientService.AsyncClient.unlockBlock_call
 
getResult(I, BlockWorkerClientService.accessBlock_args) - Method in class alluxio.thrift.BlockWorkerClientService.Processor.accessBlock
 
getResult(I, BlockWorkerClientService.cacheBlock_args) - Method in class alluxio.thrift.BlockWorkerClientService.Processor.cacheBlock
 
getResult(I, BlockWorkerClientService.cancelBlock_args) - Method in class alluxio.thrift.BlockWorkerClientService.Processor.cancelBlock
 
getResult(I, BlockWorkerClientService.lockBlock_args) - Method in class alluxio.thrift.BlockWorkerClientService.Processor.lockBlock
 
getResult(I, BlockWorkerClientService.promoteBlock_args) - Method in class alluxio.thrift.BlockWorkerClientService.Processor.promoteBlock
 
getResult(I, BlockWorkerClientService.removeBlock_args) - Method in class alluxio.thrift.BlockWorkerClientService.Processor.removeBlock
 
getResult(I, BlockWorkerClientService.requestBlockLocation_args) - Method in class alluxio.thrift.BlockWorkerClientService.Processor.requestBlockLocation
 
getResult(I, BlockWorkerClientService.requestSpace_args) - Method in class alluxio.thrift.BlockWorkerClientService.Processor.requestSpace
 
getResult(I, BlockWorkerClientService.sessionBlockHeartbeat_args) - Method in class alluxio.thrift.BlockWorkerClientService.Processor.sessionBlockHeartbeat
 
getResult(I, BlockWorkerClientService.unlockBlock_args) - Method in class alluxio.thrift.BlockWorkerClientService.Processor.unlockBlock
 
getResult() - Method in class alluxio.thrift.FileSystemMasterClientService.AsyncClient.checkConsistency_call
 
getResult() - Method in class alluxio.thrift.FileSystemMasterClientService.AsyncClient.completeFile_call
 
getResult() - Method in class alluxio.thrift.FileSystemMasterClientService.AsyncClient.createDirectory_call
 
getResult() - Method in class alluxio.thrift.FileSystemMasterClientService.AsyncClient.createFile_call
 
getResult() - Method in class alluxio.thrift.FileSystemMasterClientService.AsyncClient.free_call
 
getResult() - Method in class alluxio.thrift.FileSystemMasterClientService.AsyncClient.getFilePath_call
 
getResult() - Method in class alluxio.thrift.FileSystemMasterClientService.AsyncClient.getMountTable_call
 
getResult() - Method in class alluxio.thrift.FileSystemMasterClientService.AsyncClient.getNewBlockIdForFile_call
 
getResult() - Method in class alluxio.thrift.FileSystemMasterClientService.AsyncClient.getStatus_call
 
getResult() - Method in class alluxio.thrift.FileSystemMasterClientService.AsyncClient.listStatus_call
 
getResult() - Method in class alluxio.thrift.FileSystemMasterClientService.AsyncClient.loadMetadata_call
 
getResult() - Method in class alluxio.thrift.FileSystemMasterClientService.AsyncClient.mount_call
 
getResult() - Method in class alluxio.thrift.FileSystemMasterClientService.AsyncClient.remove_call
 
getResult() - Method in class alluxio.thrift.FileSystemMasterClientService.AsyncClient.rename_call
 
getResult() - Method in class alluxio.thrift.FileSystemMasterClientService.AsyncClient.scheduleAsyncPersistence_call
 
getResult() - Method in class alluxio.thrift.FileSystemMasterClientService.AsyncClient.setAttribute_call
 
getResult() - Method in class alluxio.thrift.FileSystemMasterClientService.AsyncClient.unmount_call
 
getResult() - Method in class alluxio.thrift.FileSystemMasterClientService.AsyncClient.updateUfsMode_call
 
getResult(I, FileSystemMasterClientService.checkConsistency_args) - Method in class alluxio.thrift.FileSystemMasterClientService.Processor.checkConsistency
 
getResult(I, FileSystemMasterClientService.completeFile_args) - Method in class alluxio.thrift.FileSystemMasterClientService.Processor.completeFile
 
getResult(I, FileSystemMasterClientService.createDirectory_args) - Method in class alluxio.thrift.FileSystemMasterClientService.Processor.createDirectory
 
getResult(I, FileSystemMasterClientService.createFile_args) - Method in class alluxio.thrift.FileSystemMasterClientService.Processor.createFile
 
getResult(I, FileSystemMasterClientService.free_args) - Method in class alluxio.thrift.FileSystemMasterClientService.Processor.free
 
getResult(I, FileSystemMasterClientService.getFilePath_args) - Method in class alluxio.thrift.FileSystemMasterClientService.Processor.getFilePath
 
getResult(I, FileSystemMasterClientService.getMountTable_args) - Method in class alluxio.thrift.FileSystemMasterClientService.Processor.getMountTable
 
getResult(I, FileSystemMasterClientService.getNewBlockIdForFile_args) - Method in class alluxio.thrift.FileSystemMasterClientService.Processor.getNewBlockIdForFile
 
getResult(I, FileSystemMasterClientService.getStatus_args) - Method in class alluxio.thrift.FileSystemMasterClientService.Processor.getStatus
 
getResult(I, FileSystemMasterClientService.listStatus_args) - Method in class alluxio.thrift.FileSystemMasterClientService.Processor.listStatus
 
getResult(I, FileSystemMasterClientService.loadMetadata_args) - Method in class alluxio.thrift.FileSystemMasterClientService.Processor.loadMetadata
 
getResult(I, FileSystemMasterClientService.mount_args) - Method in class alluxio.thrift.FileSystemMasterClientService.Processor.mount
 
getResult(I, FileSystemMasterClientService.remove_args) - Method in class alluxio.thrift.FileSystemMasterClientService.Processor.remove
 
getResult(I, FileSystemMasterClientService.rename_args) - Method in class alluxio.thrift.FileSystemMasterClientService.Processor.rename
 
getResult(I, FileSystemMasterClientService.scheduleAsyncPersistence_args) - Method in class alluxio.thrift.FileSystemMasterClientService.Processor.scheduleAsyncPersistence
 
getResult(I, FileSystemMasterClientService.setAttribute_args) - Method in class alluxio.thrift.FileSystemMasterClientService.Processor.setAttribute
 
getResult(I, FileSystemMasterClientService.unmount_args) - Method in class alluxio.thrift.FileSystemMasterClientService.Processor.unmount
 
getResult(I, FileSystemMasterClientService.updateUfsMode_args) - Method in class alluxio.thrift.FileSystemMasterClientService.Processor.updateUfsMode
 
getResult() - Method in class alluxio.thrift.FileSystemMasterWorkerService.AsyncClient.fileSystemHeartbeat_call
 
getResult() - Method in class alluxio.thrift.FileSystemMasterWorkerService.AsyncClient.getFileInfo_call
 
getResult() - Method in class alluxio.thrift.FileSystemMasterWorkerService.AsyncClient.getPinnedFileIds_call
 
getResult() - Method in class alluxio.thrift.FileSystemMasterWorkerService.AsyncClient.getUfsInfo_call
 
getResult(I, FileSystemMasterWorkerService.fileSystemHeartbeat_args) - Method in class alluxio.thrift.FileSystemMasterWorkerService.Processor.fileSystemHeartbeat
 
getResult(I, FileSystemMasterWorkerService.getFileInfo_args) - Method in class alluxio.thrift.FileSystemMasterWorkerService.Processor.getFileInfo
 
getResult(I, FileSystemMasterWorkerService.getPinnedFileIds_args) - Method in class alluxio.thrift.FileSystemMasterWorkerService.Processor.getPinnedFileIds
 
getResult(I, FileSystemMasterWorkerService.getUfsInfo_args) - Method in class alluxio.thrift.FileSystemMasterWorkerService.Processor.getUfsInfo
 
getResult() - Method in class alluxio.thrift.FileSystemWorkerClientService.AsyncClient.cancelUfsFile_call
 
getResult() - Method in class alluxio.thrift.FileSystemWorkerClientService.AsyncClient.closeUfsFile_call
 
getResult() - Method in class alluxio.thrift.FileSystemWorkerClientService.AsyncClient.completeUfsFile_call
 
getResult() - Method in class alluxio.thrift.FileSystemWorkerClientService.AsyncClient.createUfsFile_call
 
getResult() - Method in class alluxio.thrift.FileSystemWorkerClientService.AsyncClient.openUfsFile_call
 
getResult() - Method in class alluxio.thrift.FileSystemWorkerClientService.AsyncClient.sessionFileSystemHeartbeat_call
 
getResult(I, FileSystemWorkerClientService.cancelUfsFile_args) - Method in class alluxio.thrift.FileSystemWorkerClientService.Processor.cancelUfsFile
 
getResult(I, FileSystemWorkerClientService.closeUfsFile_args) - Method in class alluxio.thrift.FileSystemWorkerClientService.Processor.closeUfsFile
 
getResult(I, FileSystemWorkerClientService.completeUfsFile_args) - Method in class alluxio.thrift.FileSystemWorkerClientService.Processor.completeUfsFile
 
getResult(I, FileSystemWorkerClientService.createUfsFile_args) - Method in class alluxio.thrift.FileSystemWorkerClientService.Processor.createUfsFile
 
getResult(I, FileSystemWorkerClientService.openUfsFile_args) - Method in class alluxio.thrift.FileSystemWorkerClientService.Processor.openUfsFile
 
getResult(I, FileSystemWorkerClientService.sessionFileSystemHeartbeat_args) - Method in class alluxio.thrift.FileSystemWorkerClientService.Processor.sessionFileSystemHeartbeat
 
getResult() - Method in class alluxio.thrift.KeyValueMasterClientService.AsyncClient.completePartition_call
 
getResult() - Method in class alluxio.thrift.KeyValueMasterClientService.AsyncClient.completeStore_call
 
getResult() - Method in class alluxio.thrift.KeyValueMasterClientService.AsyncClient.createStore_call
 
getResult() - Method in class alluxio.thrift.KeyValueMasterClientService.AsyncClient.deleteStore_call
 
getResult() - Method in class alluxio.thrift.KeyValueMasterClientService.AsyncClient.getPartitionInfo_call
 
getResult() - Method in class alluxio.thrift.KeyValueMasterClientService.AsyncClient.mergeStore_call
 
getResult() - Method in class alluxio.thrift.KeyValueMasterClientService.AsyncClient.renameStore_call
 
getResult(I, KeyValueMasterClientService.completePartition_args) - Method in class alluxio.thrift.KeyValueMasterClientService.Processor.completePartition
 
getResult(I, KeyValueMasterClientService.completeStore_args) - Method in class alluxio.thrift.KeyValueMasterClientService.Processor.completeStore
 
getResult(I, KeyValueMasterClientService.createStore_args) - Method in class alluxio.thrift.KeyValueMasterClientService.Processor.createStore
 
getResult(I, KeyValueMasterClientService.deleteStore_args) - Method in class alluxio.thrift.KeyValueMasterClientService.Processor.deleteStore
 
getResult(I, KeyValueMasterClientService.getPartitionInfo_args) - Method in class alluxio.thrift.KeyValueMasterClientService.Processor.getPartitionInfo
 
getResult(I, KeyValueMasterClientService.mergeStore_args) - Method in class alluxio.thrift.KeyValueMasterClientService.Processor.mergeStore
 
getResult(I, KeyValueMasterClientService.renameStore_args) - Method in class alluxio.thrift.KeyValueMasterClientService.Processor.renameStore
 
getResult() - Method in class alluxio.thrift.KeyValueWorkerClientService.AsyncClient.get_call
 
getResult() - Method in class alluxio.thrift.KeyValueWorkerClientService.AsyncClient.getNextKeys_call
 
getResult() - Method in class alluxio.thrift.KeyValueWorkerClientService.AsyncClient.getSize_call
 
getResult(I, KeyValueWorkerClientService.get_args) - Method in class alluxio.thrift.KeyValueWorkerClientService.Processor.get
 
getResult(I, KeyValueWorkerClientService.getNextKeys_args) - Method in class alluxio.thrift.KeyValueWorkerClientService.Processor.getNextKeys
 
getResult(I, KeyValueWorkerClientService.getSize_args) - Method in class alluxio.thrift.KeyValueWorkerClientService.Processor.getSize
 
getResult() - Method in class alluxio.thrift.LineageMasterClientService.AsyncClient.createLineage_call
 
getResult() - Method in class alluxio.thrift.LineageMasterClientService.AsyncClient.deleteLineage_call
 
getResult() - Method in class alluxio.thrift.LineageMasterClientService.AsyncClient.getLineageInfoList_call
 
getResult() - Method in class alluxio.thrift.LineageMasterClientService.AsyncClient.reinitializeFile_call
 
getResult() - Method in class alluxio.thrift.LineageMasterClientService.AsyncClient.reportLostFile_call
 
getResult(I, LineageMasterClientService.createLineage_args) - Method in class alluxio.thrift.LineageMasterClientService.Processor.createLineage
 
getResult(I, LineageMasterClientService.deleteLineage_args) - Method in class alluxio.thrift.LineageMasterClientService.Processor.deleteLineage
 
getResult(I, LineageMasterClientService.getLineageInfoList_args) - Method in class alluxio.thrift.LineageMasterClientService.Processor.getLineageInfoList
 
getResult(I, LineageMasterClientService.reinitializeFile_args) - Method in class alluxio.thrift.LineageMasterClientService.Processor.reinitializeFile
 
getResult(I, LineageMasterClientService.reportLostFile_args) - Method in class alluxio.thrift.LineageMasterClientService.Processor.reportLostFile
 
getResult() - Method in class alluxio.thrift.MetaMasterClientService.AsyncClient.backup_call
 
getResult() - Method in class alluxio.thrift.MetaMasterClientService.AsyncClient.getConfigReport_call
 
getResult() - Method in class alluxio.thrift.MetaMasterClientService.AsyncClient.getConfiguration_call
 
getResult() - Method in class alluxio.thrift.MetaMasterClientService.AsyncClient.getMasterInfo_call
 
getResult() - Method in class alluxio.thrift.MetaMasterClientService.AsyncClient.getMetrics_call
 
getResult(I, MetaMasterClientService.backup_args) - Method in class alluxio.thrift.MetaMasterClientService.Processor.backup
 
getResult(I, MetaMasterClientService.getConfigReport_args) - Method in class alluxio.thrift.MetaMasterClientService.Processor.getConfigReport
 
getResult(I, MetaMasterClientService.getConfiguration_args) - Method in class alluxio.thrift.MetaMasterClientService.Processor.getConfiguration
 
getResult(I, MetaMasterClientService.getMasterInfo_args) - Method in class alluxio.thrift.MetaMasterClientService.Processor.getMasterInfo
 
getResult(I, MetaMasterClientService.getMetrics_args) - Method in class alluxio.thrift.MetaMasterClientService.Processor.getMetrics
 
getResult() - Method in class alluxio.thrift.MetaMasterMasterService.AsyncClient.getMasterId_call
 
getResult() - Method in class alluxio.thrift.MetaMasterMasterService.AsyncClient.masterHeartbeat_call
 
getResult() - Method in class alluxio.thrift.MetaMasterMasterService.AsyncClient.registerMaster_call
 
getResult(I, MetaMasterMasterService.getMasterId_args) - Method in class alluxio.thrift.MetaMasterMasterService.Processor.getMasterId
 
getResult(I, MetaMasterMasterService.masterHeartbeat_args) - Method in class alluxio.thrift.MetaMasterMasterService.Processor.masterHeartbeat
 
getResult(I, MetaMasterMasterService.registerMaster_args) - Method in class alluxio.thrift.MetaMasterMasterService.Processor.registerMaster
 
getResult() - Method in class alluxio.thrift.MetricsMasterClientService.AsyncClient.metricsHeartbeat_call
 
getResult(I, MetricsMasterClientService.metricsHeartbeat_args) - Method in class alluxio.thrift.MetricsMasterClientService.Processor.metricsHeartbeat
 
getResult() - Method in class alluxio.underfs.ObjectUnderFileSystem.DeleteBuffer
Get the combined result from all batches.
getResultFromProcess(String[]) - Static method in class alluxio.cli.validation.Utils
Executes a command in another process and check for its execution result.
getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class alluxio.thrift.AlluxioService.AsyncProcessor.getServiceVersion
 
getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class alluxio.thrift.BlockMasterClientService.AsyncProcessor.getBlockInfo
 
getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class alluxio.thrift.BlockMasterClientService.AsyncProcessor.getBlockMasterInfo
 
getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class alluxio.thrift.BlockMasterClientService.AsyncProcessor.getCapacityBytes
 
getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class alluxio.thrift.BlockMasterClientService.AsyncProcessor.getUsedBytes
 
getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class alluxio.thrift.BlockMasterClientService.AsyncProcessor.getWorkerInfoList
 
getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class alluxio.thrift.BlockMasterClientService.AsyncProcessor.getWorkerReport
 
getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class alluxio.thrift.BlockMasterWorkerService.AsyncProcessor.blockHeartbeat
 
getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class alluxio.thrift.BlockMasterWorkerService.AsyncProcessor.commitBlock
 
getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class alluxio.thrift.BlockMasterWorkerService.AsyncProcessor.getWorkerId
 
getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class alluxio.thrift.BlockMasterWorkerService.AsyncProcessor.registerWorker
 
getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class alluxio.thrift.BlockWorkerClientService.AsyncProcessor.accessBlock
 
getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class alluxio.thrift.BlockWorkerClientService.AsyncProcessor.cacheBlock
 
getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class alluxio.thrift.BlockWorkerClientService.AsyncProcessor.cancelBlock
 
getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class alluxio.thrift.BlockWorkerClientService.AsyncProcessor.lockBlock
 
getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class alluxio.thrift.BlockWorkerClientService.AsyncProcessor.promoteBlock
 
getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class alluxio.thrift.BlockWorkerClientService.AsyncProcessor.removeBlock
 
getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class alluxio.thrift.BlockWorkerClientService.AsyncProcessor.requestBlockLocation
 
getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class alluxio.thrift.BlockWorkerClientService.AsyncProcessor.requestSpace
 
getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class alluxio.thrift.BlockWorkerClientService.AsyncProcessor.sessionBlockHeartbeat
 
getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class alluxio.thrift.BlockWorkerClientService.AsyncProcessor.unlockBlock
 
getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class alluxio.thrift.FileSystemMasterClientService.AsyncProcessor.checkConsistency
 
getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class alluxio.thrift.FileSystemMasterClientService.AsyncProcessor.completeFile
 
getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class alluxio.thrift.FileSystemMasterClientService.AsyncProcessor.createDirectory
 
getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class alluxio.thrift.FileSystemMasterClientService.AsyncProcessor.createFile
 
getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class alluxio.thrift.FileSystemMasterClientService.AsyncProcessor.free
 
getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class alluxio.thrift.FileSystemMasterClientService.AsyncProcessor.getFilePath
 
getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class alluxio.thrift.FileSystemMasterClientService.AsyncProcessor.getMountTable
 
getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class alluxio.thrift.FileSystemMasterClientService.AsyncProcessor.getNewBlockIdForFile
 
getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class alluxio.thrift.FileSystemMasterClientService.AsyncProcessor.getStatus
 
getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class alluxio.thrift.FileSystemMasterClientService.AsyncProcessor.listStatus
 
getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class alluxio.thrift.FileSystemMasterClientService.AsyncProcessor.loadMetadata
 
getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class alluxio.thrift.FileSystemMasterClientService.AsyncProcessor.mount
 
getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class alluxio.thrift.FileSystemMasterClientService.AsyncProcessor.remove
 
getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class alluxio.thrift.FileSystemMasterClientService.AsyncProcessor.rename
 
getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class alluxio.thrift.FileSystemMasterClientService.AsyncProcessor.scheduleAsyncPersistence
 
getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class alluxio.thrift.FileSystemMasterClientService.AsyncProcessor.setAttribute
 
getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class alluxio.thrift.FileSystemMasterClientService.AsyncProcessor.unmount
 
getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class alluxio.thrift.FileSystemMasterClientService.AsyncProcessor.updateUfsMode
 
getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class alluxio.thrift.FileSystemMasterWorkerService.AsyncProcessor.fileSystemHeartbeat
 
getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class alluxio.thrift.FileSystemMasterWorkerService.AsyncProcessor.getFileInfo
 
getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class alluxio.thrift.FileSystemMasterWorkerService.AsyncProcessor.getPinnedFileIds
 
getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class alluxio.thrift.FileSystemMasterWorkerService.AsyncProcessor.getUfsInfo
 
getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class alluxio.thrift.FileSystemWorkerClientService.AsyncProcessor.cancelUfsFile
 
getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class alluxio.thrift.FileSystemWorkerClientService.AsyncProcessor.closeUfsFile
 
getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class alluxio.thrift.FileSystemWorkerClientService.AsyncProcessor.completeUfsFile
 
getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class alluxio.thrift.FileSystemWorkerClientService.AsyncProcessor.createUfsFile
 
getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class alluxio.thrift.FileSystemWorkerClientService.AsyncProcessor.openUfsFile
 
getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class alluxio.thrift.FileSystemWorkerClientService.AsyncProcessor.sessionFileSystemHeartbeat
 
getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class alluxio.thrift.KeyValueMasterClientService.AsyncProcessor.completePartition
 
getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class alluxio.thrift.KeyValueMasterClientService.AsyncProcessor.completeStore
 
getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class alluxio.thrift.KeyValueMasterClientService.AsyncProcessor.createStore
 
getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class alluxio.thrift.KeyValueMasterClientService.AsyncProcessor.deleteStore
 
getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class alluxio.thrift.KeyValueMasterClientService.AsyncProcessor.getPartitionInfo
 
getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class alluxio.thrift.KeyValueMasterClientService.AsyncProcessor.mergeStore
 
getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class alluxio.thrift.KeyValueMasterClientService.AsyncProcessor.renameStore
 
getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class alluxio.thrift.KeyValueWorkerClientService.AsyncProcessor.get
 
getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class alluxio.thrift.KeyValueWorkerClientService.AsyncProcessor.getNextKeys
 
getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class alluxio.thrift.KeyValueWorkerClientService.AsyncProcessor.getSize
 
getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class alluxio.thrift.LineageMasterClientService.AsyncProcessor.createLineage
 
getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class alluxio.thrift.LineageMasterClientService.AsyncProcessor.deleteLineage
 
getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class alluxio.thrift.LineageMasterClientService.AsyncProcessor.getLineageInfoList
 
getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class alluxio.thrift.LineageMasterClientService.AsyncProcessor.reinitializeFile
 
getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class alluxio.thrift.LineageMasterClientService.AsyncProcessor.reportLostFile
 
getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class alluxio.thrift.MetaMasterClientService.AsyncProcessor.backup
 
getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class alluxio.thrift.MetaMasterClientService.AsyncProcessor.getConfigReport
 
getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class alluxio.thrift.MetaMasterClientService.AsyncProcessor.getConfiguration
 
getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class alluxio.thrift.MetaMasterClientService.AsyncProcessor.getMasterInfo
 
getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class alluxio.thrift.MetaMasterClientService.AsyncProcessor.getMetrics
 
getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class alluxio.thrift.MetaMasterMasterService.AsyncProcessor.getMasterId
 
getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class alluxio.thrift.MetaMasterMasterService.AsyncProcessor.masterHeartbeat
 
getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class alluxio.thrift.MetaMasterMasterService.AsyncProcessor.registerMaster
 
getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class alluxio.thrift.MetricsMasterClientService.AsyncProcessor.metricsHeartbeat
 
getRoot() - Method in class alluxio.master.file.meta.InodeTree
 
getRoot() - Method in class alluxio.underfs.AbstractUfsManager
 
getRoot() - Method in interface alluxio.underfs.UfsManager
 
getRootCause(Throwable) - Static method in class alluxio.util.CommonUtils
Gets the root cause of an exception.
getRootKey() - Method in class alluxio.underfs.cos.COSUnderFileSystem
 
getRootKey() - Method in class alluxio.underfs.gcs.GCSUnderFileSystem
 
getRootKey() - Method in class alluxio.underfs.ObjectUnderFileSystem
Get full path of root in object store.
getRootKey() - Method in class alluxio.underfs.oss.OSSUnderFileSystem
 
getRootKey() - Method in class alluxio.underfs.s3a.S3AUnderFileSystem
 
getRootKey() - Method in class alluxio.underfs.swift.SwiftUnderFileSystem
 
getRootLineage() - Method in class alluxio.master.lineage.meta.LineageStoreView
 
getRootLineages() - Method in class alluxio.master.lineage.meta.LineageStore
 
getRootPath() - Method in class alluxio.AlluxioURI
 
getRoots() - Method in class alluxio.collections.DirectedAcyclicGraph
Gets the payloads of all the root nodes of the DAG.
getRootUserName() - Method in class alluxio.master.file.meta.InodeTree
 
getRpcAddress() - Method in class alluxio.master.AlluxioMasterProcess
 
getRpcAddress() - Method in interface alluxio.master.MasterProcess
 
getRpcAddress() - Method in class alluxio.master.meta.AlluxioMasterRestServiceHandler
Deprecated.
since version 1.4 and will be removed in version 2.0
getRpcAddress() - Method in class alluxio.master.meta.DefaultMetaMaster
 
getRpcAddress() - Method in interface alluxio.master.meta.MetaMaster
 
getRpcAddress() - Method in class alluxio.wire.AlluxioMasterInfo
 
getRpcAddress() - Method in class alluxio.wire.AlluxioWorkerInfo
 
getRpcAddress() - Method in class alluxio.worker.AlluxioWorkerProcess
 
getRpcAddress() - Method in class alluxio.worker.AlluxioWorkerRestServiceHandler
Deprecated.
since version 1.4 and will be removed in version 2.0
getRpcAddress() - Method in interface alluxio.worker.WorkerProcess
 
getRpcLocalPort() - Method in class alluxio.master.LocalAlluxioMaster
Gets the actual port that the RPC service is listening on.
getRpcPort() - Method in class alluxio.multi.process.MasterNetAddress
 
getRpcPort() - Method in class alluxio.thrift.MasterInfo
 
getRpcPort() - Method in class alluxio.thrift.MasterNetAddress
 
getRpcPort() - Method in class alluxio.thrift.WorkerNetAddress
 
getRpcPort() - Method in class alluxio.wire.Address
 
getRpcPort() - Method in class alluxio.wire.MasterInfo
 
getRpcPort() - Method in class alluxio.wire.WorkerNetAddress
 
getRpcPortSocketAddress(WorkerNetAddress) - Static method in class alluxio.util.network.NetworkAddressUtils
Extracts rpcPort InetSocketAddress from Alluxio representation of network address.
getSafeModeManager() - Method in class alluxio.master.MasterContext
 
getScheme() - Method in class alluxio.AlluxioURI
Gets the scheme of the AlluxioURI.
getScheme() - Method in class alluxio.hadoop.FaultTolerantFileSystem
Deprecated.
 
getScheme() - Method in class alluxio.hadoop.FileSystem
 
getScheme() - Method in class alluxio.MultiPartSchemeURI
 
getScheme() - Method in class alluxio.StandardURI
 
getScheme() - Method in interface alluxio.URI
 
getScope() - Method in class alluxio.PropertyKey
 
getSecond() - Method in class alluxio.collections.Pair
 
getSequenceNumber(long) - Static method in class alluxio.master.block.BlockId
 
getSequenceNumber() - Method in class alluxio.proto.journal.File.InodeDirectoryIdGeneratorEntry.Builder
optional int64 sequence_number = 2;
getSequenceNumber() - Method in class alluxio.proto.journal.File.InodeDirectoryIdGeneratorEntry
optional int64 sequence_number = 2;
getSequenceNumber() - Method in interface alluxio.proto.journal.File.InodeDirectoryIdGeneratorEntryOrBuilder
optional int64 sequence_number = 2;
getSequenceNumber() - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
optional int64 sequence_number = 1;
getSequenceNumber() - Method in class alluxio.proto.journal.Journal.JournalEntry
optional int64 sequence_number = 1;
getSequenceNumber() - Method in interface alluxio.proto.journal.Journal.JournalEntryOrBuilder
optional int64 sequence_number = 1;
getSequenceNumber() - Method in class alluxio.proto.journal.Lineage.LineageIdGeneratorEntry.Builder
optional int64 sequence_number = 1;
getSequenceNumber() - Method in class alluxio.proto.journal.Lineage.LineageIdGeneratorEntry
optional int64 sequence_number = 1;
getSequenceNumber() - Method in interface alluxio.proto.journal.Lineage.LineageIdGeneratorEntryOrBuilder
optional int64 sequence_number = 1;
getSerializedSize() - Method in class alluxio.proto.dataserver.Protocol.AsyncCacheRequest
 
getSerializedSize() - Method in class alluxio.proto.dataserver.Protocol.CreateUfsFileOptions
 
getSerializedSize() - Method in class alluxio.proto.dataserver.Protocol.Heartbeat
 
getSerializedSize() - Method in class alluxio.proto.dataserver.Protocol.LocalBlockCloseRequest
 
getSerializedSize() - Method in class alluxio.proto.dataserver.Protocol.LocalBlockCompleteRequest
 
getSerializedSize() - Method in class alluxio.proto.dataserver.Protocol.LocalBlockCreateRequest
 
getSerializedSize() - Method in class alluxio.proto.dataserver.Protocol.LocalBlockCreateResponse
 
getSerializedSize() - Method in class alluxio.proto.dataserver.Protocol.LocalBlockOpenRequest
 
getSerializedSize() - Method in class alluxio.proto.dataserver.Protocol.LocalBlockOpenResponse
 
getSerializedSize() - Method in class alluxio.proto.dataserver.Protocol.OpenUfsBlockOptions
 
getSerializedSize() - Method in class alluxio.proto.dataserver.Protocol.ReadRequest
 
getSerializedSize() - Method in class alluxio.proto.dataserver.Protocol.ReadResponse
 
getSerializedSize() - Method in class alluxio.proto.dataserver.Protocol.Response
 
getSerializedSize() - Method in class alluxio.proto.dataserver.Protocol.WriteRequest
 
getSerializedSize() - Method in class alluxio.proto.journal.Block.BlockContainerIdGeneratorEntry
 
getSerializedSize() - Method in class alluxio.proto.journal.Block.BlockInfoEntry
 
getSerializedSize() - Method in class alluxio.proto.journal.Block.DeleteBlockEntry
 
getSerializedSize() - Method in class alluxio.proto.journal.File.AddMountPointEntry
 
getSerializedSize() - Method in class alluxio.proto.journal.File.AsyncPersistRequestEntry
 
getSerializedSize() - Method in class alluxio.proto.journal.File.CompleteFileEntry
 
getSerializedSize() - Method in class alluxio.proto.journal.File.DeleteFileEntry
 
getSerializedSize() - Method in class alluxio.proto.journal.File.DeleteMountPointEntry
 
getSerializedSize() - Method in class alluxio.proto.journal.File.InodeDirectoryEntry
 
getSerializedSize() - Method in class alluxio.proto.journal.File.InodeDirectoryIdGeneratorEntry
 
getSerializedSize() - Method in class alluxio.proto.journal.File.InodeFileEntry
 
getSerializedSize() - Method in class alluxio.proto.journal.File.InodeLastModificationTimeEntry
 
getSerializedSize() - Method in class alluxio.proto.journal.File.PersistDirectoryEntry
 
getSerializedSize() - Method in class alluxio.proto.journal.File.PersistFileEntry
 
getSerializedSize() - Method in class alluxio.proto.journal.File.ReinitializeFileEntry
 
getSerializedSize() - Method in class alluxio.proto.journal.File.RenameEntry
 
getSerializedSize() - Method in class alluxio.proto.journal.File.SetAttributeEntry
 
getSerializedSize() - Method in class alluxio.proto.journal.File.StringPairEntry
 
getSerializedSize() - Method in class alluxio.proto.journal.File.UpdateUfsModeEntry
 
getSerializedSize() - Method in class alluxio.proto.journal.Journal.JournalEntry
 
getSerializedSize() - Method in class alluxio.proto.journal.KeyValue.CompletePartitionEntry
 
getSerializedSize() - Method in class alluxio.proto.journal.KeyValue.CompleteStoreEntry
 
getSerializedSize() - Method in class alluxio.proto.journal.KeyValue.CreateStoreEntry
 
getSerializedSize() - Method in class alluxio.proto.journal.KeyValue.DeleteStoreEntry
 
getSerializedSize() - Method in class alluxio.proto.journal.KeyValue.MergeStoreEntry
 
getSerializedSize() - Method in class alluxio.proto.journal.KeyValue.RenameStoreEntry
 
getSerializedSize() - Method in class alluxio.proto.journal.Lineage.DeleteLineageEntry
 
getSerializedSize() - Method in class alluxio.proto.journal.Lineage.LineageEntry
 
getSerializedSize() - Method in class alluxio.proto.journal.Lineage.LineageIdGeneratorEntry
 
getServer() - Method in class alluxio.web.WebServer
 
getServerChannelClass(boolean) - Static method in class alluxio.util.network.NettyUtils
Returns the correct ServerSocketChannel class for use by the worker.
getServerHostnames() - Static method in class alluxio.cli.extensions.ExtensionsShellUtils
Gets list of masters/workers in conf directory.
getServers() - Method in class alluxio.Registry
 
getServerTransportFactory(String) - Method in class alluxio.security.authentication.NoSaslTransportProvider
 
getServerTransportFactory(Runnable, String) - Method in class alluxio.security.authentication.NoSaslTransportProvider
 
getServerTransportFactory(String) - Method in class alluxio.security.authentication.PlainSaslTransportProvider
 
getServerTransportFactory(Runnable, String) - Method in class alluxio.security.authentication.PlainSaslTransportProvider
 
getServerTransportFactory(String) - Method in interface alluxio.security.authentication.TransportProvider
For server side, this method returns a TTransportFactory based on the auth type.
getServerTransportFactory(Runnable, String) - Method in interface alluxio.security.authentication.TransportProvider
For server side, this method returns a TTransportFactory based on the auth type.
getServiceName() - Method in class alluxio.AbstractClient
 
getServiceName() - Method in class alluxio.client.block.RetryHandlingBlockMasterClient
 
getServiceName() - Method in class alluxio.client.file.RetryHandlingFileSystemMasterClient
 
getServiceName() - Method in class alluxio.client.keyvalue.KeyValueMasterClient
 
getServiceName() - Method in class alluxio.client.keyvalue.KeyValueWorkerClient
 
getServiceName() - Method in class alluxio.client.lineage.LineageMasterClient
 
getServiceName() - Method in class alluxio.client.metrics.MetricsMasterClient
 
getServiceName() - Method in class alluxio.client.RetryHandlingMetaMasterClient
 
getServiceName() - Method in class alluxio.master.block.BlockMasterClientRestServiceHandler
Deprecated.
 
getServiceName() - Method in class alluxio.master.file.FileSystemMasterClientRestServiceHandler
Deprecated.
 
getServiceName() - Method in class alluxio.master.lineage.LineageMasterClientRestServiceHandler
Deprecated.
 
getServiceName() - Method in class alluxio.master.meta.RetryHandlingMetaMasterMasterClient
 
getServiceName() - Method in enum alluxio.util.network.NetworkAddressUtils.ServiceType
Gets service name.
getServiceName() - Method in class alluxio.worker.block.BlockMasterClient
 
getServiceName() - Method in class alluxio.worker.file.FileSystemMasterClient
 
getServices() - Method in class alluxio.master.block.DefaultBlockMaster
 
getServices() - Method in class alluxio.master.file.DefaultFileSystemMaster
 
getServices() - Method in class alluxio.master.keyvalue.DefaultKeyValueMaster
 
getServices() - Method in class alluxio.master.lineage.DefaultLineageMaster
 
getServices() - Method in class alluxio.master.meta.DefaultMetaMaster
 
getServices() - Method in class alluxio.master.metrics.DefaultMetricsMaster
 
getServices() - Method in class alluxio.master.NoopMaster
 
getServices() - Method in interface alluxio.Server
 
getServices() - Method in class alluxio.worker.block.DefaultBlockWorker
 
getServices() - Method in class alluxio.worker.file.DefaultFileSystemWorker
 
getServices() - Method in class alluxio.worker.keyvalue.KeyValueWorker
 
getServiceVersion() - Method in class alluxio.AbstractClient
 
getServiceVersion() - Method in class alluxio.client.block.RetryHandlingBlockMasterClient
 
getServiceVersion() - Method in class alluxio.client.file.RetryHandlingFileSystemMasterClient
 
getServiceVersion() - Method in class alluxio.client.keyvalue.KeyValueMasterClient
 
getServiceVersion() - Method in class alluxio.client.keyvalue.KeyValueWorkerClient
 
getServiceVersion() - Method in class alluxio.client.lineage.LineageMasterClient
 
getServiceVersion() - Method in class alluxio.client.metrics.MetricsMasterClient
 
getServiceVersion() - Method in class alluxio.client.RetryHandlingMetaMasterClient
 
getServiceVersion() - Method in class alluxio.master.block.BlockMasterClientRestServiceHandler
Deprecated.
 
getServiceVersion(GetServiceVersionTOptions) - Method in class alluxio.master.block.BlockMasterClientServiceHandler
 
getServiceVersion(GetServiceVersionTOptions) - Method in class alluxio.master.block.BlockMasterWorkerServiceHandler
 
getServiceVersion() - Method in class alluxio.master.file.FileSystemMasterClientRestServiceHandler
Deprecated.
 
getServiceVersion(GetServiceVersionTOptions) - Method in class alluxio.master.file.FileSystemMasterClientServiceHandler
 
getServiceVersion(GetServiceVersionTOptions) - Method in class alluxio.master.file.FileSystemMasterWorkerServiceHandler
 
getServiceVersion(GetServiceVersionTOptions) - Method in class alluxio.master.keyvalue.KeyValueMasterClientServiceHandler
 
getServiceVersion() - Method in class alluxio.master.lineage.LineageMasterClientRestServiceHandler
Deprecated.
 
getServiceVersion(GetServiceVersionTOptions) - Method in class alluxio.master.lineage.LineageMasterClientServiceHandler
 
getServiceVersion(GetServiceVersionTOptions) - Method in class alluxio.master.meta.MetaMasterClientServiceHandler
 
getServiceVersion(GetServiceVersionTOptions) - Method in class alluxio.master.meta.MetaMasterMasterServiceHandler
 
getServiceVersion() - Method in class alluxio.master.meta.RetryHandlingMetaMasterMasterClient
 
getServiceVersion(GetServiceVersionTOptions) - Method in class alluxio.master.metrics.MetricsMasterClientServiceHandler
 
getServiceVersion(GetServiceVersionTOptions, AsyncMethodCallback) - Method in class alluxio.thrift.AlluxioService.AsyncClient
 
getServiceVersion(GetServiceVersionTOptions, AsyncMethodCallback) - Method in interface alluxio.thrift.AlluxioService.AsyncIface
 
getServiceVersion() - Constructor for class alluxio.thrift.AlluxioService.AsyncProcessor.getServiceVersion
 
getServiceVersion(GetServiceVersionTOptions) - Method in class alluxio.thrift.AlluxioService.Client
 
getServiceVersion(GetServiceVersionTOptions) - Method in interface alluxio.thrift.AlluxioService.Iface
Returns the version of the master service.
getServiceVersion() - Constructor for class alluxio.thrift.AlluxioService.Processor.getServiceVersion
 
getServiceVersion() - Method in class alluxio.worker.block.BlockMasterClient
 
getServiceVersion(GetServiceVersionTOptions) - Method in class alluxio.worker.block.BlockWorkerClientServiceHandler
 
getServiceVersion() - Method in class alluxio.worker.file.FileSystemMasterClient
 
getServiceVersion(GetServiceVersionTOptions) - Method in class alluxio.worker.file.FileSystemWorkerClientServiceHandler
 
getServiceVersion(GetServiceVersionTOptions) - Method in class alluxio.worker.keyvalue.KeyValueWorkerClientServiceHandler
 
getServiceVersion_args() - Constructor for class alluxio.thrift.AlluxioService.getServiceVersion_args
 
getServiceVersion_args(GetServiceVersionTOptions) - Constructor for class alluxio.thrift.AlluxioService.getServiceVersion_args
 
getServiceVersion_args(AlluxioService.getServiceVersion_args) - Constructor for class alluxio.thrift.AlluxioService.getServiceVersion_args
Performs a deep copy on other.
getServiceVersion_call(GetServiceVersionTOptions, AsyncMethodCallback, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class alluxio.thrift.AlluxioService.AsyncClient.getServiceVersion_call
 
getServiceVersion_result() - Constructor for class alluxio.thrift.AlluxioService.getServiceVersion_result
 
getServiceVersion_result(GetServiceVersionTResponse, AlluxioTException) - Constructor for class alluxio.thrift.AlluxioService.getServiceVersion_result
 
getServiceVersion_result(AlluxioService.getServiceVersion_result) - Constructor for class alluxio.thrift.AlluxioService.getServiceVersion_result
Performs a deep copy on other.
GetServiceVersionTOptions - Class in alluxio.thrift
 
GetServiceVersionTOptions() - Constructor for class alluxio.thrift.GetServiceVersionTOptions
 
GetServiceVersionTOptions(GetServiceVersionTOptions) - Constructor for class alluxio.thrift.GetServiceVersionTOptions
Performs a deep copy on other.
GetServiceVersionTOptions._Fields - Enum in alluxio.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
GetServiceVersionTResponse - Class in alluxio.thrift
 
GetServiceVersionTResponse() - Constructor for class alluxio.thrift.GetServiceVersionTResponse
 
GetServiceVersionTResponse(long) - Constructor for class alluxio.thrift.GetServiceVersionTResponse
 
GetServiceVersionTResponse(GetServiceVersionTResponse) - Constructor for class alluxio.thrift.GetServiceVersionTResponse
Performs a deep copy on other.
GetServiceVersionTResponse._Fields - Enum in alluxio.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
getSessionId() - Method in class alluxio.SessionInfo
 
getSessionId() - Method in class alluxio.thrift.BlockWorkerClientService.cacheBlock_args
the id of the current session
getSessionId() - Method in class alluxio.thrift.BlockWorkerClientService.cancelBlock_args
the id of the current session
getSessionId() - Method in class alluxio.thrift.BlockWorkerClientService.lockBlock_args
the id of the current session
getSessionId() - Method in class alluxio.thrift.BlockWorkerClientService.requestBlockLocation_args
the id of the current session
getSessionId() - Method in class alluxio.thrift.BlockWorkerClientService.requestSpace_args
the id of the current session
getSessionId() - Method in class alluxio.thrift.BlockWorkerClientService.sessionBlockHeartbeat_args
the id of the current session
getSessionId() - Method in class alluxio.thrift.BlockWorkerClientService.unlockBlock_args
the id of the current session
getSessionId() - Method in class alluxio.thrift.FileSystemWorkerClientService.cancelUfsFile_args
the id of the current session
getSessionId() - Method in class alluxio.thrift.FileSystemWorkerClientService.closeUfsFile_args
the id of the current session
getSessionId() - Method in class alluxio.thrift.FileSystemWorkerClientService.completeUfsFile_args
the id of the current session
getSessionId() - Method in class alluxio.thrift.FileSystemWorkerClientService.createUfsFile_args
the id of the current session
getSessionId() - Method in class alluxio.thrift.FileSystemWorkerClientService.openUfsFile_args
the id of the current session
getSessionId() - Method in class alluxio.thrift.FileSystemWorkerClientService.sessionFileSystemHeartbeat_args
the id of the current session
getSessionId() - Method in class alluxio.worker.block.meta.TempBlockMeta
 
getSessionId() - Method in class alluxio.worker.block.meta.UnderFileSystemBlockMeta
 
getSessionTempBlocks(long) - Method in class alluxio.worker.block.BlockMetadataManager
Gets all the temporary blocks associated with a session, empty list is returned if the session has no temporary blocks.
getSessionTempBlocks(long) - Method in class alluxio.worker.block.meta.StorageDir
Gets the temporary blocks associated with a session in this StorageDir, an empty list is returned if the session has no temporary blocks in this StorageDir.
getSetAttribute() - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
optional .alluxio.proto.journal.SetAttributeEntry set_attribute = 27;
getSetAttribute() - Method in class alluxio.proto.journal.Journal.JournalEntry
optional .alluxio.proto.journal.SetAttributeEntry set_attribute = 27;
getSetAttribute() - Method in interface alluxio.proto.journal.Journal.JournalEntryOrBuilder
optional .alluxio.proto.journal.SetAttributeEntry set_attribute = 27;
getSetAttributeBuilder() - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
optional .alluxio.proto.journal.SetAttributeEntry set_attribute = 27;
getSetAttributeOrBuilder() - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
optional .alluxio.proto.journal.SetAttributeEntry set_attribute = 27;
getSetAttributeOrBuilder() - Method in class alluxio.proto.journal.Journal.JournalEntry
optional .alluxio.proto.journal.SetAttributeEntry set_attribute = 27;
getSetAttributeOrBuilder() - Method in interface alluxio.proto.journal.Journal.JournalEntryOrBuilder
optional .alluxio.proto.journal.SetAttributeEntry set_attribute = 27;
getSetPermissionCommand(String, String) - Static method in class alluxio.util.ShellUtils
Returns a Unix command to set permission.
getShared() - Method in class alluxio.master.file.meta.MountTable.Resolution
 
getShared() - Method in class alluxio.proto.journal.File.AddMountPointEntry.Builder
optional bool shared = 5;
getShared() - Method in class alluxio.proto.journal.File.AddMountPointEntry
optional bool shared = 5;
getShared() - Method in interface alluxio.proto.journal.File.AddMountPointEntryOrBuilder
optional bool shared = 5;
getShared() - Method in class alluxio.wire.MountPointInfo
 
getShellName() - Method in class alluxio.cli.AbstractShell
 
getShellName() - Method in class alluxio.cli.extensions.ExtensionsShell
 
getShellName() - Method in class alluxio.cli.fs.FileSystemShell
 
getShellName() - Method in class alluxio.cli.fsadmin.FileSystemAdminShell
 
getSize(long) - Method in class alluxio.client.keyvalue.KeyValueWorkerClient
 
getSize() - Method in class alluxio.master.file.meta.InodeTree
 
getSize() - Method in class alluxio.proxy.s3.ListBucketResult.Content
 
getSize() - Method in class alluxio.proxy.s3.ListPartsResult.Part
 
getSize() - Method in class alluxio.thrift.GetSizeTResponse
 
getSize(long, GetSizeTOptions, AsyncMethodCallback) - Method in class alluxio.thrift.KeyValueWorkerClientService.AsyncClient
 
getSize(long, GetSizeTOptions, AsyncMethodCallback) - Method in interface alluxio.thrift.KeyValueWorkerClientService.AsyncIface
 
getSize() - Constructor for class alluxio.thrift.KeyValueWorkerClientService.AsyncProcessor.getSize
 
getSize(long, GetSizeTOptions) - Method in class alluxio.thrift.KeyValueWorkerClientService.Client
 
getSize(long, GetSizeTOptions) - Method in interface alluxio.thrift.KeyValueWorkerClientService.Iface
Gets the number of key-value pairs in the partition.
getSize() - Constructor for class alluxio.thrift.KeyValueWorkerClientService.Processor.getSize
 
getSize() - Method in class alluxio.util.UnixMountInfo.Options
 
getSize() - Method in class alluxio.web.UIFileInfo
 
getSize(long, GetSizeTOptions) - Method in class alluxio.worker.keyvalue.KeyValueWorkerClientServiceHandler
 
getSize_args() - Constructor for class alluxio.thrift.KeyValueWorkerClientService.getSize_args
 
getSize_args(long, GetSizeTOptions) - Constructor for class alluxio.thrift.KeyValueWorkerClientService.getSize_args
 
getSize_args(KeyValueWorkerClientService.getSize_args) - Constructor for class alluxio.thrift.KeyValueWorkerClientService.getSize_args
Performs a deep copy on other.
getSize_call(long, GetSizeTOptions, AsyncMethodCallback, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class alluxio.thrift.KeyValueWorkerClientService.AsyncClient.getSize_call
 
getSize_result() - Constructor for class alluxio.thrift.KeyValueWorkerClientService.getSize_result
 
getSize_result(GetSizeTResponse, AlluxioTException) - Constructor for class alluxio.thrift.KeyValueWorkerClientService.getSize_result
 
getSize_result(KeyValueWorkerClientService.getSize_result) - Constructor for class alluxio.thrift.KeyValueWorkerClientService.getSize_result
Performs a deep copy on other.
getSizeFromBytes(long) - Static method in class alluxio.util.FormatUtils
Returns a human-readable version of bytes 10GB 2048KB etc.
GetSizeTOptions - Class in alluxio.thrift
 
GetSizeTOptions() - Constructor for class alluxio.thrift.GetSizeTOptions
 
GetSizeTOptions(GetSizeTOptions) - Constructor for class alluxio.thrift.GetSizeTOptions
Performs a deep copy on other.
GetSizeTOptions._Fields - Enum in alluxio.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
GetSizeTResponse - Class in alluxio.thrift
 
GetSizeTResponse() - Constructor for class alluxio.thrift.GetSizeTResponse
 
GetSizeTResponse(int) - Constructor for class alluxio.thrift.GetSizeTResponse
 
GetSizeTResponse(GetSizeTResponse) - Constructor for class alluxio.thrift.GetSizeTResponse
Performs a deep copy on other.
GetSizeTResponse._Fields - Enum in alluxio.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
getSleeper() - Method in class alluxio.time.TimeContext
 
getSleepTime() - Method in class alluxio.retry.ExponentialBackoffRetry
 
getSleepTime() - Method in class alluxio.retry.SleepingRetry
How long to sleep before the next retry is performed.
getSleepUnit() - Method in class alluxio.retry.SleepingRetry
Unit of time that SleepingRetry.getSleepTime() is measured in.
getSnapshot(UfsJournal) - Static method in class alluxio.master.journal.ufs.UfsJournalSnapshot
Creates a snapshot of the journal.
getSource(PropertyKey) - Method in interface alluxio.AlluxioConfiguration
 
getSource() - Method in class alluxio.client.block.stream.BlockInStream
 
getSource(PropertyKey) - Method in class alluxio.conf.AlluxioProperties
 
getSource(PropertyKey) - Method in class alluxio.conf.InstancedConfiguration
 
getSource(PropertyKey) - Static method in class alluxio.Configuration
 
getSource() - Method in class alluxio.master.meta.checkconf.ConfigRecord
 
getSource() - Method in class alluxio.thrift.ConfigProperty
 
getSource() - Method in class alluxio.wire.ConfigProperty
 
getSourceHost() - Method in class alluxio.proto.dataserver.Protocol.AsyncCacheRequest.Builder
optional string source_host = 2;
getSourceHost() - Method in class alluxio.proto.dataserver.Protocol.AsyncCacheRequest
optional string source_host = 2;
getSourceHost() - Method in interface alluxio.proto.dataserver.Protocol.AsyncCacheRequestOrBuilder
optional string source_host = 2;
getSourceHostBytes() - Method in class alluxio.proto.dataserver.Protocol.AsyncCacheRequest.Builder
optional string source_host = 2;
getSourceHostBytes() - Method in class alluxio.proto.dataserver.Protocol.AsyncCacheRequest
optional string source_host = 2;
getSourceHostBytes() - Method in interface alluxio.proto.dataserver.Protocol.AsyncCacheRequestOrBuilder
optional string source_host = 2;
getSourcePort() - Method in class alluxio.proto.dataserver.Protocol.AsyncCacheRequest.Builder
optional int32 source_port = 3;
getSourcePort() - Method in class alluxio.proto.dataserver.Protocol.AsyncCacheRequest
optional int32 source_port = 3;
getSourcePort() - Method in interface alluxio.proto.dataserver.Protocol.AsyncCacheRequestOrBuilder
optional int32 source_port = 3;
getSpace(String, UnderFileSystem.SpaceType) - Method in class alluxio.underfs.hdfs.HdfsUnderFileSystem
 
getSpace(String, UnderFileSystem.SpaceType) - Method in class alluxio.underfs.local.LocalUnderFileSystem
 
getSpace(String, UnderFileSystem.SpaceType) - Method in class alluxio.underfs.ObjectUnderFileSystem
 
getSpace(String, UnderFileSystem.SpaceType) - Method in interface alluxio.underfs.UnderFileSystem
Queries the under file system about the space of the indicated path (e.g., space left, space used and etc).
getSpace(String, UnderFileSystem.SpaceType) - Method in class alluxio.underfs.UnderFileSystemWithLogging
 
getSpaceToReserve() - Method in class alluxio.proto.dataserver.Protocol.LocalBlockCreateRequest.Builder
optional int64 space_to_reserve = 4;
getSpaceToReserve() - Method in class alluxio.proto.dataserver.Protocol.LocalBlockCreateRequest
optional int64 space_to_reserve = 4;
getSpaceToReserve() - Method in interface alluxio.proto.dataserver.Protocol.LocalBlockCreateRequestOrBuilder
optional int64 space_to_reserve = 4;
getSplits(JobContext) - Method in class alluxio.hadoop.mapreduce.KeyValueInputFormat
Returns a list of KeyValueInputSplit where each split is one key-value partition.
getSrcLocation() - Method in class alluxio.worker.block.evictor.BlockTransferInfo
 
getStartTime() - Method in class alluxio.master.block.meta.MasterWorkerInfo
 
getStartTime() - Method in class alluxio.web.WebInterfaceWorkerGeneralServlet.UIWorkerInfo
 
getStartTimeMs() - Method in class alluxio.master.AlluxioMasterProcess
 
getStartTimeMs() - Method in class alluxio.master.MasterContext
 
getStartTimeMs() - Method in interface alluxio.master.MasterProcess
 
getStartTimeMs() - Method in class alluxio.master.meta.AlluxioMasterRestServiceHandler
Deprecated.
since version 1.4 and will be removed in version 2.0
getStartTimeMs() - Method in class alluxio.master.meta.DefaultMetaMaster
 
getStartTimeMs() - Method in interface alluxio.master.meta.MetaMaster
 
getStartTimeMs() - Method in class alluxio.proxy.AlluxioProxyProcess
 
getStartTimeMs() - Method in interface alluxio.proxy.ProxyProcess
 
getStartTimeMs() - Method in class alluxio.thrift.MasterInfo
 
getStartTimeMs() - Method in class alluxio.thrift.WorkerInfo
 
getStartTimeMs() - Method in class alluxio.wire.AlluxioMasterInfo
 
getStartTimeMs() - Method in class alluxio.wire.AlluxioProxyInfo
 
getStartTimeMs() - Method in class alluxio.wire.AlluxioWorkerInfo
 
getStartTimeMs() - Method in class alluxio.wire.MasterInfo
 
getStartTimeMs() - Method in class alluxio.wire.WorkerInfo
 
getStartTimeMs() - Method in class alluxio.worker.AlluxioWorkerProcess
 
getStartTimeMs() - Method in class alluxio.worker.AlluxioWorkerRestServiceHandler
Deprecated.
since version 1.4 and will be removed in version 2.0
getStartTimeMs() - Method in interface alluxio.worker.WorkerProcess
 
getStartupConsistencyCheck() - Method in class alluxio.master.file.DefaultFileSystemMaster
 
getStartupConsistencyCheck() - Method in interface alluxio.master.file.FileSystemMaster
 
getStartupConsistencyCheck() - Method in class alluxio.wire.AlluxioMasterInfo
 
getState() - Method in class alluxio.master.AbstractPrimarySelector
 
getState() - Method in interface alluxio.master.PrimarySelector
 
getState() - Method in class alluxio.thrift.WorkerInfo
 
getState() - Method in class alluxio.web.WebInterfaceWorkersServlet.NodeInfo
 
getState() - Method in class alluxio.wire.WorkerInfo
 
getStatus(AlluxioURI) - Method in class alluxio.client.file.BaseFileSystem
 
getStatus(AlluxioURI, GetStatusOptions) - Method in class alluxio.client.file.BaseFileSystem
 
getStatus(AlluxioURI) - Method in interface alluxio.client.file.FileSystem
Convenience method for FileSystem.getStatus(AlluxioURI, GetStatusOptions) with default options.
getStatus(AlluxioURI, GetStatusOptions) - Method in interface alluxio.client.file.FileSystem
Gets the URIStatus object that represents the metadata of an Alluxio path.
getStatus(AlluxioURI, GetStatusOptions) - Method in interface alluxio.client.file.FileSystemMasterClient
 
getStatus() - Method in class alluxio.client.file.options.InStreamOptions
 
getStatus(AlluxioURI, GetStatusOptions) - Method in class alluxio.client.file.RetryHandlingFileSystemMasterClient
 
getStatus() - Method in exception alluxio.exception.status.AlluxioStatusException
 
getStatus(String) - Method in class alluxio.master.file.FileSystemMasterClientRestServiceHandler
Deprecated.
 
getStatus(String, GetStatusTOptions) - Method in class alluxio.master.file.FileSystemMasterClientServiceHandler
 
getStatus() - Method in class alluxio.master.file.StartupConsistencyCheck
 
getStatus() - Method in class alluxio.proto.dataserver.Protocol.Response.Builder
optional .alluxio.proto.status.PStatus status = 1;
getStatus() - Method in class alluxio.proto.dataserver.Protocol.Response
optional .alluxio.proto.status.PStatus status = 1;
getStatus() - Method in interface alluxio.proto.dataserver.Protocol.ResponseOrBuilder
optional .alluxio.proto.status.PStatus status = 1;
getStatus(String, GetStatusOptions) - Method in class alluxio.proxy.PathsRestServiceHandler
 
getStatus() - Method in class alluxio.proxy.s3.S3ErrorCode
 
getStatus() - Method in class alluxio.RestUtils.ErrorResponse
 
getStatus() - Method in exception alluxio.thrift.AlluxioTException
 
getStatus() - Method in class alluxio.thrift.ConfigCheckReport
 
getStatus(String, GetStatusTOptions, AsyncMethodCallback) - Method in class alluxio.thrift.FileSystemMasterClientService.AsyncClient
 
getStatus(String, GetStatusTOptions, AsyncMethodCallback) - Method in interface alluxio.thrift.FileSystemMasterClientService.AsyncIface
 
getStatus() - Constructor for class alluxio.thrift.FileSystemMasterClientService.AsyncProcessor.getStatus
 
getStatus(String, GetStatusTOptions) - Method in class alluxio.thrift.FileSystemMasterClientService.Client
 
getStatus(String, GetStatusTOptions) - Method in interface alluxio.thrift.FileSystemMasterClientService.Iface
Returns the status of the file or directory.
getStatus() - Constructor for class alluxio.thrift.FileSystemMasterClientService.Processor.getStatus
 
getStatus(String) - Method in class alluxio.underfs.hdfs.HdfsUnderFileSystem
 
getStatus(String) - Method in class alluxio.underfs.local.LocalUnderFileSystem
 
getStatus(String) - Method in class alluxio.underfs.ObjectUnderFileSystem
 
getStatus(String) - Method in interface alluxio.underfs.UnderFileSystem
Gets the file or directory status.
getStatus(String) - Method in class alluxio.underfs.UnderFileSystemWithLogging
 
getStatus() - Method in class alluxio.wire.StartupConsistencyCheck
 
getStatus_args() - Constructor for class alluxio.thrift.FileSystemMasterClientService.getStatus_args
 
getStatus_args(String, GetStatusTOptions) - Constructor for class alluxio.thrift.FileSystemMasterClientService.getStatus_args
 
getStatus_args(FileSystemMasterClientService.getStatus_args) - Constructor for class alluxio.thrift.FileSystemMasterClientService.getStatus_args
Performs a deep copy on other.
getStatus_call(String, GetStatusTOptions, AsyncMethodCallback, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class alluxio.thrift.FileSystemMasterClientService.AsyncClient.getStatus_call
 
getStatus_result() - Constructor for class alluxio.thrift.FileSystemMasterClientService.getStatus_result
 
getStatus_result(GetStatusTResponse, AlluxioTException) - Constructor for class alluxio.thrift.FileSystemMasterClientService.getStatus_result
 
getStatus_result(FileSystemMasterClientService.getStatus_result) - Constructor for class alluxio.thrift.FileSystemMasterClientService.getStatus_result
Performs a deep copy on other.
GetStatusOptions - Class in alluxio.client.file.options
Method options for getting the status of a path.
GetStatusOptions - Class in alluxio.master.file.options
Method options for getStatus.
GetStatusOptions(GetStatusTOptions) - Constructor for class alluxio.master.file.options.GetStatusOptions
Create an instance of GetStatusOptions from a GetStatusTOptions.
GetStatusTOptions - Class in alluxio.thrift
 
GetStatusTOptions() - Constructor for class alluxio.thrift.GetStatusTOptions
 
GetStatusTOptions(GetStatusTOptions) - Constructor for class alluxio.thrift.GetStatusTOptions
Performs a deep copy on other.
GetStatusTOptions._Fields - Enum in alluxio.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
GetStatusTResponse - Class in alluxio.thrift
 
GetStatusTResponse() - Constructor for class alluxio.thrift.GetStatusTResponse
 
GetStatusTResponse(FileInfo) - Constructor for class alluxio.thrift.GetStatusTResponse
 
GetStatusTResponse(GetStatusTResponse) - Constructor for class alluxio.thrift.GetStatusTResponse
Performs a deep copy on other.
GetStatusTResponse._Fields - Enum in alluxio.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
getStorageClass() - Method in class alluxio.proxy.s3.ListBucketResult.Content
 
getStorageClass() - Method in class alluxio.proxy.s3.ListPartsResult
 
getStorageDirs() - Method in class alluxio.worker.block.meta.StorageTier
 
getStorageTierAlias() - Method in class alluxio.web.WebInterfaceGeneralServlet.StorageTierInfo
 
getStorageTierAssoc() - Method in class alluxio.master.block.meta.MasterWorkerInfo
 
getStorageTierAssoc() - Method in class alluxio.worker.block.BlockMetadataManager
 
getStorageTierAssoc() - Method in interface alluxio.worker.block.BlockStoreMeta
 
getStorageTierAssoc() - Method in class alluxio.worker.block.DefaultBlockStoreMeta
 
getStorageTiers() - Method in class alluxio.thrift.BlockMasterWorkerService.registerWorker_args
the list of storage tiers
getStorageTiersIterator() - Method in class alluxio.thrift.BlockMasterWorkerService.registerWorker_args
 
getStorageTiersSize() - Method in class alluxio.thrift.BlockMasterWorkerService.registerWorker_args
 
getStoreId() - Method in class alluxio.proto.journal.KeyValue.CompletePartitionEntry.Builder
optional int64 store_id = 1;
getStoreId() - Method in class alluxio.proto.journal.KeyValue.CompletePartitionEntry
optional int64 store_id = 1;
getStoreId() - Method in interface alluxio.proto.journal.KeyValue.CompletePartitionEntryOrBuilder
optional int64 store_id = 1;
getStoreId() - Method in class alluxio.proto.journal.KeyValue.CompleteStoreEntry.Builder
optional int64 store_id = 1;
getStoreId() - Method in class alluxio.proto.journal.KeyValue.CompleteStoreEntry
optional int64 store_id = 1;
getStoreId() - Method in interface alluxio.proto.journal.KeyValue.CompleteStoreEntryOrBuilder
optional int64 store_id = 1;
getStoreId() - Method in class alluxio.proto.journal.KeyValue.CreateStoreEntry.Builder
optional int64 store_id = 1;
getStoreId() - Method in class alluxio.proto.journal.KeyValue.CreateStoreEntry
optional int64 store_id = 1;
getStoreId() - Method in interface alluxio.proto.journal.KeyValue.CreateStoreEntryOrBuilder
optional int64 store_id = 1;
getStoreId() - Method in class alluxio.proto.journal.KeyValue.DeleteStoreEntry.Builder
optional int64 store_id = 1;
getStoreId() - Method in class alluxio.proto.journal.KeyValue.DeleteStoreEntry
optional int64 store_id = 1;
getStoreId() - Method in interface alluxio.proto.journal.KeyValue.DeleteStoreEntryOrBuilder
optional int64 store_id = 1;
getStoreMeta() - Method in interface alluxio.worker.block.BlockWorker
Gets the metadata for the entire block store.
getStoreMeta() - Method in class alluxio.worker.block.DefaultBlockWorker
 
getStoreMetaFull() - Method in interface alluxio.worker.block.BlockWorker
Similar as BlockWorker.getStoreMeta() except that this also contains full blockId list.
getStoreMetaFull() - Method in class alluxio.worker.block.DefaultBlockWorker
 
getStructDesc() - Method in class alluxio.thrift.FileSystemCommandOptions
 
getSubject() - Method in class alluxio.master.MasterClientConfig
 
getSuccess() - Method in class alluxio.thrift.AlluxioService.getServiceVersion_result
 
getSuccess() - Method in class alluxio.thrift.BlockMasterClientService.getBlockInfo_result
 
getSuccess() - Method in class alluxio.thrift.BlockMasterClientService.getBlockMasterInfo_result
 
getSuccess() - Method in class alluxio.thrift.BlockMasterClientService.getCapacityBytes_result
 
getSuccess() - Method in class alluxio.thrift.BlockMasterClientService.getUsedBytes_result
 
getSuccess() - Method in class alluxio.thrift.BlockMasterClientService.getWorkerInfoList_result
 
getSuccess() - Method in class alluxio.thrift.BlockMasterClientService.getWorkerReport_result
 
getSuccess() - Method in class alluxio.thrift.BlockMasterWorkerService.blockHeartbeat_result
 
getSuccess() - Method in class alluxio.thrift.BlockMasterWorkerService.commitBlock_result
 
getSuccess() - Method in class alluxio.thrift.BlockMasterWorkerService.getWorkerId_result
 
getSuccess() - Method in class alluxio.thrift.BlockMasterWorkerService.registerWorker_result
 
getSuccess() - Method in class alluxio.thrift.BlockWorkerClientService.accessBlock_result
 
getSuccess() - Method in class alluxio.thrift.BlockWorkerClientService.cacheBlock_result
 
getSuccess() - Method in class alluxio.thrift.BlockWorkerClientService.cancelBlock_result
 
getSuccess() - Method in class alluxio.thrift.BlockWorkerClientService.lockBlock_result
 
getSuccess() - Method in class alluxio.thrift.BlockWorkerClientService.promoteBlock_result
 
getSuccess() - Method in class alluxio.thrift.BlockWorkerClientService.removeBlock_result
 
getSuccess() - Method in class alluxio.thrift.BlockWorkerClientService.requestBlockLocation_result
 
getSuccess() - Method in class alluxio.thrift.BlockWorkerClientService.requestSpace_result
 
getSuccess() - Method in class alluxio.thrift.BlockWorkerClientService.sessionBlockHeartbeat_result
 
getSuccess() - Method in class alluxio.thrift.BlockWorkerClientService.unlockBlock_result
 
getSuccess() - Method in class alluxio.thrift.FileSystemMasterClientService.checkConsistency_result
 
getSuccess() - Method in class alluxio.thrift.FileSystemMasterClientService.completeFile_result
 
getSuccess() - Method in class alluxio.thrift.FileSystemMasterClientService.createDirectory_result
 
getSuccess() - Method in class alluxio.thrift.FileSystemMasterClientService.createFile_result
 
getSuccess() - Method in class alluxio.thrift.FileSystemMasterClientService.free_result
 
getSuccess() - Method in class alluxio.thrift.FileSystemMasterClientService.getFilePath_result
 
getSuccess() - Method in class alluxio.thrift.FileSystemMasterClientService.getMountTable_result
 
getSuccess() - Method in class alluxio.thrift.FileSystemMasterClientService.getNewBlockIdForFile_result
 
getSuccess() - Method in class alluxio.thrift.FileSystemMasterClientService.getStatus_result
 
getSuccess() - Method in class alluxio.thrift.FileSystemMasterClientService.listStatus_result
 
getSuccess() - Method in class alluxio.thrift.FileSystemMasterClientService.loadMetadata_result
 
getSuccess() - Method in class alluxio.thrift.FileSystemMasterClientService.mount_result
 
getSuccess() - Method in class alluxio.thrift.FileSystemMasterClientService.remove_result
 
getSuccess() - Method in class alluxio.thrift.FileSystemMasterClientService.rename_result
 
getSuccess() - Method in class alluxio.thrift.FileSystemMasterClientService.scheduleAsyncPersistence_result
 
getSuccess() - Method in class alluxio.thrift.FileSystemMasterClientService.setAttribute_result
 
getSuccess() - Method in class alluxio.thrift.FileSystemMasterClientService.unmount_result
 
getSuccess() - Method in class alluxio.thrift.FileSystemMasterClientService.updateUfsMode_result
 
getSuccess() - Method in class alluxio.thrift.FileSystemMasterWorkerService.fileSystemHeartbeat_result
 
getSuccess() - Method in class alluxio.thrift.FileSystemMasterWorkerService.getFileInfo_result
 
getSuccess() - Method in class alluxio.thrift.FileSystemMasterWorkerService.getPinnedFileIds_result
 
getSuccess() - Method in class alluxio.thrift.FileSystemMasterWorkerService.getUfsInfo_result
 
getSuccess() - Method in class alluxio.thrift.FileSystemWorkerClientService.cancelUfsFile_result
 
getSuccess() - Method in class alluxio.thrift.FileSystemWorkerClientService.closeUfsFile_result
 
getSuccess() - Method in class alluxio.thrift.FileSystemWorkerClientService.completeUfsFile_result
 
getSuccess() - Method in class alluxio.thrift.FileSystemWorkerClientService.createUfsFile_result
 
getSuccess() - Method in class alluxio.thrift.FileSystemWorkerClientService.openUfsFile_result
 
getSuccess() - Method in class alluxio.thrift.FileSystemWorkerClientService.sessionFileSystemHeartbeat_result
 
getSuccess() - Method in class alluxio.thrift.KeyValueMasterClientService.completePartition_result
 
getSuccess() - Method in class alluxio.thrift.KeyValueMasterClientService.completeStore_result
 
getSuccess() - Method in class alluxio.thrift.KeyValueMasterClientService.createStore_result
 
getSuccess() - Method in class alluxio.thrift.KeyValueMasterClientService.deleteStore_result
 
getSuccess() - Method in class alluxio.thrift.KeyValueMasterClientService.getPartitionInfo_result
 
getSuccess() - Method in class alluxio.thrift.KeyValueMasterClientService.mergeStore_result
 
getSuccess() - Method in class alluxio.thrift.KeyValueMasterClientService.renameStore_result
 
getSuccess() - Method in class alluxio.thrift.KeyValueWorkerClientService.get_result
 
getSuccess() - Method in class alluxio.thrift.KeyValueWorkerClientService.getNextKeys_result
 
getSuccess() - Method in class alluxio.thrift.KeyValueWorkerClientService.getSize_result
 
getSuccess() - Method in class alluxio.thrift.LineageMasterClientService.createLineage_result
 
getSuccess() - Method in class alluxio.thrift.LineageMasterClientService.deleteLineage_result
 
getSuccess() - Method in class alluxio.thrift.LineageMasterClientService.getLineageInfoList_result
 
getSuccess() - Method in class alluxio.thrift.LineageMasterClientService.reinitializeFile_result
 
getSuccess() - Method in class alluxio.thrift.LineageMasterClientService.reportLostFile_result
 
getSuccess() - Method in class alluxio.thrift.MetaMasterClientService.backup_result
 
getSuccess() - Method in class alluxio.thrift.MetaMasterClientService.getConfigReport_result
 
getSuccess() - Method in class alluxio.thrift.MetaMasterClientService.getConfiguration_result
 
getSuccess() - Method in class alluxio.thrift.MetaMasterClientService.getMasterInfo_result
 
getSuccess() - Method in class alluxio.thrift.MetaMasterClientService.getMetrics_result
 
getSuccess() - Method in class alluxio.thrift.MetaMasterMasterService.getMasterId_result
 
getSuccess() - Method in class alluxio.thrift.MetaMasterMasterService.masterHeartbeat_result
 
getSuccess() - Method in class alluxio.thrift.MetaMasterMasterService.registerMaster_result
 
getSuccess() - Method in class alluxio.thrift.MetricsMasterClientService.metricsHeartbeat_result
 
getSyncIntervalMs() - Method in class alluxio.thrift.FileSystemMasterCommonTOptions
 
getSyncIntervalMs() - Method in class alluxio.wire.CommonOptions
 
getTag(Fingerprint.Tag) - Method in class alluxio.underfs.Fingerprint
 
getTags() - Method in class alluxio.metrics.Metric
 
getTags() - Method in class alluxio.thrift.Metric
 
getTagsSize() - Method in class alluxio.thrift.Metric
 
getTargetDirectory() - Method in class alluxio.thrift.BackupTOptions
 
getTargetDirectory() - Method in class alluxio.wire.BackupOptions
 
getTaskOutputURI(TaskAttemptContext) - Static method in class alluxio.hadoop.mapreduce.KeyValueOutputFormat
 
getTempBlockMeta(long) - Method in class alluxio.worker.block.BlockMetadataManager
Gets the metadata of a temp block.
getTempBlockMeta(long, long) - Method in interface alluxio.worker.block.BlockStore
Gets the temp metadata of a specific block from local storage.
getTempBlockMeta(long) - Method in class alluxio.worker.block.meta.StorageDir
Gets the BlockMeta from this storage dir by its block id.
getTempBlockMeta(long, long) - Method in class alluxio.worker.block.TieredBlockStore
 
getTempBlockMetaOrNull(long) - Method in class alluxio.worker.block.BlockMetadataManager
Gets the metadata of a temp block.
getTempBlockWriterRemote(long, long) - Method in interface alluxio.worker.block.BlockWorker
Opens a BlockWriter for an existing temporary block.
getTempBlockWriterRemote(long, long) - Method in class alluxio.worker.block.DefaultBlockWorker
 
getTemporaryCheckpoints() - Method in class alluxio.master.journal.ufs.UfsJournalSnapshot
 
getTempUfsFileId() - Method in class alluxio.thrift.FileSystemWorkerClientService.cancelUfsFile_args
the worker specific file id of the ufs file
getTempUfsFileId() - Method in class alluxio.thrift.FileSystemWorkerClientService.closeUfsFile_args
the worker specific file id of the ufs file
getTempUfsFileId() - Method in class alluxio.thrift.FileSystemWorkerClientService.completeUfsFile_args
the worker specific file id of the ufs file
getTempUrlPrefix(TempUrlHashPrefixSource) - Method in class alluxio.underfs.swift.KeystoneV3Access
 
getThis() - Method in class alluxio.master.file.meta.Inode
 
getThis() - Method in class alluxio.master.file.meta.InodeDirectory
 
getThis() - Method in class alluxio.master.file.meta.InodeFile
 
getThis() - Method in class alluxio.master.file.options.CreateDirectoryOptions
 
getThis() - Method in class alluxio.master.file.options.CreateFileOptions
 
getThis() - Method in class alluxio.master.file.options.CreatePathOptions
 
getThreadName() - Method in class alluxio.heartbeat.ScheduledTimer
 
getThreadNames() - Static method in class alluxio.heartbeat.HeartbeatScheduler
 
getThriftFieldId() - Method in enum alluxio.thrift.AccessBlockTOptions._Fields
 
getThriftFieldId() - Method in enum alluxio.thrift.AccessBlockTResponse._Fields
 
getThriftFieldId() - Method in enum alluxio.thrift.AlluxioService.getServiceVersion_args._Fields
 
getThriftFieldId() - Method in enum alluxio.thrift.AlluxioService.getServiceVersion_result._Fields
 
getThriftFieldId() - Method in enum alluxio.thrift.AlluxioTException._Fields
 
getThriftFieldId() - Method in enum alluxio.thrift.BackupTOptions._Fields
 
getThriftFieldId() - Method in enum alluxio.thrift.BackupTResponse._Fields
 
getThriftFieldId() - Method in enum alluxio.thrift.BlockHeartbeatTOptions._Fields
 
getThriftFieldId() - Method in enum alluxio.thrift.BlockHeartbeatTResponse._Fields
 
getThriftFieldId() - Method in enum alluxio.thrift.BlockInfo._Fields
 
getThriftFieldId() - Method in enum alluxio.thrift.BlockLocation._Fields
 
getThriftFieldId() - Method in enum alluxio.thrift.BlockMasterClientService.getBlockInfo_args._Fields
 
getThriftFieldId() - Method in enum alluxio.thrift.BlockMasterClientService.getBlockInfo_result._Fields
 
getThriftFieldId() - Method in enum alluxio.thrift.BlockMasterClientService.getBlockMasterInfo_args._Fields
 
getThriftFieldId() - Method in enum alluxio.thrift.BlockMasterClientService.getBlockMasterInfo_result._Fields
 
getThriftFieldId() - Method in enum alluxio.thrift.BlockMasterClientService.getCapacityBytes_args._Fields
 
getThriftFieldId() - Method in enum alluxio.thrift.BlockMasterClientService.getCapacityBytes_result._Fields
 
getThriftFieldId() - Method in enum alluxio.thrift.BlockMasterClientService.getUsedBytes_args._Fields
 
getThriftFieldId() - Method in enum alluxio.thrift.BlockMasterClientService.getUsedBytes_result._Fields
 
getThriftFieldId() - Method in enum alluxio.thrift.BlockMasterClientService.getWorkerInfoList_args._Fields
 
getThriftFieldId() - Method in enum alluxio.thrift.BlockMasterClientService.getWorkerInfoList_result._Fields
 
getThriftFieldId() - Method in enum alluxio.thrift.BlockMasterClientService.getWorkerReport_args._Fields
 
getThriftFieldId() - Method in enum alluxio.thrift.BlockMasterClientService.getWorkerReport_result._Fields
 
getThriftFieldId() - Method in enum alluxio.thrift.BlockMasterInfo._Fields
 
getThriftFieldId() - Method in enum alluxio.thrift.BlockMasterWorkerService.blockHeartbeat_args._Fields
 
getThriftFieldId() - Method in enum alluxio.thrift.BlockMasterWorkerService.blockHeartbeat_result._Fields
 
getThriftFieldId() - Method in enum alluxio.thrift.BlockMasterWorkerService.commitBlock_args._Fields
 
getThriftFieldId() - Method in enum alluxio.thrift.BlockMasterWorkerService.commitBlock_result._Fields
 
getThriftFieldId() - Method in enum alluxio.thrift.BlockMasterWorkerService.getWorkerId_args._Fields
 
getThriftFieldId() - Method in enum alluxio.thrift.BlockMasterWorkerService.getWorkerId_result._Fields
 
getThriftFieldId() - Method in enum alluxio.thrift.BlockMasterWorkerService.registerWorker_args._Fields
 
getThriftFieldId() - Method in enum alluxio.thrift.BlockMasterWorkerService.registerWorker_result._Fields
 
getThriftFieldId() - Method in enum alluxio.thrift.BlockWorkerClientService.accessBlock_args._Fields
 
getThriftFieldId() - Method in enum alluxio.thrift.BlockWorkerClientService.accessBlock_result._Fields
 
getThriftFieldId() - Method in enum alluxio.thrift.BlockWorkerClientService.cacheBlock_args._Fields
 
getThriftFieldId() - Method in enum alluxio.thrift.BlockWorkerClientService.cacheBlock_result._Fields
 
getThriftFieldId() - Method in enum alluxio.thrift.BlockWorkerClientService.cancelBlock_args._Fields
 
getThriftFieldId() - Method in enum alluxio.thrift.BlockWorkerClientService.cancelBlock_result._Fields
 
getThriftFieldId() - Method in enum alluxio.thrift.BlockWorkerClientService.lockBlock_args._Fields
 
getThriftFieldId() - Method in enum alluxio.thrift.BlockWorkerClientService.lockBlock_result._Fields
 
getThriftFieldId() - Method in enum alluxio.thrift.BlockWorkerClientService.promoteBlock_args._Fields
 
getThriftFieldId() - Method in enum alluxio.thrift.BlockWorkerClientService.promoteBlock_result._Fields
 
getThriftFieldId() - Method in enum alluxio.thrift.BlockWorkerClientService.removeBlock_args._Fields
 
getThriftFieldId() - Method in enum alluxio.thrift.BlockWorkerClientService.removeBlock_result._Fields
 
getThriftFieldId() - Method in enum alluxio.thrift.BlockWorkerClientService.requestBlockLocation_args._Fields
 
getThriftFieldId() - Method in enum alluxio.thrift.BlockWorkerClientService.requestBlockLocation_result._Fields
 
getThriftFieldId() - Method in enum alluxio.thrift.BlockWorkerClientService.requestSpace_args._Fields
 
getThriftFieldId() - Method in enum alluxio.thrift.BlockWorkerClientService.requestSpace_result._Fields
 
getThriftFieldId() - Method in enum alluxio.thrift.BlockWorkerClientService.sessionBlockHeartbeat_args._Fields
 
getThriftFieldId() - Method in enum alluxio.thrift.BlockWorkerClientService.sessionBlockHeartbeat_result._Fields
 
getThriftFieldId() - Method in enum alluxio.thrift.BlockWorkerClientService.unlockBlock_args._Fields
 
getThriftFieldId() - Method in enum alluxio.thrift.BlockWorkerClientService.unlockBlock_result._Fields
 
getThriftFieldId() - Method in enum alluxio.thrift.CacheBlockTOptions._Fields
 
getThriftFieldId() - Method in enum alluxio.thrift.CacheBlockTResponse._Fields
 
getThriftFieldId() - Method in enum alluxio.thrift.CancelBlockTOptions._Fields
 
getThriftFieldId() - Method in enum alluxio.thrift.CancelBlockTResponse._Fields
 
getThriftFieldId() - Method in enum alluxio.thrift.CancelUfsFileTOptions._Fields
 
getThriftFieldId() - Method in enum alluxio.thrift.CancelUfsFileTResponse._Fields
 
getThriftFieldId() - Method in enum alluxio.thrift.CheckConsistencyTOptions._Fields
 
getThriftFieldId() - Method in enum alluxio.thrift.CheckConsistencyTResponse._Fields
 
getThriftFieldId() - Method in enum alluxio.thrift.CloseUfsFileTOptions._Fields
 
getThriftFieldId() - Method in enum alluxio.thrift.CloseUfsFileTResponse._Fields
 
getThriftFieldId() - Method in enum alluxio.thrift.Command._Fields
 
getThriftFieldId() - Method in enum alluxio.thrift.CommandLineJobInfo._Fields
 
getThriftFieldId() - Method in enum alluxio.thrift.CommitBlockTOptions._Fields
 
getThriftFieldId() - Method in enum alluxio.thrift.CommitBlockTResponse._Fields
 
getThriftFieldId() - Method in enum alluxio.thrift.CompleteFileTOptions._Fields
 
getThriftFieldId() - Method in enum alluxio.thrift.CompleteFileTResponse._Fields
 
getThriftFieldId() - Method in enum alluxio.thrift.CompletePartitionTOptions._Fields
 
getThriftFieldId() - Method in enum alluxio.thrift.CompletePartitionTResponse._Fields
 
getThriftFieldId() - Method in enum alluxio.thrift.CompleteStoreTOptions._Fields
 
getThriftFieldId() - Method in enum alluxio.thrift.CompleteStoreTResponse._Fields
 
getThriftFieldId() - Method in enum alluxio.thrift.CompleteUfsFileTOptions._Fields
 
getThriftFieldId() - Method in enum alluxio.thrift.CompleteUfsFileTReponse._Fields
 
getThriftFieldId() - Method in enum alluxio.thrift.ConfigCheckReport._Fields
 
getThriftFieldId() - Method in enum alluxio.thrift.ConfigProperty._Fields
 
getThriftFieldId() - Method in enum alluxio.thrift.CreateDirectoryTOptions._Fields
 
getThriftFieldId() - Method in enum alluxio.thrift.CreateDirectoryTResponse._Fields
 
getThriftFieldId() - Method in enum alluxio.thrift.CreateFileTOptions._Fields
 
getThriftFieldId() - Method in enum alluxio.thrift.CreateFileTResponse._Fields
 
getThriftFieldId() - Method in enum alluxio.thrift.CreateLineageTOptions._Fields
 
getThriftFieldId() - Method in enum alluxio.thrift.CreateLineageTResponse._Fields
 
getThriftFieldId() - Method in enum alluxio.thrift.CreateStoreTOptions._Fields
 
getThriftFieldId() - Method in enum alluxio.thrift.CreateStoreTResponse._Fields
 
getThriftFieldId() - Method in enum alluxio.thrift.CreateUfsFileTOptions._Fields
 
getThriftFieldId() - Method in enum alluxio.thrift.CreateUfsFileTResponse._Fields
 
getThriftFieldId() - Method in enum alluxio.thrift.DeleteLineageTOptions._Fields
 
getThriftFieldId() - Method in enum alluxio.thrift.DeleteLineageTResponse._Fields
 
getThriftFieldId() - Method in enum alluxio.thrift.DeleteStoreTOptions._Fields
 
getThriftFieldId() - Method in enum alluxio.thrift.DeleteStoreTResponse._Fields
 
getThriftFieldId() - Method in enum alluxio.thrift.DeleteTOptions._Fields
 
getThriftFieldId() - Method in enum alluxio.thrift.DeleteTResponse._Fields
 
getThriftFieldId() - Method in enum alluxio.thrift.DependencyInfo._Fields
 
getThriftFieldId() - Method in enum alluxio.thrift.FileBlockInfo._Fields
 
getThriftFieldId() - Method in enum alluxio.thrift.FileInfo._Fields
 
getThriftFieldId() - Method in enum alluxio.thrift.FileSystemCommand._Fields
 
getThriftFieldId() - Method in enum alluxio.thrift.FileSystemCommandOptions._Fields
 
getThriftFieldId() - Method in enum alluxio.thrift.FileSystemHeartbeatTOptions._Fields
 
getThriftFieldId() - Method in enum alluxio.thrift.FileSystemHeartbeatTResponse._Fields
 
getThriftFieldId() - Method in enum alluxio.thrift.FileSystemMasterClientService.checkConsistency_args._Fields
 
getThriftFieldId() - Method in enum alluxio.thrift.FileSystemMasterClientService.checkConsistency_result._Fields
 
getThriftFieldId() - Method in enum alluxio.thrift.FileSystemMasterClientService.completeFile_args._Fields
 
getThriftFieldId() - Method in enum alluxio.thrift.FileSystemMasterClientService.completeFile_result._Fields
 
getThriftFieldId() - Method in enum alluxio.thrift.FileSystemMasterClientService.createDirectory_args._Fields
 
getThriftFieldId() - Method in enum alluxio.thrift.FileSystemMasterClientService.createDirectory_result._Fields
 
getThriftFieldId() - Method in enum alluxio.thrift.FileSystemMasterClientService.createFile_args._Fields
 
getThriftFieldId() - Method in enum alluxio.thrift.FileSystemMasterClientService.createFile_result._Fields
 
getThriftFieldId() - Method in enum alluxio.thrift.FileSystemMasterClientService.free_args._Fields
 
getThriftFieldId() - Method in enum alluxio.thrift.FileSystemMasterClientService.free_result._Fields
 
getThriftFieldId() - Method in enum alluxio.thrift.FileSystemMasterClientService.getFilePath_args._Fields
 
getThriftFieldId() - Method in enum alluxio.thrift.FileSystemMasterClientService.getFilePath_result._Fields
 
getThriftFieldId() - Method in enum alluxio.thrift.FileSystemMasterClientService.getMountTable_args._Fields
 
getThriftFieldId() - Method in enum alluxio.thrift.FileSystemMasterClientService.getMountTable_result._Fields
 
getThriftFieldId() - Method in enum alluxio.thrift.FileSystemMasterClientService.getNewBlockIdForFile_args._Fields
 
getThriftFieldId() - Method in enum alluxio.thrift.FileSystemMasterClientService.getNewBlockIdForFile_result._Fields
 
getThriftFieldId() - Method in enum alluxio.thrift.FileSystemMasterClientService.getStatus_args._Fields
 
getThriftFieldId() - Method in enum alluxio.thrift.FileSystemMasterClientService.getStatus_result._Fields
 
getThriftFieldId() - Method in enum alluxio.thrift.FileSystemMasterClientService.listStatus_args._Fields
 
getThriftFieldId() - Method in enum alluxio.thrift.FileSystemMasterClientService.listStatus_result._Fields
 
getThriftFieldId() - Method in enum alluxio.thrift.FileSystemMasterClientService.loadMetadata_args._Fields
 
getThriftFieldId() - Method in enum alluxio.thrift.FileSystemMasterClientService.loadMetadata_result._Fields
 
getThriftFieldId() - Method in enum alluxio.thrift.FileSystemMasterClientService.mount_args._Fields
 
getThriftFieldId() - Method in enum alluxio.thrift.FileSystemMasterClientService.mount_result._Fields
 
getThriftFieldId() - Method in enum alluxio.thrift.FileSystemMasterClientService.remove_args._Fields
 
getThriftFieldId() - Method in enum alluxio.thrift.FileSystemMasterClientService.remove_result._Fields
 
getThriftFieldId() - Method in enum alluxio.thrift.FileSystemMasterClientService.rename_args._Fields
 
getThriftFieldId() - Method in enum alluxio.thrift.FileSystemMasterClientService.rename_result._Fields
 
getThriftFieldId() - Method in enum alluxio.thrift.FileSystemMasterClientService.scheduleAsyncPersistence_args._Fields
 
getThriftFieldId() - Method in enum alluxio.thrift.FileSystemMasterClientService.scheduleAsyncPersistence_result._Fields
 
getThriftFieldId() - Method in enum alluxio.thrift.FileSystemMasterClientService.setAttribute_args._Fields
 
getThriftFieldId() - Method in enum alluxio.thrift.FileSystemMasterClientService.setAttribute_result._Fields
 
getThriftFieldId() - Method in enum alluxio.thrift.FileSystemMasterClientService.unmount_args._Fields
 
getThriftFieldId() - Method in enum alluxio.thrift.FileSystemMasterClientService.unmount_result._Fields
 
getThriftFieldId() - Method in enum alluxio.thrift.FileSystemMasterClientService.updateUfsMode_args._Fields
 
getThriftFieldId() - Method in enum alluxio.thrift.FileSystemMasterClientService.updateUfsMode_result._Fields
 
getThriftFieldId() - Method in enum alluxio.thrift.FileSystemMasterCommonTOptions._Fields
 
getThriftFieldId() - Method in enum alluxio.thrift.FileSystemMasterWorkerService.fileSystemHeartbeat_args._Fields
 
getThriftFieldId() - Method in enum alluxio.thrift.FileSystemMasterWorkerService.fileSystemHeartbeat_result._Fields
 
getThriftFieldId() - Method in enum alluxio.thrift.FileSystemMasterWorkerService.getFileInfo_args._Fields
 
getThriftFieldId() - Method in enum alluxio.thrift.FileSystemMasterWorkerService.getFileInfo_result._Fields
 
getThriftFieldId() - Method in enum alluxio.thrift.FileSystemMasterWorkerService.getPinnedFileIds_args._Fields
 
getThriftFieldId() - Method in enum alluxio.thrift.FileSystemMasterWorkerService.getPinnedFileIds_result._Fields
 
getThriftFieldId() - Method in enum alluxio.thrift.FileSystemMasterWorkerService.getUfsInfo_args._Fields
 
getThriftFieldId() - Method in enum alluxio.thrift.FileSystemMasterWorkerService.getUfsInfo_result._Fields
 
getThriftFieldId() - Method in enum alluxio.thrift.FileSystemWorkerClientService.cancelUfsFile_args._Fields
 
getThriftFieldId() - Method in enum alluxio.thrift.FileSystemWorkerClientService.cancelUfsFile_result._Fields
 
getThriftFieldId() - Method in enum alluxio.thrift.FileSystemWorkerClientService.closeUfsFile_args._Fields
 
getThriftFieldId() - Method in enum alluxio.thrift.FileSystemWorkerClientService.closeUfsFile_result._Fields
 
getThriftFieldId() - Method in enum alluxio.thrift.FileSystemWorkerClientService.completeUfsFile_args._Fields
 
getThriftFieldId() - Method in enum alluxio.thrift.FileSystemWorkerClientService.completeUfsFile_result._Fields
 
getThriftFieldId() - Method in enum alluxio.thrift.FileSystemWorkerClientService.createUfsFile_args._Fields
 
getThriftFieldId() - Method in enum alluxio.thrift.FileSystemWorkerClientService.createUfsFile_result._Fields
 
getThriftFieldId() - Method in enum alluxio.thrift.FileSystemWorkerClientService.openUfsFile_args._Fields
 
getThriftFieldId() - Method in enum alluxio.thrift.FileSystemWorkerClientService.openUfsFile_result._Fields
 
getThriftFieldId() - Method in enum alluxio.thrift.FileSystemWorkerClientService.sessionFileSystemHeartbeat_args._Fields
 
getThriftFieldId() - Method in enum alluxio.thrift.FileSystemWorkerClientService.sessionFileSystemHeartbeat_result._Fields
 
getThriftFieldId() - Method in enum alluxio.thrift.FreeTOptions._Fields
 
getThriftFieldId() - Method in enum alluxio.thrift.FreeTResponse._Fields
 
getThriftFieldId() - Method in enum alluxio.thrift.GetBlockInfoTOptions._Fields
 
getThriftFieldId() - Method in enum alluxio.thrift.GetBlockInfoTResponse._Fields
 
getThriftFieldId() - Method in enum alluxio.thrift.GetBlockMasterInfoTOptions._Fields
 
getThriftFieldId() - Method in enum alluxio.thrift.GetBlockMasterInfoTResponse._Fields
 
getThriftFieldId() - Method in enum alluxio.thrift.GetCapacityBytesTOptions._Fields
 
getThriftFieldId() - Method in enum alluxio.thrift.GetCapacityBytesTResponse._Fields
 
getThriftFieldId() - Method in enum alluxio.thrift.GetConfigReportTOptions._Fields
 
getThriftFieldId() - Method in enum alluxio.thrift.GetConfigReportTResponse._Fields
 
getThriftFieldId() - Method in enum alluxio.thrift.GetConfigurationTOptions._Fields
 
getThriftFieldId() - Method in enum alluxio.thrift.GetConfigurationTResponse._Fields
 
getThriftFieldId() - Method in enum alluxio.thrift.GetFileInfoTOptions._Fields
 
getThriftFieldId() - Method in enum alluxio.thrift.GetFileInfoTResponse._Fields
 
getThriftFieldId() - Method in enum alluxio.thrift.GetFilePathTOptions._Fields
 
getThriftFieldId() - Method in enum alluxio.thrift.GetFilePathTResponse._Fields
 
getThriftFieldId() - Method in enum alluxio.thrift.GetLineageInfoListTOptions._Fields
 
getThriftFieldId() - Method in enum alluxio.thrift.GetLineageInfoListTResponse._Fields
 
getThriftFieldId() - Method in enum alluxio.thrift.GetMasterIdTOptions._Fields
 
getThriftFieldId() - Method in enum alluxio.thrift.GetMasterIdTResponse._Fields
 
getThriftFieldId() - Method in enum alluxio.thrift.GetMasterInfoTOptions._Fields
 
getThriftFieldId() - Method in enum alluxio.thrift.GetMasterInfoTResponse._Fields
 
getThriftFieldId() - Method in enum alluxio.thrift.GetMetricsTOptions._Fields
 
getThriftFieldId() - Method in enum alluxio.thrift.GetMetricsTResponse._Fields
 
getThriftFieldId() - Method in enum alluxio.thrift.GetMountTableTResponse._Fields
 
getThriftFieldId() - Method in enum alluxio.thrift.GetNewBlockIdForFileTOptions._Fields
 
getThriftFieldId() - Method in enum alluxio.thrift.GetNewBlockIdForFileTResponse._Fields
 
getThriftFieldId() - Method in enum alluxio.thrift.GetNextKeysTOptions._Fields
 
getThriftFieldId() - Method in enum alluxio.thrift.GetNextKeysTResponse._Fields
 
getThriftFieldId() - Method in enum alluxio.thrift.GetPartitionInfoTOptions._Fields
 
getThriftFieldId() - Method in enum alluxio.thrift.GetPartitionInfoTResponse._Fields
 
getThriftFieldId() - Method in enum alluxio.thrift.GetPinnedFileIdsTOptions._Fields
 
getThriftFieldId() - Method in enum alluxio.thrift.GetPinnedFileIdsTResponse._Fields
 
getThriftFieldId() - Method in enum alluxio.thrift.GetServiceVersionTOptions._Fields
 
getThriftFieldId() - Method in enum alluxio.thrift.GetServiceVersionTResponse._Fields
 
getThriftFieldId() - Method in enum alluxio.thrift.GetSizeTOptions._Fields
 
getThriftFieldId() - Method in enum alluxio.thrift.GetSizeTResponse._Fields
 
getThriftFieldId() - Method in enum alluxio.thrift.GetStatusTOptions._Fields
 
getThriftFieldId() - Method in enum alluxio.thrift.GetStatusTResponse._Fields
 
getThriftFieldId() - Method in enum alluxio.thrift.GetTOptions._Fields
 
getThriftFieldId() - Method in enum alluxio.thrift.GetTResponse._Fields
 
getThriftFieldId() - Method in enum alluxio.thrift.GetUfsInfoTOptions._Fields
 
getThriftFieldId() - Method in enum alluxio.thrift.GetUfsInfoTResponse._Fields
 
getThriftFieldId() - Method in enum alluxio.thrift.GetUsedBytesTOptions._Fields
 
getThriftFieldId() - Method in enum alluxio.thrift.GetUsedBytesTResponse._Fields
 
getThriftFieldId() - Method in enum alluxio.thrift.GetWorkerIdTOptions._Fields
 
getThriftFieldId() - Method in enum alluxio.thrift.GetWorkerIdTResponse._Fields
 
getThriftFieldId() - Method in enum alluxio.thrift.GetWorkerInfoListTOptions._Fields
 
getThriftFieldId() - Method in enum alluxio.thrift.GetWorkerInfoListTResponse._Fields
 
getThriftFieldId() - Method in enum alluxio.thrift.GetWorkerReportTOptions._Fields
 
getThriftFieldId() - Method in enum alluxio.thrift.InconsistentProperty._Fields
 
getThriftFieldId() - Method in enum alluxio.thrift.JobConfInfo._Fields
 
getThriftFieldId() - Method in enum alluxio.thrift.KeyValueMasterClientService.completePartition_args._Fields
 
getThriftFieldId() - Method in enum alluxio.thrift.KeyValueMasterClientService.completePartition_result._Fields
 
getThriftFieldId() - Method in enum alluxio.thrift.KeyValueMasterClientService.completeStore_args._Fields
 
getThriftFieldId() - Method in enum alluxio.thrift.KeyValueMasterClientService.completeStore_result._Fields
 
getThriftFieldId() - Method in enum alluxio.thrift.KeyValueMasterClientService.createStore_args._Fields
 
getThriftFieldId() - Method in enum alluxio.thrift.KeyValueMasterClientService.createStore_result._Fields
 
getThriftFieldId() - Method in enum alluxio.thrift.KeyValueMasterClientService.deleteStore_args._Fields
 
getThriftFieldId() - Method in enum alluxio.thrift.KeyValueMasterClientService.deleteStore_result._Fields
 
getThriftFieldId() - Method in enum alluxio.thrift.KeyValueMasterClientService.getPartitionInfo_args._Fields
 
getThriftFieldId() - Method in enum alluxio.thrift.KeyValueMasterClientService.getPartitionInfo_result._Fields
 
getThriftFieldId() - Method in enum alluxio.thrift.KeyValueMasterClientService.mergeStore_args._Fields
 
getThriftFieldId() - Method in enum alluxio.thrift.KeyValueMasterClientService.mergeStore_result._Fields
 
getThriftFieldId() - Method in enum alluxio.thrift.KeyValueMasterClientService.renameStore_args._Fields
 
getThriftFieldId() - Method in enum alluxio.thrift.KeyValueMasterClientService.renameStore_result._Fields
 
getThriftFieldId() - Method in enum alluxio.thrift.KeyValueWorkerClientService.get_args._Fields
 
getThriftFieldId() - Method in enum alluxio.thrift.KeyValueWorkerClientService.get_result._Fields
 
getThriftFieldId() - Method in enum alluxio.thrift.KeyValueWorkerClientService.getNextKeys_args._Fields
 
getThriftFieldId() - Method in enum alluxio.thrift.KeyValueWorkerClientService.getNextKeys_result._Fields
 
getThriftFieldId() - Method in enum alluxio.thrift.KeyValueWorkerClientService.getSize_args._Fields
 
getThriftFieldId() - Method in enum alluxio.thrift.KeyValueWorkerClientService.getSize_result._Fields
 
getThriftFieldId() - Method in enum alluxio.thrift.LineageInfo._Fields
 
getThriftFieldId() - Method in enum alluxio.thrift.LineageMasterClientService.createLineage_args._Fields
 
getThriftFieldId() - Method in enum alluxio.thrift.LineageMasterClientService.createLineage_result._Fields
 
getThriftFieldId() - Method in enum alluxio.thrift.LineageMasterClientService.deleteLineage_args._Fields
 
getThriftFieldId() - Method in enum alluxio.thrift.LineageMasterClientService.deleteLineage_result._Fields
 
getThriftFieldId() - Method in enum alluxio.thrift.LineageMasterClientService.getLineageInfoList_args._Fields
 
getThriftFieldId() - Method in enum alluxio.thrift.LineageMasterClientService.getLineageInfoList_result._Fields
 
getThriftFieldId() - Method in enum alluxio.thrift.LineageMasterClientService.reinitializeFile_args._Fields
 
getThriftFieldId() - Method in enum alluxio.thrift.LineageMasterClientService.reinitializeFile_result._Fields
 
getThriftFieldId() - Method in enum alluxio.thrift.LineageMasterClientService.reportLostFile_args._Fields
 
getThriftFieldId() - Method in enum alluxio.thrift.LineageMasterClientService.reportLostFile_result._Fields
 
getThriftFieldId() - Method in enum alluxio.thrift.ListStatusTOptions._Fields
 
getThriftFieldId() - Method in enum alluxio.thrift.ListStatusTResponse._Fields
 
getThriftFieldId() - Method in enum alluxio.thrift.LoadMetadataTOptions._Fields
 
getThriftFieldId() - Method in enum alluxio.thrift.LoadMetadataTResponse._Fields
 
getThriftFieldId() - Method in enum alluxio.thrift.LocalityTier._Fields
 
getThriftFieldId() - Method in enum alluxio.thrift.LockBlockTOptions._Fields
 
getThriftFieldId() - Method in enum alluxio.thrift.LockBlockTResponse._Fields
 
getThriftFieldId() - Method in enum alluxio.thrift.MasterHeartbeatTOptions._Fields
 
getThriftFieldId() - Method in enum alluxio.thrift.MasterHeartbeatTResponse._Fields
 
getThriftFieldId() - Method in enum alluxio.thrift.MasterInfo._Fields
 
getThriftFieldId() - Method in enum alluxio.thrift.MasterNetAddress._Fields
 
getThriftFieldId() - Method in enum alluxio.thrift.MergeStoreTOptions._Fields
 
getThriftFieldId() - Method in enum alluxio.thrift.MergeStoreTResponse._Fields
 
getThriftFieldId() - Method in enum alluxio.thrift.MetaMasterClientService.backup_args._Fields
 
getThriftFieldId() - Method in enum alluxio.thrift.MetaMasterClientService.backup_result._Fields
 
getThriftFieldId() - Method in enum alluxio.thrift.MetaMasterClientService.getConfigReport_args._Fields
 
getThriftFieldId() - Method in enum alluxio.thrift.MetaMasterClientService.getConfigReport_result._Fields
 
getThriftFieldId() - Method in enum alluxio.thrift.MetaMasterClientService.getConfiguration_args._Fields
 
getThriftFieldId() - Method in enum alluxio.thrift.MetaMasterClientService.getConfiguration_result._Fields
 
getThriftFieldId() - Method in enum alluxio.thrift.MetaMasterClientService.getMasterInfo_args._Fields
 
getThriftFieldId() - Method in enum alluxio.thrift.MetaMasterClientService.getMasterInfo_result._Fields
 
getThriftFieldId() - Method in enum alluxio.thrift.MetaMasterClientService.getMetrics_args._Fields
 
getThriftFieldId() - Method in enum alluxio.thrift.MetaMasterClientService.getMetrics_result._Fields
 
getThriftFieldId() - Method in enum alluxio.thrift.MetaMasterMasterService.getMasterId_args._Fields
 
getThriftFieldId() - Method in enum alluxio.thrift.MetaMasterMasterService.getMasterId_result._Fields
 
getThriftFieldId() - Method in enum alluxio.thrift.MetaMasterMasterService.masterHeartbeat_args._Fields
 
getThriftFieldId() - Method in enum alluxio.thrift.MetaMasterMasterService.masterHeartbeat_result._Fields
 
getThriftFieldId() - Method in enum alluxio.thrift.MetaMasterMasterService.registerMaster_args._Fields
 
getThriftFieldId() - Method in enum alluxio.thrift.MetaMasterMasterService.registerMaster_result._Fields
 
getThriftFieldId() - Method in enum alluxio.thrift.Metric._Fields
 
getThriftFieldId() - Method in enum alluxio.thrift.MetricsHeartbeatTOptions._Fields
 
getThriftFieldId() - Method in enum alluxio.thrift.MetricsHeartbeatTResponse._Fields
 
getThriftFieldId() - Method in enum alluxio.thrift.MetricsMasterClientService.metricsHeartbeat_args._Fields
 
getThriftFieldId() - Method in enum alluxio.thrift.MetricsMasterClientService.metricsHeartbeat_result._Fields
 
getThriftFieldId() - Method in enum alluxio.thrift.MetricValue._Fields
 
getThriftFieldId() - Method in enum alluxio.thrift.MountPointInfo._Fields
 
getThriftFieldId() - Method in enum alluxio.thrift.MountTOptions._Fields
 
getThriftFieldId() - Method in enum alluxio.thrift.MountTResponse._Fields
 
getThriftFieldId() - Method in enum alluxio.thrift.OpenUfsFileTOptions._Fields
 
getThriftFieldId() - Method in enum alluxio.thrift.OpenUfsFileTResponse._Fields
 
getThriftFieldId() - Method in enum alluxio.thrift.OptionalString._Fields
 
getThriftFieldId() - Method in enum alluxio.thrift.PartitionInfo._Fields
 
getThriftFieldId() - Method in enum alluxio.thrift.PersistCommandOptions._Fields
 
getThriftFieldId() - Method in enum alluxio.thrift.PersistFile._Fields
 
getThriftFieldId() - Method in enum alluxio.thrift.PromoteBlockTOptions._Fields
 
getThriftFieldId() - Method in enum alluxio.thrift.PromoteBlockTResponse._Fields
 
getThriftFieldId() - Method in enum alluxio.thrift.RegisterMasterTOptions._Fields
 
getThriftFieldId() - Method in enum alluxio.thrift.RegisterMasterTResponse._Fields
 
getThriftFieldId() - Method in enum alluxio.thrift.RegisterWorkerTOptions._Fields
 
getThriftFieldId() - Method in enum alluxio.thrift.RegisterWorkerTResponse._Fields
 
getThriftFieldId() - Method in enum alluxio.thrift.ReinitializeFileTOptions._Fields
 
getThriftFieldId() - Method in enum alluxio.thrift.ReinitializeFileTResponse._Fields
 
getThriftFieldId() - Method in enum alluxio.thrift.RemoveBlockTOptions._Fields
 
getThriftFieldId() - Method in enum alluxio.thrift.RemoveBlockTResponse._Fields
 
getThriftFieldId() - Method in enum alluxio.thrift.RenameStoreTOptions._Fields
 
getThriftFieldId() - Method in enum alluxio.thrift.RenameStoreTResponse._Fields
 
getThriftFieldId() - Method in enum alluxio.thrift.RenameTOptions._Fields
 
getThriftFieldId() - Method in enum alluxio.thrift.RenameTResponse._Fields
 
getThriftFieldId() - Method in enum alluxio.thrift.ReportLostFileTOptions._Fields
 
getThriftFieldId() - Method in enum alluxio.thrift.ReportLostFileTResponse._Fields
 
getThriftFieldId() - Method in enum alluxio.thrift.RequestBlockLocationTOptions._Fields
 
getThriftFieldId() - Method in enum alluxio.thrift.RequestBlockLocationTResponse._Fields
 
getThriftFieldId() - Method in enum alluxio.thrift.RequestSpaceTOptions._Fields
 
getThriftFieldId() - Method in enum alluxio.thrift.RequestSpaceTResponse._Fields
 
getThriftFieldId() - Method in enum alluxio.thrift.ScheduleAsyncPersistenceTOptions._Fields
 
getThriftFieldId() - Method in enum alluxio.thrift.ScheduleAsyncPersistenceTResponse._Fields
 
getThriftFieldId() - Method in enum alluxio.thrift.SessionBlockHeartbeatTOptions._Fields
 
getThriftFieldId() - Method in enum alluxio.thrift.SessionBlockHeartbeatTResponse._Fields
 
getThriftFieldId() - Method in enum alluxio.thrift.SessionFileSystemHeartbeatTOptions._Fields
 
getThriftFieldId() - Method in enum alluxio.thrift.SessionFileSystemHeartbeatTResponse._Fields
 
getThriftFieldId() - Method in enum alluxio.thrift.SetAttributeTOptions._Fields
 
getThriftFieldId() - Method in enum alluxio.thrift.SetAttributeTResponse._Fields
 
getThriftFieldId() - Method in enum alluxio.thrift.SyncMetadataTOptions._Fields
 
getThriftFieldId() - Method in enum alluxio.thrift.SyncMetadataTResponse._Fields
 
getThriftFieldId() - Method in enum alluxio.thrift.TieredIdentity._Fields
 
getThriftFieldId() - Method in enum alluxio.thrift.UfsInfo._Fields
 
getThriftFieldId() - Method in enum alluxio.thrift.UnlockBlockTOptions._Fields
 
getThriftFieldId() - Method in enum alluxio.thrift.UnlockBlockTResponse._Fields
 
getThriftFieldId() - Method in enum alluxio.thrift.UnmountTOptions._Fields
 
getThriftFieldId() - Method in enum alluxio.thrift.UnmountTResponse._Fields
 
getThriftFieldId() - Method in enum alluxio.thrift.UpdateUfsModeTOptions._Fields
 
getThriftFieldId() - Method in enum alluxio.thrift.UpdateUfsModeTResponse._Fields
 
getThriftFieldId() - Method in enum alluxio.thrift.WorkerInfo._Fields
 
getThriftFieldId() - Method in enum alluxio.thrift.WorkerNetAddress._Fields
 
getThriftPort(TServerSocket) - Static method in class alluxio.network.thrift.ThriftUtils
Gets the port for the underline socket.
getThriftSocket(TServerSocket) - Static method in class alluxio.network.thrift.ThriftUtils
Extracts internal socket from the thrift socket.
getTier() - Method in class alluxio.proto.dataserver.Protocol.LocalBlockCreateRequest.Builder
optional int32 tier = 3;
getTier() - Method in class alluxio.proto.dataserver.Protocol.LocalBlockCreateRequest
optional int32 tier = 3;
getTier() - Method in interface alluxio.proto.dataserver.Protocol.LocalBlockCreateRequestOrBuilder
optional int32 tier = 3;
getTier() - Method in class alluxio.proto.dataserver.Protocol.WriteRequest.Builder
optional int32 tier = 4;
getTier() - Method in class alluxio.proto.dataserver.Protocol.WriteRequest
optional int32 tier = 4;
getTier() - Method in interface alluxio.proto.dataserver.Protocol.WriteRequestOrBuilder
optional int32 tier = 4;
getTier(int) - Method in class alluxio.wire.TieredIdentity
 
getTier(String) - Method in class alluxio.worker.block.BlockMetadataManager
Gets the StorageTier given its tierAlias.
getTier() - Method in class alluxio.worker.netty.BlockWriteRequest
 
getTierAlias() - Method in class alluxio.master.block.meta.MasterBlockLocation
 
getTierAlias() - Method in class alluxio.thrift.BlockLocation
 
getTierAlias() - Method in class alluxio.thrift.BlockMasterWorkerService.commitBlock_args
the alias of the target tier
getTierAlias() - Method in class alluxio.web.WebInterfaceWorkerGeneralServlet.UIStorageDir
 
getTierAlias() - Method in class alluxio.web.WebInterfaceWorkerGeneralServlet.UIUsageOnTier
 
getTierAlias() - Method in class alluxio.wire.BlockLocation
 
getTierAlias() - Method in class alluxio.worker.block.meta.StorageTier
 
getTierCapacity() - Method in class alluxio.wire.AlluxioMasterInfo
 
getTierCapacity() - Method in class alluxio.wire.AlluxioWorkerInfo
 
getTieredIdentity() - Method in class alluxio.thrift.WorkerNetAddress
 
getTieredIdentity() - Method in class alluxio.wire.WorkerNetAddress
 
getTierName() - Method in class alluxio.thrift.LocalityTier
 
getTierName() - Method in class alluxio.wire.TieredIdentity.LocalityTier
 
getTierOrdinal() - Method in class alluxio.worker.block.meta.StorageTier
 
getTierPaths() - Method in class alluxio.wire.AlluxioWorkerInfo
 
getTiers() - Method in class alluxio.thrift.TieredIdentity
 
getTiers() - Method in class alluxio.wire.TieredIdentity
 
getTiers() - Method in class alluxio.worker.block.BlockMetadataManager
Gets the list of StorageTier managed.
getTiersBelow(String) - Method in class alluxio.worker.block.BlockMetadataManager
Gets the list of StorageTier below the tier with the given tierAlias.
getTiersIterator() - Method in class alluxio.thrift.TieredIdentity
 
getTiersSize() - Method in class alluxio.thrift.TieredIdentity
 
getTierView(String) - Method in class alluxio.worker.block.BlockMetadataManagerView
Provides StorageTierView given tierAlias.
getTierViewAlias() - Method in class alluxio.worker.block.meta.StorageTierView
 
getTierViewOrdinal() - Method in class alluxio.worker.block.meta.StorageTierView
 
getTierViews() - Method in class alluxio.worker.block.BlockMetadataManagerView
Gets all tierViews under this managerView.
getTierViewsBelow(String) - Method in class alluxio.worker.block.BlockMetadataManagerView
Gets all tierViews before certain tierView.
getTimedOutSessions() - Method in class alluxio.Sessions
Gets the sessions that timed out.
getTimeoutMs() - Method in class alluxio.network.netty.NettyRPCContext
 
getTimeoutMs() - Method in class alluxio.util.WaitForOptions
 
getTimerClass(String) - Static method in class alluxio.heartbeat.HeartbeatContext
 
getTimerClasses() - Static method in class alluxio.heartbeat.HeartbeatContext
 
getTmpDir() - Static method in class alluxio.util.CommonUtils
 
getTo(int) - Method in class alluxio.underfs.swift.MidPartLongRange
 
getToken() - Method in class alluxio.underfs.swift.KeystoneV3Access
 
getToPath() - Method in class alluxio.thrift.KeyValueMasterClientService.mergeStore_args
the path of the store to be merged to
GetTOptions - Class in alluxio.thrift
 
GetTOptions() - Constructor for class alluxio.thrift.GetTOptions
 
GetTOptions(GetTOptions) - Constructor for class alluxio.thrift.GetTOptions
Performs a deep copy on other.
GetTOptions._Fields - Enum in alluxio.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
getToRemoveBlocks() - Method in class alluxio.master.block.meta.MasterWorkerInfo
 
getToStoreId() - Method in class alluxio.proto.journal.KeyValue.MergeStoreEntry.Builder
optional int64 to_store_id = 2;
getToStoreId() - Method in class alluxio.proto.journal.KeyValue.MergeStoreEntry
optional int64 to_store_id = 2;
getToStoreId() - Method in interface alluxio.proto.journal.KeyValue.MergeStoreEntryOrBuilder
optional int64 to_store_id = 2;
getTotal() - Method in class alluxio.wire.Capacity
 
getTotalBytesOnTiers() - Method in interface alluxio.master.block.BlockMaster
 
getTotalBytesOnTiers() - Method in class alluxio.master.block.DefaultBlockMaster
 
getTotalBytesOnTiers() - Method in class alluxio.master.block.meta.MasterWorkerInfo
 
getTotalBytesOnTiers() - Method in class alluxio.thrift.BlockMasterWorkerService.registerWorker_args
the map of total bytes on each tier
getTotalBytesOnTiersSize() - Method in class alluxio.thrift.BlockMasterWorkerService.registerWorker_args
 
getTotalExtraTime() - Method in class alluxio.util.JvmPauseMonitor
 
getTransport(TTransport) - Method in class alluxio.network.thrift.BootstrapServerTransport.Factory
 
GetTResponse - Class in alluxio.thrift
 
GetTResponse() - Constructor for class alluxio.thrift.GetTResponse
 
GetTResponse(ByteBuffer) - Constructor for class alluxio.thrift.GetTResponse
 
GetTResponse(GetTResponse) - Constructor for class alluxio.thrift.GetTResponse
Performs a deep copy on other.
GetTResponse._Fields - Enum in alluxio.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
getTtl() - Method in class alluxio.client.file.options.CreateDirectoryOptions
 
getTtl() - Method in class alluxio.client.file.options.CreateFileOptions
 
getTtl() - Method in class alluxio.client.file.options.OutStreamOptions
 
getTtl() - Method in class alluxio.client.file.options.SetAttributeOptions
 
getTtl() - Method in class alluxio.client.file.URIStatus
 
getTtl() - Method in class alluxio.master.file.meta.Inode
 
getTtl() - Method in class alluxio.master.file.options.CreateDirectoryOptions
 
getTtl() - Method in class alluxio.master.file.options.CreateFileOptions
 
getTtl() - Method in class alluxio.master.file.options.SetAttributeOptions
 
getTtl() - Method in class alluxio.proto.journal.File.InodeDirectoryEntry.Builder
optional int64 ttl = 13;
getTtl() - Method in class alluxio.proto.journal.File.InodeDirectoryEntry
optional int64 ttl = 13;
getTtl() - Method in interface alluxio.proto.journal.File.InodeDirectoryEntryOrBuilder
optional int64 ttl = 13;
getTtl() - Method in class alluxio.proto.journal.File.InodeFileEntry.Builder
optional int64 ttl = 13;
getTtl() - Method in class alluxio.proto.journal.File.InodeFileEntry
optional int64 ttl = 13;
getTtl() - Method in interface alluxio.proto.journal.File.InodeFileEntryOrBuilder
optional int64 ttl = 13;
getTtl() - Method in class alluxio.proto.journal.File.ReinitializeFileEntry.Builder
optional int64 ttl = 3;
getTtl() - Method in class alluxio.proto.journal.File.ReinitializeFileEntry
optional int64 ttl = 3;
getTtl() - Method in interface alluxio.proto.journal.File.ReinitializeFileEntryOrBuilder
optional int64 ttl = 3;
getTtl() - Method in class alluxio.proto.journal.File.SetAttributeEntry.Builder
optional int64 ttl = 4;
getTtl() - Method in class alluxio.proto.journal.File.SetAttributeEntry
optional int64 ttl = 4;
getTtl() - Method in interface alluxio.proto.journal.File.SetAttributeEntryOrBuilder
optional int64 ttl = 4;
getTtl() - Method in class alluxio.thrift.CreateDirectoryTOptions
 
getTtl() - Method in class alluxio.thrift.CreateFileTOptions
 
getTtl() - Method in class alluxio.thrift.FileInfo
 
getTtl() - Method in class alluxio.thrift.LineageMasterClientService.reinitializeFile_args
time to live
getTtl() - Method in class alluxio.thrift.SetAttributeTOptions
 
getTtl() - Method in class alluxio.wire.FileInfo
 
getTtlAction() - Method in class alluxio.client.file.options.CreateDirectoryOptions
 
getTtlAction() - Method in class alluxio.client.file.options.CreateFileOptions
 
getTtlAction() - Method in class alluxio.client.file.options.OutStreamOptions
 
getTtlAction() - Method in class alluxio.client.file.options.SetAttributeOptions
 
getTtlAction() - Method in class alluxio.client.file.URIStatus
 
getTtlAction() - Method in class alluxio.master.file.meta.Inode
 
getTtlAction() - Method in class alluxio.master.file.options.CreateDirectoryOptions
 
getTtlAction() - Method in class alluxio.master.file.options.CreateFileOptions
 
getTtlAction() - Method in class alluxio.master.file.options.SetAttributeOptions
 
getTtlAction() - Method in class alluxio.proto.journal.File.InodeDirectoryEntry.Builder
optional .alluxio.proto.journal.PTtlAction ttlAction = 14 [default = DELETE];
getTtlAction() - Method in class alluxio.proto.journal.File.InodeDirectoryEntry
optional .alluxio.proto.journal.PTtlAction ttlAction = 14 [default = DELETE];
getTtlAction() - Method in interface alluxio.proto.journal.File.InodeDirectoryEntryOrBuilder
optional .alluxio.proto.journal.PTtlAction ttlAction = 14 [default = DELETE];
getTtlAction() - Method in class alluxio.proto.journal.File.InodeFileEntry.Builder
optional .alluxio.proto.journal.PTtlAction ttlAction = 17 [default = DELETE];
getTtlAction() - Method in class alluxio.proto.journal.File.InodeFileEntry
optional .alluxio.proto.journal.PTtlAction ttlAction = 17 [default = DELETE];
getTtlAction() - Method in interface alluxio.proto.journal.File.InodeFileEntryOrBuilder
optional .alluxio.proto.journal.PTtlAction ttlAction = 17 [default = DELETE];
getTtlAction() - Method in class alluxio.proto.journal.File.ReinitializeFileEntry.Builder
optional .alluxio.proto.journal.PTtlAction ttlAction = 4 [default = DELETE];
getTtlAction() - Method in class alluxio.proto.journal.File.ReinitializeFileEntry
optional .alluxio.proto.journal.PTtlAction ttlAction = 4 [default = DELETE];
getTtlAction() - Method in interface alluxio.proto.journal.File.ReinitializeFileEntryOrBuilder
optional .alluxio.proto.journal.PTtlAction ttlAction = 4 [default = DELETE];
getTtlAction() - Method in class alluxio.proto.journal.File.SetAttributeEntry.Builder
optional .alluxio.proto.journal.PTtlAction ttlAction = 9 [default = DELETE];
getTtlAction() - Method in class alluxio.proto.journal.File.SetAttributeEntry
optional .alluxio.proto.journal.PTtlAction ttlAction = 9 [default = DELETE];
getTtlAction() - Method in interface alluxio.proto.journal.File.SetAttributeEntryOrBuilder
optional .alluxio.proto.journal.PTtlAction ttlAction = 9 [default = DELETE];
getTtlAction() - Method in class alluxio.thrift.CreateDirectoryTOptions
 
getTtlAction() - Method in class alluxio.thrift.CreateFileTOptions
 
getTtlAction() - Method in class alluxio.thrift.FileInfo
 
getTtlAction() - Method in class alluxio.thrift.LineageMasterClientService.reinitializeFile_args
expiry action
getTtlAction() - Method in class alluxio.thrift.SetAttributeTOptions
 
getTtlAction() - Method in class alluxio.wire.FileInfo
 
getTtlIntervalEndTimeMs() - Method in class alluxio.master.file.meta.TtlBucket
 
getTtlIntervalMs() - Static method in class alluxio.master.file.meta.TtlBucket
 
getTtlIntervalStartTimeMs() - Method in class alluxio.master.file.meta.TtlBucket
 
getType() - Method in class alluxio.conf.Source
 
getType() - Method in class alluxio.network.protocol.RPCMessage
Returns the type of the message.
getType() - Method in class alluxio.network.protocol.RPCProtoMessage
 
getType() - Method in class alluxio.proto.dataserver.Protocol.ReadResponse.Builder
optional .alluxio.proto.dataserver.ReadResponse.Type type = 1;
getType() - Method in class alluxio.proto.dataserver.Protocol.ReadResponse
optional .alluxio.proto.dataserver.ReadResponse.Type type = 1;
getType() - Method in interface alluxio.proto.dataserver.Protocol.ReadResponseOrBuilder
optional .alluxio.proto.dataserver.ReadResponse.Type type = 1;
getType() - Method in class alluxio.proto.dataserver.Protocol.WriteRequest.Builder
optional .alluxio.proto.dataserver.RequestType type = 1;
getType() - Method in class alluxio.proto.dataserver.Protocol.WriteRequest
optional .alluxio.proto.dataserver.RequestType type = 1;
getType() - Method in interface alluxio.proto.dataserver.Protocol.WriteRequestOrBuilder
optional .alluxio.proto.dataserver.RequestType type = 1;
getUfsAddress() - Method in class alluxio.master.file.DefaultFileSystemMaster
 
getUfsAddress() - Method in interface alluxio.master.file.FileSystemMaster
 
getUfsCapacity() - Method in class alluxio.wire.AlluxioMasterInfo
 
getUfsCapacityBytes() - Method in class alluxio.master.meta.AlluxioMasterRestServiceHandler
Deprecated.
since version 1.4 and will be removed in version 2.0
getUfsCapacityBytes() - Method in class alluxio.thrift.MountPointInfo
 
getUfsCapacityBytes() - Method in class alluxio.wire.MountPointInfo
 
getUfsFingerprint() - Method in class alluxio.client.file.URIStatus
 
getUfsFingerprint() - Method in class alluxio.master.file.meta.Inode
 
getUfsFingerprint() - Method in class alluxio.master.file.options.SetAttributeOptions
 
getUfsFingerprint() - Method in class alluxio.proto.journal.File.CompleteFileEntry.Builder
optional string ufs_fingerprint = 5;
getUfsFingerprint() - Method in class alluxio.proto.journal.File.CompleteFileEntry
optional string ufs_fingerprint = 5;
getUfsFingerprint() - Method in interface alluxio.proto.journal.File.CompleteFileEntryOrBuilder
optional string ufs_fingerprint = 5;
getUfsFingerprint() - Method in class alluxio.proto.journal.File.InodeFileEntry.Builder
optional string ufs_fingerprint = 18;
getUfsFingerprint() - Method in class alluxio.proto.journal.File.InodeFileEntry
optional string ufs_fingerprint = 18;
getUfsFingerprint() - Method in interface alluxio.proto.journal.File.InodeFileEntryOrBuilder
optional string ufs_fingerprint = 18;
getUfsFingerprint() - Method in class alluxio.proto.journal.File.SetAttributeEntry.Builder
optional string ufs_fingerprint = 10;
getUfsFingerprint() - Method in class alluxio.proto.journal.File.SetAttributeEntry
optional string ufs_fingerprint = 10;
getUfsFingerprint() - Method in interface alluxio.proto.journal.File.SetAttributeEntryOrBuilder
optional string ufs_fingerprint = 10;
getUfsFingerprint() - Method in class alluxio.thrift.FileInfo
 
getUfsFingerprint() - Method in class alluxio.wire.FileInfo
 
getUfsFingerprintBytes() - Method in class alluxio.proto.journal.File.CompleteFileEntry.Builder
optional string ufs_fingerprint = 5;
getUfsFingerprintBytes() - Method in class alluxio.proto.journal.File.CompleteFileEntry
optional string ufs_fingerprint = 5;
getUfsFingerprintBytes() - Method in interface alluxio.proto.journal.File.CompleteFileEntryOrBuilder
optional string ufs_fingerprint = 5;
getUfsFingerprintBytes() - Method in class alluxio.proto.journal.File.InodeFileEntry.Builder
optional string ufs_fingerprint = 18;
getUfsFingerprintBytes() - Method in class alluxio.proto.journal.File.InodeFileEntry
optional string ufs_fingerprint = 18;
getUfsFingerprintBytes() - Method in interface alluxio.proto.journal.File.InodeFileEntryOrBuilder
optional string ufs_fingerprint = 18;
getUfsFingerprintBytes() - Method in class alluxio.proto.journal.File.SetAttributeEntry.Builder
optional string ufs_fingerprint = 10;
getUfsFingerprintBytes() - Method in class alluxio.proto.journal.File.SetAttributeEntry
optional string ufs_fingerprint = 10;
getUfsFingerprintBytes() - Method in interface alluxio.proto.journal.File.SetAttributeEntryOrBuilder
optional string ufs_fingerprint = 10;
getUfsFreeBytes() - Method in class alluxio.master.meta.AlluxioMasterRestServiceHandler
Deprecated.
since version 1.4 and will be removed in version 2.0
getUfsInfo(long) - Method in class alluxio.master.file.DefaultFileSystemMaster
 
getUfsInfo(long) - Method in interface alluxio.master.file.FileSystemMaster
 
getUfsInfo(long, GetUfsInfoTOptions) - Method in class alluxio.master.file.FileSystemMasterWorkerServiceHandler
 
getUfsInfo(long, GetUfsInfoTOptions, AsyncMethodCallback) - Method in class alluxio.thrift.FileSystemMasterWorkerService.AsyncClient
 
getUfsInfo(long, GetUfsInfoTOptions, AsyncMethodCallback) - Method in interface alluxio.thrift.FileSystemMasterWorkerService.AsyncIface
 
getUfsInfo() - Constructor for class alluxio.thrift.FileSystemMasterWorkerService.AsyncProcessor.getUfsInfo
 
getUfsInfo(long, GetUfsInfoTOptions) - Method in class alluxio.thrift.FileSystemMasterWorkerService.Client
 
getUfsInfo(long, GetUfsInfoTOptions) - Method in interface alluxio.thrift.FileSystemMasterWorkerService.Iface
Returns the UFS information for the given mount point identified by its id.
getUfsInfo() - Constructor for class alluxio.thrift.FileSystemMasterWorkerService.Processor.getUfsInfo
 
getUfsInfo() - Method in class alluxio.thrift.GetUfsInfoTResponse
 
getUfsInfo(long) - Method in class alluxio.worker.file.FileSystemMasterClient
 
getUfsInfo_args() - Constructor for class alluxio.thrift.FileSystemMasterWorkerService.getUfsInfo_args
 
getUfsInfo_args(long, GetUfsInfoTOptions) - Constructor for class alluxio.thrift.FileSystemMasterWorkerService.getUfsInfo_args
 
getUfsInfo_args(FileSystemMasterWorkerService.getUfsInfo_args) - Constructor for class alluxio.thrift.FileSystemMasterWorkerService.getUfsInfo_args
Performs a deep copy on other.
getUfsInfo_call(long, GetUfsInfoTOptions, AsyncMethodCallback, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class alluxio.thrift.FileSystemMasterWorkerService.AsyncClient.getUfsInfo_call
 
getUfsInfo_result() - Constructor for class alluxio.thrift.FileSystemMasterWorkerService.getUfsInfo_result
 
getUfsInfo_result(GetUfsInfoTResponse, AlluxioTException) - Constructor for class alluxio.thrift.FileSystemMasterWorkerService.getUfsInfo_result
 
getUfsInfo_result(FileSystemMasterWorkerService.getUfsInfo_result) - Constructor for class alluxio.thrift.FileSystemMasterWorkerService.getUfsInfo_result
Performs a deep copy on other.
GetUfsInfoTOptions - Class in alluxio.thrift
 
GetUfsInfoTOptions() - Constructor for class alluxio.thrift.GetUfsInfoTOptions
 
GetUfsInfoTOptions(GetUfsInfoTOptions) - Constructor for class alluxio.thrift.GetUfsInfoTOptions
Performs a deep copy on other.
GetUfsInfoTOptions._Fields - Enum in alluxio.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
GetUfsInfoTResponse - Class in alluxio.thrift
 
GetUfsInfoTResponse() - Constructor for class alluxio.thrift.GetUfsInfoTResponse
 
GetUfsInfoTResponse(UfsInfo) - Constructor for class alluxio.thrift.GetUfsInfoTResponse
 
GetUfsInfoTResponse(GetUfsInfoTResponse) - Constructor for class alluxio.thrift.GetUfsInfoTResponse
Performs a deep copy on other.
GetUfsInfoTResponse._Fields - Enum in alluxio.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
getUfsLength() - Method in class alluxio.client.file.options.CompleteFileOptions
 
getUfsLength() - Method in class alluxio.master.file.options.CompleteFileOptions
 
getUfsLength() - Method in class alluxio.thrift.CompleteFileTOptions
 
getUfsLocations() - Method in class alluxio.thrift.FileBlockInfo
 
getUfsLocations() - Method in class alluxio.wire.FileBlockInfo
 
getUfsLocationsIterator() - Method in class alluxio.thrift.FileBlockInfo
 
getUfsLocationsSize() - Method in class alluxio.thrift.FileBlockInfo
 
getUfsManager() - Method in class alluxio.worker.AlluxioWorkerProcess
 
getUfsManager() - Method in interface alluxio.worker.WorkerProcess
 
getUfsMode() - Method in class alluxio.client.file.options.UpdateUfsModeOptions
 
getUfsMode() - Method in class alluxio.proto.journal.File.UpdateUfsModeEntry.Builder
optional .alluxio.proto.journal.UfsMode ufsMode = 2 [default = READ_WRITE];
getUfsMode() - Method in class alluxio.proto.journal.File.UpdateUfsModeEntry
optional .alluxio.proto.journal.UfsMode ufsMode = 2 [default = READ_WRITE];
getUfsMode() - Method in interface alluxio.proto.journal.File.UpdateUfsModeEntryOrBuilder
optional .alluxio.proto.journal.UfsMode ufsMode = 2 [default = READ_WRITE];
getUfsMode() - Method in class alluxio.thrift.UpdateUfsModeTOptions
 
getUfsMountPointUri() - Method in class alluxio.underfs.UfsManager.UfsClient
 
getUfsMountPointUri() - Method in class alluxio.worker.block.UnderFileSystemBlockReader
 
getUfsPath() - Method in class alluxio.client.block.options.LockBlockOptions
 
getUfsPath() - Method in class alluxio.client.file.options.OutStreamOptions
 
getUfsPath() - Method in class alluxio.client.file.URIStatus
 
getUfsPath() - Method in class alluxio.proto.dataserver.Protocol.CreateUfsFileOptions.Builder
optional string ufs_path = 1;
getUfsPath() - Method in class alluxio.proto.dataserver.Protocol.CreateUfsFileOptions
optional string ufs_path = 1;
getUfsPath() - Method in interface alluxio.proto.dataserver.Protocol.CreateUfsFileOptionsOrBuilder
optional string ufs_path = 1;
getUfsPath() - Method in class alluxio.proto.dataserver.Protocol.OpenUfsBlockOptions.Builder
optional string ufs_path = 1;
getUfsPath() - Method in class alluxio.proto.dataserver.Protocol.OpenUfsBlockOptions
optional string ufs_path = 1;
getUfsPath() - Method in interface alluxio.proto.dataserver.Protocol.OpenUfsBlockOptionsOrBuilder
optional string ufs_path = 1;
getUfsPath() - Method in class alluxio.proto.journal.File.AddMountPointEntry.Builder
optional string ufs_path = 2;
getUfsPath() - Method in class alluxio.proto.journal.File.AddMountPointEntry
optional string ufs_path = 2;
getUfsPath() - Method in interface alluxio.proto.journal.File.AddMountPointEntryOrBuilder
optional string ufs_path = 2;
getUfsPath() - Method in class alluxio.proto.journal.File.UpdateUfsModeEntry.Builder
optional string ufsPath = 1;
getUfsPath() - Method in class alluxio.proto.journal.File.UpdateUfsModeEntry
optional string ufsPath = 1;
getUfsPath() - Method in interface alluxio.proto.journal.File.UpdateUfsModeEntryOrBuilder
optional string ufsPath = 1;
getUfsPath() - Method in class alluxio.thrift.FileInfo
 
getUfsPath() - Method in class alluxio.thrift.FileSystemMasterClientService.loadMetadata_args
the path of the under file system
getUfsPath() - Method in class alluxio.thrift.FileSystemMasterClientService.mount_args
the path of the under file system
getUfsPath() - Method in class alluxio.thrift.FileSystemMasterClientService.updateUfsMode_args
the ufs path
getUfsPath() - Method in class alluxio.thrift.FileSystemWorkerClientService.createUfsFile_args
the path of the file in the ufs
getUfsPath() - Method in class alluxio.thrift.FileSystemWorkerClientService.openUfsFile_args
the path of the file in the ufs
getUfsPath() - Method in class alluxio.thrift.LockBlockTOptions
 
getUfsPath() - Method in class alluxio.wire.FileInfo
 
getUfsPath() - Method in class alluxio.worker.netty.UfsFileWriteRequest
 
getUfsPathBytes() - Method in class alluxio.proto.dataserver.Protocol.CreateUfsFileOptions.Builder
optional string ufs_path = 1;
getUfsPathBytes() - Method in class alluxio.proto.dataserver.Protocol.CreateUfsFileOptions
optional string ufs_path = 1;
getUfsPathBytes() - Method in interface alluxio.proto.dataserver.Protocol.CreateUfsFileOptionsOrBuilder
optional string ufs_path = 1;
getUfsPathBytes() - Method in class alluxio.proto.dataserver.Protocol.OpenUfsBlockOptions.Builder
optional string ufs_path = 1;
getUfsPathBytes() - Method in class alluxio.proto.dataserver.Protocol.OpenUfsBlockOptions
optional string ufs_path = 1;
getUfsPathBytes() - Method in interface alluxio.proto.dataserver.Protocol.OpenUfsBlockOptionsOrBuilder
optional string ufs_path = 1;
getUfsPathBytes() - Method in class alluxio.proto.journal.File.AddMountPointEntry.Builder
optional string ufs_path = 2;
getUfsPathBytes() - Method in class alluxio.proto.journal.File.AddMountPointEntry
optional string ufs_path = 2;
getUfsPathBytes() - Method in interface alluxio.proto.journal.File.AddMountPointEntryOrBuilder
optional string ufs_path = 2;
getUfsPathBytes() - Method in class alluxio.proto.journal.File.UpdateUfsModeEntry.Builder
optional string ufsPath = 1;
getUfsPathBytes() - Method in class alluxio.proto.journal.File.UpdateUfsModeEntry
optional string ufsPath = 1;
getUfsPathBytes() - Method in interface alluxio.proto.journal.File.UpdateUfsModeEntryOrBuilder
optional string ufsPath = 1;
getUfsReadLocationPolicy() - Method in class alluxio.client.file.options.OpenFileOptions
 
getUfsReadLocationPolicyClass() - Method in class alluxio.client.file.options.OpenFileOptions
 
getUfsResource() - Method in class alluxio.worker.netty.UfsFileWriteRequestContext
 
getUfsStatus() - Method in class alluxio.master.file.options.CompleteFileOptions
 
getUfsStatus() - Method in class alluxio.master.file.options.CreateDirectoryOptions
 
getUfsStatus() - Method in class alluxio.master.file.options.LoadMetadataOptions
 
getUfsStringLocations() - Method in class alluxio.thrift.FileBlockInfo
 
getUfsStringLocationsIterator() - Method in class alluxio.thrift.FileBlockInfo
 
getUfsStringLocationsSize() - Method in class alluxio.thrift.FileBlockInfo
 
getUfsType() - Method in class alluxio.thrift.MountPointInfo
 
getUfsType() - Method in class alluxio.wire.MountPointInfo
 
getUfsUri() - Method in class alluxio.master.file.meta.options.MountInfo
 
getUfsUri() - Method in class alluxio.thrift.MountPointInfo
 
getUfsUri() - Method in class alluxio.wire.MountPointInfo
 
getUfsUsedBytes() - Method in class alluxio.master.meta.AlluxioMasterRestServiceHandler
Deprecated.
since version 1.4 and will be removed in version 2.0
getUfsUsedBytes() - Method in class alluxio.thrift.MountPointInfo
 
getUfsUsedBytes() - Method in class alluxio.wire.MountPointInfo
 
getUid(String) - Static method in class alluxio.fuse.AlluxioFuseUtils
Retrieves the uid of the given user.
getUMask(String) - Static method in class alluxio.security.authorization.Mode
Gets the file / directory creation umask.
getUnderFileSystem() - Method in class alluxio.underfs.UnderFileSystemWithLogging
This is only used in the test.
getUnderFileSystemPath() - Method in class alluxio.worker.block.meta.UnderFileSystemBlockMeta
 
getUnderFSType() - Method in class alluxio.underfs.cos.COSUnderFileSystem
 
getUnderFSType() - Method in class alluxio.underfs.gcs.GCSUnderFileSystem
 
getUnderFSType() - Method in class alluxio.underfs.hdfs.HdfsUnderFileSystem
 
getUnderFSType() - Method in class alluxio.underfs.local.LocalUnderFileSystem
 
getUnderFSType() - Method in class alluxio.underfs.oss.OSSUnderFileSystem
 
getUnderFSType() - Method in class alluxio.underfs.s3a.S3AUnderFileSystem
 
getUnderFSType() - Method in class alluxio.underfs.swift.SwiftUnderFileSystem
 
getUnderFSType() - Method in interface alluxio.underfs.UnderFileSystem
Returns the name of the under filesystem implementation.
getUnderFSType() - Method in class alluxio.underfs.UnderFileSystemWithLogging
 
getUnderFSType() - Method in class alluxio.underfs.wasb.WasbUnderFileSystem
 
getUnderStorageType() - Method in class alluxio.client.file.options.OutStreamOptions
 
getUnderStorageType() - Method in enum alluxio.client.WriteType
 
getUnixGroups(String) - Static method in class alluxio.util.CommonUtils
Gets the current user's group list from Unix by running the command 'groups' NOTE.
getUnixMountInfo() - Static method in class alluxio.util.ShellUtils
Gets system mount information.
getUnknownFields() - Method in class alluxio.proto.dataserver.Protocol.AsyncCacheRequest
 
getUnknownFields() - Method in class alluxio.proto.dataserver.Protocol.CreateUfsFileOptions
 
getUnknownFields() - Method in class alluxio.proto.dataserver.Protocol.Heartbeat
 
getUnknownFields() - Method in class alluxio.proto.dataserver.Protocol.LocalBlockCloseRequest
 
getUnknownFields() - Method in class alluxio.proto.dataserver.Protocol.LocalBlockCompleteRequest
 
getUnknownFields() - Method in class alluxio.proto.dataserver.Protocol.LocalBlockCreateRequest
 
getUnknownFields() - Method in class alluxio.proto.dataserver.Protocol.LocalBlockCreateResponse
 
getUnknownFields() - Method in class alluxio.proto.dataserver.Protocol.LocalBlockOpenRequest
 
getUnknownFields() - Method in class alluxio.proto.dataserver.Protocol.LocalBlockOpenResponse
 
getUnknownFields() - Method in class alluxio.proto.dataserver.Protocol.OpenUfsBlockOptions
 
getUnknownFields() - Method in class alluxio.proto.dataserver.Protocol.ReadRequest
 
getUnknownFields() - Method in class alluxio.proto.dataserver.Protocol.ReadResponse
 
getUnknownFields() - Method in class alluxio.proto.dataserver.Protocol.Response
 
getUnknownFields() - Method in class alluxio.proto.dataserver.Protocol.WriteRequest
 
getUnknownFields() - Method in class alluxio.proto.journal.Block.BlockContainerIdGeneratorEntry
 
getUnknownFields() - Method in class alluxio.proto.journal.Block.BlockInfoEntry
 
getUnknownFields() - Method in class alluxio.proto.journal.Block.DeleteBlockEntry
 
getUnknownFields() - Method in class alluxio.proto.journal.File.AddMountPointEntry
 
getUnknownFields() - Method in class alluxio.proto.journal.File.AsyncPersistRequestEntry
 
getUnknownFields() - Method in class alluxio.proto.journal.File.CompleteFileEntry
 
getUnknownFields() - Method in class alluxio.proto.journal.File.DeleteFileEntry
 
getUnknownFields() - Method in class alluxio.proto.journal.File.DeleteMountPointEntry
 
getUnknownFields() - Method in class alluxio.proto.journal.File.InodeDirectoryEntry
 
getUnknownFields() - Method in class alluxio.proto.journal.File.InodeDirectoryIdGeneratorEntry
 
getUnknownFields() - Method in class alluxio.proto.journal.File.InodeFileEntry
 
getUnknownFields() - Method in class alluxio.proto.journal.File.InodeLastModificationTimeEntry
 
getUnknownFields() - Method in class alluxio.proto.journal.File.PersistDirectoryEntry
 
getUnknownFields() - Method in class alluxio.proto.journal.File.PersistFileEntry
 
getUnknownFields() - Method in class alluxio.proto.journal.File.ReinitializeFileEntry
 
getUnknownFields() - Method in class alluxio.proto.journal.File.RenameEntry
 
getUnknownFields() - Method in class alluxio.proto.journal.File.SetAttributeEntry
 
getUnknownFields() - Method in class alluxio.proto.journal.File.StringPairEntry
 
getUnknownFields() - Method in class alluxio.proto.journal.File.UpdateUfsModeEntry
 
getUnknownFields() - Method in class alluxio.proto.journal.Journal.JournalEntry
 
getUnknownFields() - Method in class alluxio.proto.journal.KeyValue.CompletePartitionEntry
 
getUnknownFields() - Method in class alluxio.proto.journal.KeyValue.CompleteStoreEntry
 
getUnknownFields() - Method in class alluxio.proto.journal.KeyValue.CreateStoreEntry
 
getUnknownFields() - Method in class alluxio.proto.journal.KeyValue.DeleteStoreEntry
 
getUnknownFields() - Method in class alluxio.proto.journal.KeyValue.MergeStoreEntry
 
getUnknownFields() - Method in class alluxio.proto.journal.KeyValue.RenameStoreEntry
 
getUnknownFields() - Method in class alluxio.proto.journal.Lineage.DeleteLineageEntry
 
getUnknownFields() - Method in class alluxio.proto.journal.Lineage.LineageEntry
 
getUnknownFields() - Method in class alluxio.proto.journal.Lineage.LineageIdGeneratorEntry
 
getUpdateUfsMode() - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
optional .alluxio.proto.journal.UpdateUfsModeEntry update_ufs_mode = 30;
getUpdateUfsMode() - Method in class alluxio.proto.journal.Journal.JournalEntry
optional .alluxio.proto.journal.UpdateUfsModeEntry update_ufs_mode = 30;
getUpdateUfsMode() - Method in interface alluxio.proto.journal.Journal.JournalEntryOrBuilder
optional .alluxio.proto.journal.UpdateUfsModeEntry update_ufs_mode = 30;
getUpdateUfsModeBuilder() - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
optional .alluxio.proto.journal.UpdateUfsModeEntry update_ufs_mode = 30;
getUpdateUfsModeOrBuilder() - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
optional .alluxio.proto.journal.UpdateUfsModeEntry update_ufs_mode = 30;
getUpdateUfsModeOrBuilder() - Method in class alluxio.proto.journal.Journal.JournalEntry
optional .alluxio.proto.journal.UpdateUfsModeEntry update_ufs_mode = 30;
getUpdateUfsModeOrBuilder() - Method in interface alluxio.proto.journal.Journal.JournalEntryOrBuilder
optional .alluxio.proto.journal.UpdateUfsModeEntry update_ufs_mode = 30;
getUploadId() - Method in class alluxio.proxy.s3.InitiateMultipartUploadResult
 
getUploadId() - Method in class alluxio.proxy.s3.ListPartsResult
 
getUploadPath() - Method in class alluxio.underfs.s3a.S3AOutputStream
 
getUptime() - Method in class alluxio.web.WebInterfaceWorkerGeneralServlet.UIWorkerInfo
 
getUptimeClockTime() - Method in class alluxio.web.WebInterfaceWorkersServlet.NodeInfo
 
getUptimeMs() - Method in class alluxio.master.AlluxioMasterProcess
 
getUptimeMs() - Method in interface alluxio.master.MasterProcess
 
getUptimeMs() - Method in class alluxio.master.meta.AlluxioMasterRestServiceHandler
Deprecated.
since version 1.4 and will be removed in version 2.0
getUptimeMs() - Method in class alluxio.master.meta.DefaultMetaMaster
 
getUptimeMs() - Method in interface alluxio.master.meta.MetaMaster
 
getUptimeMs() - Method in class alluxio.proxy.AlluxioProxyProcess
 
getUptimeMs() - Method in interface alluxio.proxy.ProxyProcess
 
getUpTimeMs() - Method in class alluxio.thrift.MasterInfo
 
getUptimeMs() - Method in class alluxio.wire.AlluxioMasterInfo
 
getUptimeMs() - Method in class alluxio.wire.AlluxioProxyInfo
 
getUptimeMs() - Method in class alluxio.wire.AlluxioWorkerInfo
 
getUpTimeMs() - Method in class alluxio.wire.MasterInfo
 
getUptimeMs() - Method in class alluxio.worker.AlluxioWorkerProcess
 
getUptimeMs() - Method in class alluxio.worker.AlluxioWorkerRestServiceHandler
Deprecated.
since version 1.4 and will be removed in version 2.0
getUptimeMs() - Method in interface alluxio.worker.WorkerProcess
 
getUri() - Method in class alluxio.master.file.meta.LockedInodePath
 
getUri() - Method in class alluxio.master.file.meta.MountTable.Resolution
 
getUri() - Method in class alluxio.master.LocalAlluxioMaster
 
getUri() - Method in class alluxio.master.MultiMasterLocalAlluxioCluster
 
getUri() - Method in class alluxio.thrift.UfsInfo
 
getUriDefaultPort() - Method in class alluxio.hadoop.AlluxioFileSystem
 
getUsage() - Method in interface alluxio.cli.Command
 
getUsage() - Method in class alluxio.cli.extensions.command.InstallCommand
 
getUsage() - Method in class alluxio.cli.extensions.command.LsCommand
 
getUsage() - Method in class alluxio.cli.extensions.command.UninstallCommand
 
getUsage() - Method in class alluxio.cli.fs.command.CatCommand
 
getUsage() - Method in class alluxio.cli.fs.command.CheckConsistencyCommand
 
getUsage() - Method in class alluxio.cli.fs.command.ChecksumCommand
 
getUsage() - Method in class alluxio.cli.fs.command.ChgrpCommand
 
getUsage() - Method in class alluxio.cli.fs.command.ChmodCommand
 
getUsage() - Method in class alluxio.cli.fs.command.ChownCommand
 
getUsage() - Method in class alluxio.cli.fs.command.CopyFromLocalCommand
 
getUsage() - Method in class alluxio.cli.fs.command.CopyToLocalCommand
 
getUsage() - Method in class alluxio.cli.fs.command.CountCommand
 
getUsage() - Method in class alluxio.cli.fs.command.CpCommand
 
getUsage() - Method in class alluxio.cli.fs.command.CreateLineageCommand
 
getUsage() - Method in class alluxio.cli.fs.command.DeleteLineageCommand
 
getUsage() - Method in class alluxio.cli.fs.command.DuCommand
 
getUsage() - Method in class alluxio.cli.fs.command.FileInfoCommand
Deprecated.
 
getUsage() - Method in class alluxio.cli.fs.command.FreeCommand
 
getUsage() - Method in class alluxio.cli.fs.command.GetCapacityBytesCommand
 
getUsage() - Method in class alluxio.cli.fs.command.GetUsedBytesCommand
 
getUsage() - Method in class alluxio.cli.fs.command.HeadCommand
 
getUsage() - Method in class alluxio.cli.fs.command.HelpCommand
 
getUsage() - Method in class alluxio.cli.fs.command.LeaderCommand
 
getUsage() - Method in class alluxio.cli.fs.command.ListLineagesCommand
 
getUsage() - Method in class alluxio.cli.fs.command.LoadCommand
 
getUsage() - Method in class alluxio.cli.fs.command.LoadMetadataCommand
Deprecated.
 
getUsage() - Method in class alluxio.cli.fs.command.LocationCommand
 
getUsage() - Method in class alluxio.cli.fs.command.LsCommand
 
getUsage() - Method in class alluxio.cli.fs.command.MasterInfoCommand
 
getUsage() - Method in class alluxio.cli.fs.command.MkdirCommand
 
getUsage() - Method in class alluxio.cli.fs.command.MountCommand
 
getUsage() - Method in class alluxio.cli.fs.command.MvCommand
 
getUsage() - Method in class alluxio.cli.fs.command.PersistCommand
 
getUsage() - Method in class alluxio.cli.fs.command.PinCommand
 
getUsage() - Method in class alluxio.cli.fs.command.ReportCommand
 
getUsage() - Method in class alluxio.cli.fs.command.RmCommand
 
getUsage() - Method in class alluxio.cli.fs.command.SetTtlCommand
 
getUsage() - Method in class alluxio.cli.fs.command.StatCommand
 
getUsage() - Method in class alluxio.cli.fs.command.TailCommand
 
getUsage() - Method in class alluxio.cli.fs.command.TestCommand
 
getUsage() - Method in class alluxio.cli.fs.command.TouchCommand
 
getUsage() - Method in class alluxio.cli.fs.command.UnmountCommand
 
getUsage() - Method in class alluxio.cli.fs.command.UnpinCommand
 
getUsage() - Method in class alluxio.cli.fs.command.UnsetTtlCommand
 
getUsage() - Method in class alluxio.cli.fsadmin.command.BackupCommand
 
getUsage() - Method in class alluxio.cli.fsadmin.command.DoctorCommand
 
getUsage() - Method in class alluxio.cli.fsadmin.command.GetBlockInfoCommand
 
getUsage() - Method in class alluxio.cli.fsadmin.command.ReportCommand
 
getUsage() - Method in class alluxio.cli.fsadmin.command.UfsCommand
 
getUsage() - Static method in class alluxio.cli.fsadmin.report.CapacityCommand
 
getUsageCount() - Method in class alluxio.worker.block.io.LocalFileBlockReader
 
getUsed() - Method in class alluxio.wire.Capacity
 
getUsedBytes() - Method in class alluxio.client.block.AlluxioBlockStore
Gets the used bytes of Alluxio's BlockStore.
getUsedBytes() - Method in interface alluxio.client.block.BlockMasterClient
Gets the total amount of used space in bytes, on all the tiers of all the workers.
getUsedBytes() - Method in class alluxio.client.block.BlockWorkerInfo
 
getUsedBytes() - Method in class alluxio.client.block.RetryHandlingBlockMasterClient
Gets the total amount of used space in bytes, on all the tiers of all the workers.
getUsedBytes() - Method in interface alluxio.master.block.BlockMaster
 
getUsedBytes(GetUsedBytesTOptions) - Method in class alluxio.master.block.BlockMasterClientServiceHandler
 
getUsedBytes() - Method in class alluxio.master.block.DefaultBlockMaster
 
getUsedBytes() - Method in class alluxio.master.block.meta.MasterWorkerInfo
 
getUsedBytes() - Method in class alluxio.master.meta.AlluxioMasterRestServiceHandler
Deprecated.
since version 1.4 and will be removed in version 2.0
getUsedBytes(GetUsedBytesTOptions, AsyncMethodCallback) - Method in class alluxio.thrift.BlockMasterClientService.AsyncClient
 
getUsedBytes(GetUsedBytesTOptions, AsyncMethodCallback) - Method in interface alluxio.thrift.BlockMasterClientService.AsyncIface
 
getUsedBytes() - Constructor for class alluxio.thrift.BlockMasterClientService.AsyncProcessor.getUsedBytes
 
getUsedBytes(GetUsedBytesTOptions) - Method in class alluxio.thrift.BlockMasterClientService.Client
 
getUsedBytes(GetUsedBytesTOptions) - Method in interface alluxio.thrift.BlockMasterClientService.Iface
Returns the used storage (in bytes).
getUsedBytes() - Constructor for class alluxio.thrift.BlockMasterClientService.Processor.getUsedBytes
 
getUsedBytes() - Method in class alluxio.thrift.BlockMasterInfo
 
getUsedBytes() - Method in class alluxio.thrift.WorkerInfo
 
getUsedBytes() - Method in class alluxio.web.WebInterfaceWorkerGeneralServlet.UIStorageDir
 
getUsedBytes() - Method in class alluxio.web.WebInterfaceWorkerGeneralServlet.UIUsageOnTier
 
getUsedBytes() - Method in class alluxio.wire.BlockMasterInfo
 
getUsedBytes() - Method in class alluxio.wire.WorkerInfo
 
getUsedBytes() - Method in class alluxio.worker.AlluxioWorkerRestServiceHandler
Deprecated.
since version 1.4 and will be removed in version 2.0
getUsedBytes() - Method in interface alluxio.worker.block.BlockStoreMeta
 
getUsedBytes() - Method in class alluxio.worker.block.DefaultBlockStoreMeta
 
getUsedBytes_args() - Constructor for class alluxio.thrift.BlockMasterClientService.getUsedBytes_args
 
getUsedBytes_args(GetUsedBytesTOptions) - Constructor for class alluxio.thrift.BlockMasterClientService.getUsedBytes_args
 
getUsedBytes_args(BlockMasterClientService.getUsedBytes_args) - Constructor for class alluxio.thrift.BlockMasterClientService.getUsedBytes_args
Performs a deep copy on other.
getUsedBytes_call(GetUsedBytesTOptions, AsyncMethodCallback, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class alluxio.thrift.BlockMasterClientService.AsyncClient.getUsedBytes_call
 
getUsedBytes_result() - Constructor for class alluxio.thrift.BlockMasterClientService.getUsedBytes_result
 
getUsedBytes_result(GetUsedBytesTResponse, AlluxioTException) - Constructor for class alluxio.thrift.BlockMasterClientService.getUsedBytes_result
 
getUsedBytes_result(BlockMasterClientService.getUsedBytes_result) - Constructor for class alluxio.thrift.BlockMasterClientService.getUsedBytes_result
Performs a deep copy on other.
GetUsedBytesCommand - Class in alluxio.cli.fs.command
Gets number of bytes used in the FileSystem.
GetUsedBytesCommand(FileSystem) - Constructor for class alluxio.cli.fs.command.GetUsedBytesCommand
Constructs a new instance to get the number of bytes used in the FileSystem.
getUsedBytesOnDirs() - Method in interface alluxio.worker.block.BlockStoreMeta
 
getUsedBytesOnDirs() - Method in class alluxio.worker.block.DefaultBlockStoreMeta
 
getUsedBytesOnTier() - Method in class alluxio.thrift.BlockMasterWorkerService.commitBlock_args
the space used in bytes on the target tier
getUsedBytesOnTiers() - Method in interface alluxio.master.block.BlockMaster
 
getUsedBytesOnTiers() - Method in class alluxio.master.block.DefaultBlockMaster
 
getUsedBytesOnTiers() - Method in class alluxio.master.block.meta.MasterWorkerInfo
 
getUsedBytesOnTiers() - Method in class alluxio.master.meta.AlluxioMasterRestServiceHandler
Deprecated.
since version 1.4 and will be removed in version 2.0
getUsedBytesOnTiers() - Method in class alluxio.thrift.BlockMasterInfo
 
getUsedBytesOnTiers() - Method in class alluxio.thrift.BlockMasterWorkerService.blockHeartbeat_args
the map of space used in bytes on all tiers
getUsedBytesOnTiers() - Method in class alluxio.thrift.BlockMasterWorkerService.registerWorker_args
the map of used bytes on each tier
getUsedBytesOnTiers() - Method in class alluxio.thrift.WorkerInfo
 
getUsedBytesOnTiers() - Method in class alluxio.wire.BlockMasterInfo
 
getUsedBytesOnTiers() - Method in class alluxio.wire.WorkerInfo
 
getUsedBytesOnTiers() - Method in class alluxio.worker.AlluxioWorkerRestServiceHandler
Deprecated.
since version 1.4 and will be removed in version 2.0
getUsedBytesOnTiers() - Method in interface alluxio.worker.block.BlockStoreMeta
 
getUsedBytesOnTiers() - Method in class alluxio.worker.block.DefaultBlockStoreMeta
 
getUsedBytesOnTiersSize() - Method in class alluxio.thrift.BlockMasterInfo
 
getUsedBytesOnTiersSize() - Method in class alluxio.thrift.BlockMasterWorkerService.blockHeartbeat_args
 
getUsedBytesOnTiersSize() - Method in class alluxio.thrift.BlockMasterWorkerService.registerWorker_args
 
getUsedBytesOnTiersSize() - Method in class alluxio.thrift.WorkerInfo
 
GetUsedBytesTOptions - Class in alluxio.thrift
 
GetUsedBytesTOptions() - Constructor for class alluxio.thrift.GetUsedBytesTOptions
 
GetUsedBytesTOptions(GetUsedBytesTOptions) - Constructor for class alluxio.thrift.GetUsedBytesTOptions
Performs a deep copy on other.
GetUsedBytesTOptions._Fields - Enum in alluxio.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
GetUsedBytesTResponse - Class in alluxio.thrift
 
GetUsedBytesTResponse() - Constructor for class alluxio.thrift.GetUsedBytesTResponse
 
GetUsedBytesTResponse(long) - Constructor for class alluxio.thrift.GetUsedBytesTResponse
 
GetUsedBytesTResponse(GetUsedBytesTResponse) - Constructor for class alluxio.thrift.GetUsedBytesTResponse
Performs a deep copy on other.
GetUsedBytesTResponse._Fields - Enum in alluxio.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
getUsedCapacity() - Method in class alluxio.web.WebInterfaceGeneralServlet.StorageTierInfo
 
getUsedMemory() - Method in class alluxio.web.WebInterfaceWorkersServlet.NodeInfo
 
getUsedSpacePercent() - Method in class alluxio.web.WebInterfaceGeneralServlet.StorageTierInfo
 
getUsedSpacePercent() - Method in class alluxio.web.WebInterfaceWorkersServlet.NodeInfo
 
getUser() - Method in class alluxio.proto.dataserver.Protocol.OpenUfsBlockOptions.Builder
optional string user = 7;
getUser() - Method in class alluxio.proto.dataserver.Protocol.OpenUfsBlockOptions
optional string user = 7;
getUser() - Method in interface alluxio.proto.dataserver.Protocol.OpenUfsBlockOptionsOrBuilder
optional string user = 7;
getUser() - Method in class alluxio.worker.block.meta.UnderFileSystemBlockMeta
 
getUserBytes() - Method in class alluxio.proto.dataserver.Protocol.OpenUfsBlockOptions.Builder
optional string user = 7;
getUserBytes() - Method in class alluxio.proto.dataserver.Protocol.OpenUfsBlockOptions
optional string user = 7;
getUserBytes() - Method in interface alluxio.proto.dataserver.Protocol.OpenUfsBlockOptionsOrBuilder
optional string user = 7;
getUserName(long) - Static method in class alluxio.fuse.AlluxioFuseUtils
Gets the user name from the user id.
getUserSpecifiedConf() - Method in class alluxio.underfs.UnderFileSystemConfiguration
 
getValue() - Method in class alluxio.client.keyvalue.KeyValuePair
 
getValue(int) - Method in interface alluxio.client.keyvalue.PayloadReader
Gets the value given the position of payload buffer.
getValue() - Method in enum alluxio.client.ReadType
 
getValue() - Method in enum alluxio.client.WriteType
 
getValue() - Method in class alluxio.master.meta.checkconf.ConfigRecord
 
getValue(String) - Method in class alluxio.metrics.aggregator.SingleTagValueAggregator
 
getValue(Map<MetricsFilter, Set<Metric>>) - Method in class alluxio.metrics.aggregator.SumInstancesAggregator
 
getValue() - Method in class alluxio.metrics.Metric
 
getValue(String) - Method in interface alluxio.metrics.MultiValueMetricsAggregator
Gets the metric value of the given fully qualified metric name.
getValue(Map<MetricsFilter, Set<Metric>>) - Method in interface alluxio.metrics.SingleValueAggregator
Gets the aggregated value from the filtered metrics.
getValue() - Method in class alluxio.proto.journal.File.StringPairEntry.Builder
optional string value = 2;
getValue() - Method in class alluxio.proto.journal.File.StringPairEntry
optional string value = 2;
getValue() - Method in interface alluxio.proto.journal.File.StringPairEntryOrBuilder
optional string value = 2;
getValue() - Method in enum alluxio.thrift.BlockMasterInfoField
Get the integer value of this enum value, as defined in the Thrift IDL.
getValue() - Method in enum alluxio.thrift.CommandType
Get the integer value of this enum value, as defined in the Thrift IDL.
getValue() - Method in class alluxio.thrift.ConfigProperty
 
getValue() - Method in enum alluxio.thrift.ConfigStatus
Get the integer value of this enum value, as defined in the Thrift IDL.
getValue() - Method in enum alluxio.thrift.LoadMetadataTType
Get the integer value of this enum value, as defined in the Thrift IDL.
getValue() - Method in class alluxio.thrift.LocalityTier
 
getValue() - Method in enum alluxio.thrift.LockBlockStatus
Get the integer value of this enum value, as defined in the Thrift IDL.
getValue() - Method in enum alluxio.thrift.MasterInfoField
Get the integer value of this enum value, as defined in the Thrift IDL.
getValue() - Method in enum alluxio.thrift.MetaCommand
Get the integer value of this enum value, as defined in the Thrift IDL.
getValue() - Method in class alluxio.thrift.Metric
 
getValue() - Method in class alluxio.thrift.OptionalString
 
getValue() - Method in enum alluxio.thrift.Scope
Get the integer value of this enum value, as defined in the Thrift IDL.
getValue() - Method in enum alluxio.thrift.TStatus
Get the integer value of this enum value, as defined in the Thrift IDL.
getValue() - Method in enum alluxio.thrift.TTtlAction
Get the integer value of this enum value, as defined in the Thrift IDL.
getValue() - Method in enum alluxio.thrift.UfsMode
Get the integer value of this enum value, as defined in the Thrift IDL.
getValue() - Method in enum alluxio.thrift.WorkerInfoField
Get the integer value of this enum value, as defined in the Thrift IDL.
getValue() - Method in enum alluxio.thrift.WorkerRange
Get the integer value of this enum value, as defined in the Thrift IDL.
getValue() - Method in enum alluxio.underfs.UnderFileSystem.SpaceType
 
getValue(PropertyKey) - Method in class alluxio.underfs.UnderFileSystemConfiguration
Gets the value of the given key in the given UFS configuration or the global configuration (in case the key is not found in the UFS configuration), throw RuntimeException if the key is not found in both configurations.
getValue() - Method in class alluxio.util.executor.ControllableQueue.DelayNode
 
getValue() - Method in class alluxio.wire.ConfigProperty
 
getValue() - Method in enum alluxio.wire.LoadMetadataType
 
getValue() - Method in class alluxio.wire.OptionalString
 
getValue() - Method in class alluxio.wire.TieredIdentity.LocalityTier
 
getValue() - Method in enum alluxio.worker.block.BlockLockType
 
getValueBytes() - Method in class alluxio.proto.journal.File.StringPairEntry.Builder
optional string value = 2;
getValueBytes() - Method in class alluxio.proto.journal.File.StringPairEntry
optional string value = 2;
getValueBytes() - Method in interface alluxio.proto.journal.File.StringPairEntryOrBuilder
optional string value = 2;
getValueDescriptor() - Method in enum alluxio.proto.dataserver.Protocol.ReadResponse.Type
 
getValueDescriptor() - Method in enum alluxio.proto.dataserver.Protocol.RequestType
 
getValueDescriptor() - Method in enum alluxio.proto.journal.File.PTtlAction
 
getValueDescriptor() - Method in enum alluxio.proto.journal.File.UfsMode
 
getValueDescriptor() - Method in enum alluxio.proto.status.Status.PStatus
 
getValueFromStaticMapping(String, String) - Static method in class alluxio.util.CommonUtils
Gets the value with a given key from a static key/value mapping in string format.
getValues() - Method in class alluxio.thrift.InconsistentProperty
 
getValues() - Method in class alluxio.wire.InconsistentProperty
 
getValuesSize() - Method in class alluxio.thrift.InconsistentProperty
 
getVersion() - Method in class alluxio.master.meta.AlluxioMasterRestServiceHandler
Deprecated.
since version 1.4 and will be removed in version 2.0
getVersion() - Method in class alluxio.thrift.GetServiceVersionTResponse
 
getVersion() - Method in class alluxio.thrift.MasterInfo
 
getVersion() - Method in class alluxio.wire.AlluxioMasterInfo
 
getVersion() - Method in class alluxio.wire.AlluxioProxyInfo
 
getVersion() - Method in class alluxio.wire.AlluxioWorkerInfo
 
getVersion() - Method in class alluxio.wire.MasterInfo
 
getVersion() - Method in class alluxio.worker.AlluxioWorkerRestServiceHandler
Deprecated.
since version 1.4 and will be removed in version 2.0
getVolatileBlockMeta(long) - Method in interface alluxio.worker.block.BlockStore
Gets the metadata of a block given its block id or throws BlockDoesNotExistException.
getVolatileBlockMeta(long) - Method in interface alluxio.worker.block.BlockWorker
Gets the metadata of a block given its blockId or throws IOException.
getVolatileBlockMeta(long) - Method in class alluxio.worker.block.DefaultBlockWorker
 
getVolatileBlockMeta(long) - Method in class alluxio.worker.block.TieredBlockStore
 
getWarns() - Method in class alluxio.thrift.ConfigCheckReport
 
getWarnsSize() - Method in class alluxio.thrift.ConfigCheckReport
 
getWarnTimeExceeded() - Method in class alluxio.util.JvmPauseMonitor
 
getWebAddress() - Method in class alluxio.master.AlluxioMasterProcess
 
getWebAddress() - Method in interface alluxio.master.MasterProcess
 
getWebBindHost() - Method in class alluxio.worker.AlluxioWorkerProcess
 
getWebBindHost() - Method in interface alluxio.worker.WorkerProcess
 
getWebLocalPort() - Method in class alluxio.proxy.AlluxioProxyProcess
 
getWebLocalPort() - Method in interface alluxio.proxy.ProxyProcess
 
getWebLocalPort() - Method in class alluxio.worker.AlluxioWorkerProcess
 
getWebLocalPort() - Method in interface alluxio.worker.WorkerProcess
 
getWebPort() - Method in class alluxio.master.meta.DefaultMetaMaster
 
getWebPort() - Method in interface alluxio.master.meta.MetaMaster
 
getWebPort() - Method in class alluxio.multi.process.MasterNetAddress
 
getWebPort() - Method in class alluxio.thrift.MasterInfo
 
getWebPort() - Method in class alluxio.thrift.WorkerNetAddress
 
getWebPort() - Method in class alluxio.web.WebInterfaceWorkersServlet.NodeInfo
 
getWebPort() - Method in class alluxio.wire.MasterInfo
 
getWebPort() - Method in class alluxio.wire.WorkerNetAddress
 
getWhiteList() - Method in class alluxio.master.file.DefaultFileSystemMaster
 
getWhiteList() - Method in interface alluxio.master.file.FileSystemMaster
 
getWorker(GetWorkerOptions) - Method in interface alluxio.client.block.policy.BlockLocationPolicy
Gets the worker's network address for serving operations requested for the block.
getWorker(GetWorkerOptions) - Method in class alluxio.client.block.policy.DeterministicHashPolicy
 
getWorker(GetWorkerOptions) - Method in class alluxio.client.file.policy.LocalFirstAvoidEvictionPolicy
 
getWorker(GetWorkerOptions) - Method in class alluxio.client.file.policy.LocalFirstPolicy
 
getWorker(GetWorkerOptions) - Method in class alluxio.client.file.policy.MostAvailableFirstPolicy
 
getWorker(GetWorkerOptions) - Method in class alluxio.client.file.policy.RoundRobinPolicy
 
getWorker(GetWorkerOptions) - Method in class alluxio.client.file.policy.SpecificHostPolicy
 
getWorker(Class<T>) - Method in class alluxio.worker.AlluxioWorkerProcess
 
getWorker(Class<T>) - Method in interface alluxio.worker.WorkerProcess
 
getWorkerAddress() - Method in class alluxio.master.block.meta.MasterWorkerInfo
 
getWorkerAddress() - Method in class alluxio.master.LocalAlluxioCluster
 
getWorkerAddress() - Method in class alluxio.thrift.BlockLocation
 
getWorkerAddress() - Method in class alluxio.web.WebInterfaceWorkerGeneralServlet.UIWorkerInfo
 
getWorkerAddress() - Method in class alluxio.wire.BlockLocation
 
getWorkerAddresses() - Method in class alluxio.master.meta.DefaultMetaMaster
 
getWorkerAddresses() - Method in interface alluxio.master.meta.MetaMaster
 
getWorkerAddresses() - Method in class alluxio.thrift.MasterInfo
 
getWorkerAddresses() - Method in class alluxio.wire.MasterInfo
 
getWorkerAddressesIterator() - Method in class alluxio.thrift.MasterInfo
 
getWorkerAddressesSize() - Method in class alluxio.thrift.MasterInfo
 
getWorkerCount() - Method in interface alluxio.master.block.BlockMaster
 
getWorkerCount() - Method in class alluxio.master.block.DefaultBlockMaster
 
getWorkerCount() - Method in class alluxio.master.meta.AlluxioMasterRestServiceHandler
Deprecated.
since version 1.4 and will be removed in version 2.0
getWorkerDataDirectory(String) - Static method in class alluxio.util.io.PathUtils
 
getWorkerForNextBlock(Iterable<BlockWorkerInfo>, long) - Method in interface alluxio.client.file.policy.FileWriteLocationPolicy
Gets the worker's host name for the next block to write to.
getWorkerForNextBlock(Iterable<BlockWorkerInfo>, long) - Method in class alluxio.client.file.policy.LocalFirstAvoidEvictionPolicy
 
getWorkerForNextBlock(Iterable<BlockWorkerInfo>, long) - Method in class alluxio.client.file.policy.LocalFirstPolicy
 
getWorkerForNextBlock(Iterable<BlockWorkerInfo>, long) - Method in class alluxio.client.file.policy.MostAvailableFirstPolicy
 
getWorkerForNextBlock(Iterable<BlockWorkerInfo>, long) - Method in class alluxio.client.file.policy.RoundRobinPolicy
The policy uses the first fetch of worker info list as the base, and visits each of them in a round-robin manner in the subsequent calls.
getWorkerForNextBlock(Iterable<BlockWorkerInfo>, long) - Method in class alluxio.client.file.policy.SpecificHostPolicy
 
getWorkerHostnames() - Static method in class alluxio.cli.extensions.ExtensionsShellUtils
Gets list of workers in conf directory.
getWorkerId(WorkerNetAddress) - Method in interface alluxio.master.block.BlockMaster
Returns a worker id for the given worker, creating one if the worker is new.
getWorkerId(WorkerNetAddress, GetWorkerIdTOptions) - Method in class alluxio.master.block.BlockMasterWorkerServiceHandler
 
getWorkerId(WorkerNetAddress) - Method in class alluxio.master.block.DefaultBlockMaster
 
getWorkerId() - Method in class alluxio.master.block.meta.MasterBlockLocation
 
getWorkerId() - Method in class alluxio.thrift.BlockLocation
 
getWorkerId(WorkerNetAddress, GetWorkerIdTOptions, AsyncMethodCallback) - Method in class alluxio.thrift.BlockMasterWorkerService.AsyncClient
 
getWorkerId(WorkerNetAddress, GetWorkerIdTOptions, AsyncMethodCallback) - Method in interface alluxio.thrift.BlockMasterWorkerService.AsyncIface
 
getWorkerId() - Constructor for class alluxio.thrift.BlockMasterWorkerService.AsyncProcessor.getWorkerId
 
getWorkerId() - Method in class alluxio.thrift.BlockMasterWorkerService.blockHeartbeat_args
the id of the worker
getWorkerId(WorkerNetAddress, GetWorkerIdTOptions) - Method in class alluxio.thrift.BlockMasterWorkerService.Client
 
getWorkerId() - Method in class alluxio.thrift.BlockMasterWorkerService.commitBlock_args
the id of the worker
getWorkerId(WorkerNetAddress, GetWorkerIdTOptions) - Method in interface alluxio.thrift.BlockMasterWorkerService.Iface
Returns a worker id for the given network address.
getWorkerId() - Constructor for class alluxio.thrift.BlockMasterWorkerService.Processor.getWorkerId
 
getWorkerId() - Method in class alluxio.thrift.BlockMasterWorkerService.registerWorker_args
the id of the worker
getWorkerId() - Method in class alluxio.thrift.FileSystemMasterWorkerService.fileSystemHeartbeat_args
the id of the worker
getWorkerId() - Method in class alluxio.thrift.GetWorkerIdTResponse
 
getWorkerId() - Method in class alluxio.web.WebInterfaceWorkersServlet.NodeInfo
 
getWorkerId() - Method in class alluxio.wire.BlockLocation
 
getWorkerId() - Method in interface alluxio.worker.block.BlockWorker
 
getWorkerId() - Method in class alluxio.worker.block.DefaultBlockWorker
 
getWorkerId_args() - Constructor for class alluxio.thrift.BlockMasterWorkerService.getWorkerId_args
 
getWorkerId_args(WorkerNetAddress, GetWorkerIdTOptions) - Constructor for class alluxio.thrift.BlockMasterWorkerService.getWorkerId_args
 
getWorkerId_args(BlockMasterWorkerService.getWorkerId_args) - Constructor for class alluxio.thrift.BlockMasterWorkerService.getWorkerId_args
Performs a deep copy on other.
getWorkerId_call(WorkerNetAddress, GetWorkerIdTOptions, AsyncMethodCallback, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class alluxio.thrift.BlockMasterWorkerService.AsyncClient.getWorkerId_call
 
getWorkerId_result() - Constructor for class alluxio.thrift.BlockMasterWorkerService.getWorkerId_result
 
getWorkerId_result(GetWorkerIdTResponse, AlluxioTException) - Constructor for class alluxio.thrift.BlockMasterWorkerService.getWorkerId_result
 
getWorkerId_result(BlockMasterWorkerService.getWorkerId_result) - Constructor for class alluxio.thrift.BlockMasterWorkerService.getWorkerId_result
Performs a deep copy on other.
GetWorkerIdTOptions - Class in alluxio.thrift
 
GetWorkerIdTOptions() - Constructor for class alluxio.thrift.GetWorkerIdTOptions
 
GetWorkerIdTOptions(GetWorkerIdTOptions) - Constructor for class alluxio.thrift.GetWorkerIdTOptions
Performs a deep copy on other.
GetWorkerIdTOptions._Fields - Enum in alluxio.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
GetWorkerIdTResponse - Class in alluxio.thrift
 
GetWorkerIdTResponse() - Constructor for class alluxio.thrift.GetWorkerIdTResponse
 
GetWorkerIdTResponse(long) - Constructor for class alluxio.thrift.GetWorkerIdTResponse
 
GetWorkerIdTResponse(GetWorkerIdTResponse) - Constructor for class alluxio.thrift.GetWorkerIdTResponse
Performs a deep copy on other.
GetWorkerIdTResponse._Fields - Enum in alluxio.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
getWorkerInfoList() - Method in interface alluxio.client.block.BlockMasterClient
Gets the worker information of live workers(support older version Alluxio server).
getWorkerInfoList() - Method in class alluxio.client.block.RetryHandlingBlockMasterClient
 
getWorkerInfoList() - Method in interface alluxio.master.block.BlockMaster
 
getWorkerInfoList(GetWorkerInfoListTOptions) - Method in class alluxio.master.block.BlockMasterClientServiceHandler
 
getWorkerInfoList() - Method in class alluxio.master.block.DefaultBlockMaster
 
getWorkerInfoList() - Method in class alluxio.master.file.DefaultFileSystemMaster
 
getWorkerInfoList() - Method in interface alluxio.master.file.FileSystemMaster
 
getWorkerInfoList() - Method in class alluxio.master.file.meta.FileSystemMasterView
 
getWorkerInfoList() - Method in class alluxio.master.meta.AlluxioMasterRestServiceHandler
Deprecated.
since version 1.4 and will be removed in version 2.0
getWorkerInfoList(GetWorkerInfoListTOptions, AsyncMethodCallback) - Method in class alluxio.thrift.BlockMasterClientService.AsyncClient
 
getWorkerInfoList(GetWorkerInfoListTOptions, AsyncMethodCallback) - Method in interface alluxio.thrift.BlockMasterClientService.AsyncIface
 
getWorkerInfoList() - Constructor for class alluxio.thrift.BlockMasterClientService.AsyncProcessor.getWorkerInfoList
 
getWorkerInfoList(GetWorkerInfoListTOptions) - Method in class alluxio.thrift.BlockMasterClientService.Client
 
getWorkerInfoList(GetWorkerInfoListTOptions) - Method in interface alluxio.thrift.BlockMasterClientService.Iface
Returns a list of workers information.
getWorkerInfoList() - Constructor for class alluxio.thrift.BlockMasterClientService.Processor.getWorkerInfoList
 
getWorkerInfoList() - Method in class alluxio.thrift.GetWorkerInfoListTResponse
 
getWorkerInfoList_args() - Constructor for class alluxio.thrift.BlockMasterClientService.getWorkerInfoList_args
 
getWorkerInfoList_args(GetWorkerInfoListTOptions) - Constructor for class alluxio.thrift.BlockMasterClientService.getWorkerInfoList_args
 
getWorkerInfoList_args(BlockMasterClientService.getWorkerInfoList_args) - Constructor for class alluxio.thrift.BlockMasterClientService.getWorkerInfoList_args
Performs a deep copy on other.
getWorkerInfoList_call(GetWorkerInfoListTOptions, AsyncMethodCallback, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class alluxio.thrift.BlockMasterClientService.AsyncClient.getWorkerInfoList_call
 
getWorkerInfoList_result() - Constructor for class alluxio.thrift.BlockMasterClientService.getWorkerInfoList_result
 
getWorkerInfoList_result(GetWorkerInfoListTResponse, AlluxioTException) - Constructor for class alluxio.thrift.BlockMasterClientService.getWorkerInfoList_result
 
getWorkerInfoList_result(BlockMasterClientService.getWorkerInfoList_result) - Constructor for class alluxio.thrift.BlockMasterClientService.getWorkerInfoList_result
Performs a deep copy on other.
getWorkerInfoListIterator() - Method in class alluxio.thrift.GetWorkerInfoListTResponse
 
getWorkerInfoListSize() - Method in class alluxio.thrift.GetWorkerInfoListTResponse
 
GetWorkerInfoListTOptions - Class in alluxio.thrift
 
GetWorkerInfoListTOptions() - Constructor for class alluxio.thrift.GetWorkerInfoListTOptions
 
GetWorkerInfoListTOptions(GetWorkerInfoListTOptions) - Constructor for class alluxio.thrift.GetWorkerInfoListTOptions
Performs a deep copy on other.
GetWorkerInfoListTOptions._Fields - Enum in alluxio.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
GetWorkerInfoListTResponse - Class in alluxio.thrift
 
GetWorkerInfoListTResponse() - Constructor for class alluxio.thrift.GetWorkerInfoListTResponse
 
GetWorkerInfoListTResponse(List<WorkerInfo>) - Constructor for class alluxio.thrift.GetWorkerInfoListTResponse
 
GetWorkerInfoListTResponse(GetWorkerInfoListTResponse) - Constructor for class alluxio.thrift.GetWorkerInfoListTResponse
Performs a deep copy on other.
GetWorkerInfoListTResponse._Fields - Enum in alluxio.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
getWorkerNetAddress() - Method in class alluxio.thrift.BlockMasterWorkerService.getWorkerId_args
the worker network address
GetWorkerOptions - Class in alluxio.client.block.policy.options
getWorkerProcess() - Method in class alluxio.master.LocalAlluxioCluster
 
getWorkerRange() - Method in class alluxio.client.block.options.GetWorkerReportOptions
 
getWorkerRange() - Method in class alluxio.thrift.GetWorkerReportTOptions
 
getWorkerReport(GetWorkerReportOptions) - Method in interface alluxio.client.block.BlockMasterClient
Gets the worker information of selected workers and selected fields for report CLI.
getWorkerReport(GetWorkerReportOptions) - Method in class alluxio.client.block.RetryHandlingBlockMasterClient
 
getWorkerReport(GetWorkerReportOptions) - Method in interface alluxio.master.block.BlockMaster
Gets the worker information list for report CLI.
getWorkerReport(GetWorkerReportTOptions) - Method in class alluxio.master.block.BlockMasterClientServiceHandler
 
getWorkerReport(GetWorkerReportOptions) - Method in class alluxio.master.block.DefaultBlockMaster
 
getWorkerReport(GetWorkerReportTOptions, AsyncMethodCallback) - Method in class alluxio.thrift.BlockMasterClientService.AsyncClient
 
getWorkerReport(GetWorkerReportTOptions, AsyncMethodCallback) - Method in interface alluxio.thrift.BlockMasterClientService.AsyncIface
 
getWorkerReport() - Constructor for class alluxio.thrift.BlockMasterClientService.AsyncProcessor.getWorkerReport
 
getWorkerReport(GetWorkerReportTOptions) - Method in class alluxio.thrift.BlockMasterClientService.Client
 
getWorkerReport(GetWorkerReportTOptions) - Method in interface alluxio.thrift.BlockMasterClientService.Iface
Returns a list of workers information for report CLI.
getWorkerReport() - Constructor for class alluxio.thrift.BlockMasterClientService.Processor.getWorkerReport
 
getWorkerReport_args() - Constructor for class alluxio.thrift.BlockMasterClientService.getWorkerReport_args
 
getWorkerReport_args(GetWorkerReportTOptions) - Constructor for class alluxio.thrift.BlockMasterClientService.getWorkerReport_args
 
getWorkerReport_args(BlockMasterClientService.getWorkerReport_args) - Constructor for class alluxio.thrift.BlockMasterClientService.getWorkerReport_args
Performs a deep copy on other.
getWorkerReport_call(GetWorkerReportTOptions, AsyncMethodCallback, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class alluxio.thrift.BlockMasterClientService.AsyncClient.getWorkerReport_call
 
getWorkerReport_result() - Constructor for class alluxio.thrift.BlockMasterClientService.getWorkerReport_result
 
getWorkerReport_result(GetWorkerInfoListTResponse, AlluxioTException) - Constructor for class alluxio.thrift.BlockMasterClientService.getWorkerReport_result
 
getWorkerReport_result(BlockMasterClientService.getWorkerReport_result) - Constructor for class alluxio.thrift.BlockMasterClientService.getWorkerReport_result
Performs a deep copy on other.
GetWorkerReportOptions - Class in alluxio.client.block.options
Worker information options.
GetWorkerReportOptions(GetWorkerReportTOptions) - Constructor for class alluxio.client.block.options.GetWorkerReportOptions
Creates a new instance of GetWorkerReportOptions from a thrift representation.
GetWorkerReportOptions.WorkerInfoField - Enum in alluxio.client.block.options
Enum representing the fields of the worker information.
GetWorkerReportOptions.WorkerRange - Enum in alluxio.client.block.options
Enum representing the range of workers that we want to show capacity information for.
GetWorkerReportTOptions - Class in alluxio.thrift
 
GetWorkerReportTOptions() - Constructor for class alluxio.thrift.GetWorkerReportTOptions
 
GetWorkerReportTOptions(GetWorkerReportTOptions) - Constructor for class alluxio.thrift.GetWorkerReportTOptions
Performs a deep copy on other.
GetWorkerReportTOptions._Fields - Enum in alluxio.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
getWorkers() - Method in class alluxio.master.block.meta.MasterBlockInfo
 
getWorkers() - Method in class alluxio.wire.AlluxioMasterInfo
 
getWorkerServiceHandler() - Method in interface alluxio.worker.block.BlockWorker
 
getWorkerServiceHandler() - Method in class alluxio.worker.block.DefaultBlockWorker
 
getWorkerServiceLoader() - Static method in class alluxio.ServiceUtils
 
getWriter() - Method in interface alluxio.master.journalv0.MutableJournal
 
getWriter() - Method in class alluxio.master.journalv0.ufs.UfsMutableJournal
 
getWriteTier() - Method in class alluxio.client.file.options.CreateFileOptions
 
getWriteTier() - Method in class alluxio.client.file.options.OutStreamOptions
 
getWriteTier() - Method in class alluxio.thrift.BlockWorkerClientService.requestBlockLocation_args
the target tier to write to
getWriteType() - Method in class alluxio.client.file.options.CreateDirectoryOptions
 
getWriteType() - Method in class alluxio.client.file.options.CreateFileOptions
 
getWriteType() - Method in class alluxio.client.file.options.OutStreamOptions
 
getZkAddress() - Method in class alluxio.master.ZkMasterInquireClient.ZkMasterConnectDetails
 
getZone() - Method in class alluxio.clock.ElapsedTimeClock
 
getZone() - Method in class alluxio.clock.SystemClock
 
getZookeeperAddresses() - Method in class alluxio.thrift.MasterInfo
 
getZookeeperAddresses() - Method in class alluxio.wire.MasterInfo
 
getZookeeperAddressesIterator() - Method in class alluxio.thrift.MasterInfo
 
getZookeeperAddressesSize() - Method in class alluxio.thrift.MasterInfo
 
global() - Static method in class alluxio.Configuration
 
GraphiteSink - Class in alluxio.metrics.sink
A sink which publishes metric values to a Graphite server.
GraphiteSink(Properties, MetricRegistry) - Constructor for class alluxio.metrics.sink.GraphiteSink
Creates a new GraphiteSink with a Properties and MetricRegistry.
GreedyAllocator - Class in alluxio.worker.block.allocator
A greedy allocator that returns the first Storage dir fitting the size of block to allocate.
GreedyAllocator(BlockMetadataManagerView) - Constructor for class alluxio.worker.block.allocator.GreedyAllocator
Creates a new instance of GreedyAllocator.
GreedyEvictor - Class in alluxio.worker.block.evictor
A simple evictor that evicts arbitrary blocks until the required size is met.
GreedyEvictor(BlockMetadataManagerView, Allocator) - Constructor for class alluxio.worker.block.evictor.GreedyEvictor
Creates a new instance of GreedyEvictor.
GROUP_FIELD_NUMBER - Static variable in class alluxio.proto.dataserver.Protocol.CreateUfsFileOptions
 
GROUP_FIELD_NUMBER - Static variable in class alluxio.proto.journal.File.InodeDirectoryEntry
 
GROUP_FIELD_NUMBER - Static variable in class alluxio.proto.journal.File.InodeFileEntry
 
GROUP_FIELD_NUMBER - Static variable in class alluxio.proto.journal.File.SetAttributeEntry
 
GroupMappingService - Interface in alluxio.security.group
Interface for Alluxio user-to-groups mapping.
GroupMappingService.Factory - Class in alluxio.security.group
Factory for creating a new instance.

H

HADOOP_CONF_DIR_ENV_VAR - Static variable in class alluxio.cli.validation.HdfsValidationTask
Name of the environment variable to store the path to Hadoop config directory.
HADOOP_CONF_DIR_OPTION - Static variable in class alluxio.cli.validation.HdfsValidationTask
 
HADOOP_VERSION - Static variable in class alluxio.ProjectConstants
 
HadoopConfigurationFileParser - Class in alluxio.cli.validation
Parser for configuration files.
HadoopConfigurationFileParser() - Constructor for class alluxio.cli.validation.HadoopConfigurationFileParser
Constructs a HadoopConfigurationFileParser object.
HadoopConfigurationUtils - Class in alluxio.hadoop
Utility class for merging Alluxio Configuration with Hadoop's Configuration class.
HadoopUtils - Class in alluxio.hadoop
Utility class for using Alluxio with Hadoop.
handle(Callback[]) - Method in class alluxio.security.authentication.PlainSaslClientCallbackHandler
 
handle(Callback[]) - Method in class alluxio.security.authentication.PlainSaslServerCallbackHandler
 
handle(Callback[]) - Method in class alluxio.security.login.AppLoginModule.AppCallbackHandler
 
handleNodeLost(Address) - Method in class alluxio.master.meta.checkconf.ServerConfigurationStore
Updates configuration when a live node becomes lost.
hasAddMountPoint() - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
optional .alluxio.proto.journal.AddMountPointEntry add_mount_point = 2;
hasAddMountPoint() - Method in class alluxio.proto.journal.Journal.JournalEntry
optional .alluxio.proto.journal.AddMountPointEntry add_mount_point = 2;
hasAddMountPoint() - Method in interface alluxio.proto.journal.Journal.JournalEntryOrBuilder
optional .alluxio.proto.journal.AddMountPointEntry add_mount_point = 2;
hasAlluxioOnly() - Method in class alluxio.proto.journal.File.DeleteFileEntry.Builder
optional bool alluxioOnly = 4;
hasAlluxioOnly() - Method in class alluxio.proto.journal.File.DeleteFileEntry
optional bool alluxioOnly = 4;
hasAlluxioOnly() - Method in interface alluxio.proto.journal.File.DeleteFileEntryOrBuilder
optional bool alluxioOnly = 4;
hasAlluxioPath() - Method in class alluxio.proto.journal.File.AddMountPointEntry.Builder
optional string alluxio_path = 1;
hasAlluxioPath() - Method in class alluxio.proto.journal.File.AddMountPointEntry
optional string alluxio_path = 1;
hasAlluxioPath() - Method in interface alluxio.proto.journal.File.AddMountPointEntryOrBuilder
optional string alluxio_path = 1;
hasAlluxioPath() - Method in class alluxio.proto.journal.File.DeleteMountPointEntry.Builder
optional string alluxio_path = 1;
hasAlluxioPath() - Method in class alluxio.proto.journal.File.DeleteMountPointEntry
optional string alluxio_path = 1;
hasAlluxioPath() - Method in interface alluxio.proto.journal.File.DeleteMountPointEntryOrBuilder
optional string alluxio_path = 1;
hasAsyncPersistRequest() - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
optional .alluxio.proto.journal.AsyncPersistRequestEntry async_persist_request = 16;
hasAsyncPersistRequest() - Method in class alluxio.proto.journal.Journal.JournalEntry
optional .alluxio.proto.journal.AsyncPersistRequestEntry async_persist_request = 16;
hasAsyncPersistRequest() - Method in interface alluxio.proto.journal.Journal.JournalEntryOrBuilder
optional .alluxio.proto.journal.AsyncPersistRequestEntry async_persist_request = 16;
hasAuthority() - Method in class alluxio.AlluxioURI
Tells if the AlluxioURI has authority or not.
hasBlockContainerIdGenerator() - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
optional .alluxio.proto.journal.BlockContainerIdGeneratorEntry block_container_id_generator = 3;
hasBlockContainerIdGenerator() - Method in class alluxio.proto.journal.Journal.JournalEntry
optional .alluxio.proto.journal.BlockContainerIdGeneratorEntry block_container_id_generator = 3;
hasBlockContainerIdGenerator() - Method in interface alluxio.proto.journal.Journal.JournalEntryOrBuilder
optional .alluxio.proto.journal.BlockContainerIdGeneratorEntry block_container_id_generator = 3;
hasBlockId() - Method in class alluxio.proto.dataserver.Protocol.AsyncCacheRequest.Builder
optional int64 block_id = 1;
hasBlockId() - Method in class alluxio.proto.dataserver.Protocol.AsyncCacheRequest
optional int64 block_id = 1;
hasBlockId() - Method in interface alluxio.proto.dataserver.Protocol.AsyncCacheRequestOrBuilder
optional int64 block_id = 1;
hasBlockId() - Method in class alluxio.proto.dataserver.Protocol.LocalBlockCloseRequest.Builder
optional int64 block_id = 1;
hasBlockId() - Method in class alluxio.proto.dataserver.Protocol.LocalBlockCloseRequest
optional int64 block_id = 1;
hasBlockId() - Method in interface alluxio.proto.dataserver.Protocol.LocalBlockCloseRequestOrBuilder
optional int64 block_id = 1;
hasBlockId() - Method in class alluxio.proto.dataserver.Protocol.LocalBlockCompleteRequest.Builder
optional int64 block_id = 1;
hasBlockId() - Method in class alluxio.proto.dataserver.Protocol.LocalBlockCompleteRequest
optional int64 block_id = 1;
hasBlockId() - Method in interface alluxio.proto.dataserver.Protocol.LocalBlockCompleteRequestOrBuilder
optional int64 block_id = 1;
hasBlockId() - Method in class alluxio.proto.dataserver.Protocol.LocalBlockCreateRequest.Builder
optional int64 block_id = 1;
hasBlockId() - Method in class alluxio.proto.dataserver.Protocol.LocalBlockCreateRequest
optional int64 block_id = 1;
hasBlockId() - Method in interface alluxio.proto.dataserver.Protocol.LocalBlockCreateRequestOrBuilder
optional int64 block_id = 1;
hasBlockId() - Method in class alluxio.proto.dataserver.Protocol.LocalBlockOpenRequest.Builder
optional int64 block_id = 1;
hasBlockId() - Method in class alluxio.proto.dataserver.Protocol.LocalBlockOpenRequest
optional int64 block_id = 1;
hasBlockId() - Method in interface alluxio.proto.dataserver.Protocol.LocalBlockOpenRequestOrBuilder
optional int64 block_id = 1;
hasBlockId() - Method in class alluxio.proto.dataserver.Protocol.ReadRequest.Builder
optional int64 block_id = 1;
hasBlockId() - Method in class alluxio.proto.dataserver.Protocol.ReadRequest
optional int64 block_id = 1;
hasBlockId() - Method in interface alluxio.proto.dataserver.Protocol.ReadRequestOrBuilder
optional int64 block_id = 1;
hasBlockId() - Method in class alluxio.proto.journal.Block.BlockInfoEntry.Builder
optional int64 block_id = 1;
hasBlockId() - Method in class alluxio.proto.journal.Block.BlockInfoEntry
optional int64 block_id = 1;
hasBlockId() - Method in interface alluxio.proto.journal.Block.BlockInfoEntryOrBuilder
optional int64 block_id = 1;
hasBlockId() - Method in class alluxio.proto.journal.Block.DeleteBlockEntry.Builder
optional int64 block_id = 1;
hasBlockId() - Method in class alluxio.proto.journal.Block.DeleteBlockEntry
optional int64 block_id = 1;
hasBlockId() - Method in interface alluxio.proto.journal.Block.DeleteBlockEntryOrBuilder
optional int64 block_id = 1;
hasBlockId() - Method in class alluxio.proto.journal.KeyValue.CompletePartitionEntry.Builder
optional int64 block_id = 4;
hasBlockId() - Method in class alluxio.proto.journal.KeyValue.CompletePartitionEntry
optional int64 block_id = 4;
hasBlockId() - Method in interface alluxio.proto.journal.KeyValue.CompletePartitionEntryOrBuilder
optional int64 block_id = 4;
hasBlockInfo() - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
optional .alluxio.proto.journal.BlockInfoEntry block_info = 4;
hasBlockInfo() - Method in class alluxio.proto.journal.Journal.JournalEntry
optional .alluxio.proto.journal.BlockInfoEntry block_info = 4;
hasBlockInfo() - Method in interface alluxio.proto.journal.Journal.JournalEntryOrBuilder
optional .alluxio.proto.journal.BlockInfoEntry block_info = 4;
hasBlockMeta(long) - Method in class alluxio.worker.block.BlockMetadataManager
Checks if the storage has a given block.
hasBlockMeta(long) - Method in interface alluxio.worker.block.BlockStore
Checks if the storage has a given block.
hasBlockMeta(long) - Method in interface alluxio.worker.block.BlockWorker
Checks if the storage has a given block.
hasBlockMeta(long) - Method in class alluxio.worker.block.DefaultBlockWorker
 
hasBlockMeta(long) - Method in class alluxio.worker.block.meta.StorageDir
Checks if a block is in this storage dir.
hasBlockMeta(long) - Method in class alluxio.worker.block.TieredBlockStore
 
hasBlockSize() - Method in class alluxio.proto.dataserver.Protocol.OpenUfsBlockOptions.Builder
optional int64 block_size = 3;
hasBlockSize() - Method in class alluxio.proto.dataserver.Protocol.OpenUfsBlockOptions
optional int64 block_size = 3;
hasBlockSize() - Method in interface alluxio.proto.dataserver.Protocol.OpenUfsBlockOptionsOrBuilder
optional int64 block_size = 3;
hasBlockSizeBytes() - Method in class alluxio.proto.journal.File.InodeFileEntry.Builder
optional int64 block_size_bytes = 8;
hasBlockSizeBytes() - Method in class alluxio.proto.journal.File.InodeFileEntry
optional int64 block_size_bytes = 8;
hasBlockSizeBytes() - Method in interface alluxio.proto.journal.File.InodeFileEntryOrBuilder
optional int64 block_size_bytes = 8;
hasBlockSizeBytes() - Method in class alluxio.proto.journal.File.ReinitializeFileEntry.Builder
optional int64 block_size_bytes = 2;
hasBlockSizeBytes() - Method in class alluxio.proto.journal.File.ReinitializeFileEntry
optional int64 block_size_bytes = 2;
hasBlockSizeBytes() - Method in interface alluxio.proto.journal.File.ReinitializeFileEntryOrBuilder
optional int64 block_size_bytes = 2;
hasCacheable() - Method in class alluxio.proto.journal.File.InodeFileEntry.Builder
optional bool cacheable = 11;
hasCacheable() - Method in class alluxio.proto.journal.File.InodeFileEntry
optional bool cacheable = 11;
hasCacheable() - Method in interface alluxio.proto.journal.File.InodeFileEntryOrBuilder
optional bool cacheable = 11;
hasCancel() - Method in class alluxio.proto.dataserver.Protocol.LocalBlockCompleteRequest.Builder
optional bool cancel = 2;
hasCancel() - Method in class alluxio.proto.dataserver.Protocol.LocalBlockCompleteRequest
optional bool cancel = 2;
hasCancel() - Method in interface alluxio.proto.dataserver.Protocol.LocalBlockCompleteRequestOrBuilder
optional bool cancel = 2;
hasCancel() - Method in class alluxio.proto.dataserver.Protocol.ReadRequest.Builder
optional bool cancel = 4;
hasCancel() - Method in class alluxio.proto.dataserver.Protocol.ReadRequest
optional bool cancel = 4;
hasCancel() - Method in interface alluxio.proto.dataserver.Protocol.ReadRequestOrBuilder
optional bool cancel = 4;
hasCancel() - Method in class alluxio.proto.dataserver.Protocol.WriteRequest.Builder
optional bool cancel = 6;
hasCancel() - Method in class alluxio.proto.dataserver.Protocol.WriteRequest
optional bool cancel = 6;
hasCancel() - Method in interface alluxio.proto.dataserver.Protocol.WriteRequestOrBuilder
optional bool cancel = 6;
hasCascade() - Method in class alluxio.proto.journal.Lineage.DeleteLineageEntry.Builder
optional bool cascade = 2;
hasCascade() - Method in class alluxio.proto.journal.Lineage.DeleteLineageEntry
optional bool cascade = 2;
hasCascade() - Method in interface alluxio.proto.journal.Lineage.DeleteLineageEntryOrBuilder
optional bool cascade = 2;
hasCompleted() - Method in class alluxio.proto.journal.File.InodeFileEntry.Builder
optional bool completed = 10;
hasCompleted() - Method in class alluxio.proto.journal.File.InodeFileEntry
optional bool completed = 10;
hasCompleted() - Method in interface alluxio.proto.journal.File.InodeFileEntryOrBuilder
optional bool completed = 10;
hasCompleteFile() - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
optional .alluxio.proto.journal.CompleteFileEntry complete_file = 5;
hasCompleteFile() - Method in class alluxio.proto.journal.Journal.JournalEntry
optional .alluxio.proto.journal.CompleteFileEntry complete_file = 5;
hasCompleteFile() - Method in interface alluxio.proto.journal.Journal.JournalEntryOrBuilder
optional .alluxio.proto.journal.CompleteFileEntry complete_file = 5;
hasCompletePartition() - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
optional .alluxio.proto.journal.CompletePartitionEntry complete_partition = 21;
hasCompletePartition() - Method in class alluxio.proto.journal.Journal.JournalEntry
optional .alluxio.proto.journal.CompletePartitionEntry complete_partition = 21;
hasCompletePartition() - Method in interface alluxio.proto.journal.Journal.JournalEntryOrBuilder
optional .alluxio.proto.journal.CompletePartitionEntry complete_partition = 21;
hasCompleteStore() - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
optional .alluxio.proto.journal.CompleteStoreEntry complete_store = 22;
hasCompleteStore() - Method in class alluxio.proto.journal.Journal.JournalEntry
optional .alluxio.proto.journal.CompleteStoreEntry complete_store = 22;
hasCompleteStore() - Method in interface alluxio.proto.journal.Journal.JournalEntryOrBuilder
optional .alluxio.proto.journal.CompleteStoreEntry complete_store = 22;
hasContainerId() - Method in class alluxio.proto.journal.File.InodeDirectoryIdGeneratorEntry.Builder
optional int64 container_id = 1;
hasContainerId() - Method in class alluxio.proto.journal.File.InodeDirectoryIdGeneratorEntry
optional int64 container_id = 1;
hasContainerId() - Method in interface alluxio.proto.journal.File.InodeDirectoryIdGeneratorEntryOrBuilder
optional int64 container_id = 1;
hasCreateStore() - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
optional .alluxio.proto.journal.CreateStoreEntry create_store = 23;
hasCreateStore() - Method in class alluxio.proto.journal.Journal.JournalEntry
optional .alluxio.proto.journal.CreateStoreEntry create_store = 23;
hasCreateStore() - Method in interface alluxio.proto.journal.Journal.JournalEntryOrBuilder
optional .alluxio.proto.journal.CreateStoreEntry create_store = 23;
hasCreateUfsFileOptions() - Method in class alluxio.proto.dataserver.Protocol.WriteRequest.Builder
optional .alluxio.proto.dataserver.CreateUfsFileOptions create_ufs_file_options = 7;
hasCreateUfsFileOptions() - Method in class alluxio.proto.dataserver.Protocol.WriteRequest
optional .alluxio.proto.dataserver.CreateUfsFileOptions create_ufs_file_options = 7;
hasCreateUfsFileOptions() - Method in interface alluxio.proto.dataserver.Protocol.WriteRequestOrBuilder
optional .alluxio.proto.dataserver.CreateUfsFileOptions create_ufs_file_options = 7;
hasCreationTimeMs() - Method in class alluxio.proto.journal.File.InodeDirectoryEntry.Builder
optional int64 creation_time_ms = 6;
hasCreationTimeMs() - Method in class alluxio.proto.journal.File.InodeDirectoryEntry
optional int64 creation_time_ms = 6;
hasCreationTimeMs() - Method in interface alluxio.proto.journal.File.InodeDirectoryEntryOrBuilder
optional int64 creation_time_ms = 6;
hasCreationTimeMs() - Method in class alluxio.proto.journal.File.InodeFileEntry.Builder
optional int64 creation_time_ms = 6;
hasCreationTimeMs() - Method in class alluxio.proto.journal.File.InodeFileEntry
optional int64 creation_time_ms = 6;
hasCreationTimeMs() - Method in interface alluxio.proto.journal.File.InodeFileEntryOrBuilder
optional int64 creation_time_ms = 6;
hasCreationTimeMs() - Method in class alluxio.proto.journal.Lineage.LineageEntry.Builder
optional int64 creation_time_ms = 6;
hasCreationTimeMs() - Method in class alluxio.proto.journal.Lineage.LineageEntry
optional int64 creation_time_ms = 6;
hasCreationTimeMs() - Method in interface alluxio.proto.journal.Lineage.LineageEntryOrBuilder
optional int64 creation_time_ms = 6;
hasDeleteBlock() - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
optional .alluxio.proto.journal.DeleteBlockEntry delete_block = 29;
hasDeleteBlock() - Method in class alluxio.proto.journal.Journal.JournalEntry
optional .alluxio.proto.journal.DeleteBlockEntry delete_block = 29;
hasDeleteBlock() - Method in interface alluxio.proto.journal.Journal.JournalEntryOrBuilder
optional .alluxio.proto.journal.DeleteBlockEntry delete_block = 29;
hasDeleteFile() - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
optional .alluxio.proto.journal.DeleteFileEntry delete_file = 6;
hasDeleteFile() - Method in class alluxio.proto.journal.Journal.JournalEntry
optional .alluxio.proto.journal.DeleteFileEntry delete_file = 6;
hasDeleteFile() - Method in interface alluxio.proto.journal.Journal.JournalEntryOrBuilder
optional .alluxio.proto.journal.DeleteFileEntry delete_file = 6;
hasDeleteLineage() - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
optional .alluxio.proto.journal.DeleteLineageEntry delete_lineage = 7;
hasDeleteLineage() - Method in class alluxio.proto.journal.Journal.JournalEntry
optional .alluxio.proto.journal.DeleteLineageEntry delete_lineage = 7;
hasDeleteLineage() - Method in interface alluxio.proto.journal.Journal.JournalEntryOrBuilder
optional .alluxio.proto.journal.DeleteLineageEntry delete_lineage = 7;
hasDeleteMountPoint() - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
optional .alluxio.proto.journal.DeleteMountPointEntry delete_mount_point = 8;
hasDeleteMountPoint() - Method in class alluxio.proto.journal.Journal.JournalEntry
optional .alluxio.proto.journal.DeleteMountPointEntry delete_mount_point = 8;
hasDeleteMountPoint() - Method in interface alluxio.proto.journal.Journal.JournalEntryOrBuilder
optional .alluxio.proto.journal.DeleteMountPointEntry delete_mount_point = 8;
hasDeleteStore() - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
optional .alluxio.proto.journal.DeleteStoreEntry delete_store = 25;
hasDeleteStore() - Method in class alluxio.proto.journal.Journal.JournalEntry
optional .alluxio.proto.journal.DeleteStoreEntry delete_store = 25;
hasDeleteStore() - Method in interface alluxio.proto.journal.Journal.JournalEntryOrBuilder
optional .alluxio.proto.journal.DeleteStoreEntry delete_store = 25;
hasDirectChildrenLoaded() - Method in class alluxio.proto.journal.File.InodeDirectoryEntry.Builder
optional bool direct_children_loaded = 12;
hasDirectChildrenLoaded() - Method in class alluxio.proto.journal.File.InodeDirectoryEntry
optional bool direct_children_loaded = 12;
hasDirectChildrenLoaded() - Method in interface alluxio.proto.journal.File.InodeDirectoryEntryOrBuilder
optional bool direct_children_loaded = 12;
hasDstPath() - Method in class alluxio.proto.journal.File.RenameEntry.Builder
optional string dst_path = 2;
hasDstPath() - Method in class alluxio.proto.journal.File.RenameEntry
optional string dst_path = 2;
hasDstPath() - Method in interface alluxio.proto.journal.File.RenameEntryOrBuilder
optional string dst_path = 2;
hasEof() - Method in class alluxio.proto.dataserver.Protocol.WriteRequest.Builder
optional bool eof = 5;
hasEof() - Method in class alluxio.proto.dataserver.Protocol.WriteRequest
optional bool eof = 5;
hasEof() - Method in interface alluxio.proto.dataserver.Protocol.WriteRequestOrBuilder
optional bool eof = 5;
hasFileId() - Method in class alluxio.proto.journal.File.AsyncPersistRequestEntry.Builder
optional int64 file_id = 1;
hasFileId() - Method in class alluxio.proto.journal.File.AsyncPersistRequestEntry
optional int64 file_id = 1;
hasFileId() - Method in interface alluxio.proto.journal.File.AsyncPersistRequestEntryOrBuilder
optional int64 file_id = 1;
hasFromStoreId() - Method in class alluxio.proto.journal.KeyValue.MergeStoreEntry.Builder
optional int64 from_store_id = 1;
hasFromStoreId() - Method in class alluxio.proto.journal.KeyValue.MergeStoreEntry
optional int64 from_store_id = 1;
hasFromStoreId() - Method in interface alluxio.proto.journal.KeyValue.MergeStoreEntryOrBuilder
optional int64 from_store_id = 1;
hasGroup() - Method in class alluxio.proto.dataserver.Protocol.CreateUfsFileOptions.Builder
optional string group = 3;
hasGroup() - Method in class alluxio.proto.dataserver.Protocol.CreateUfsFileOptions
optional string group = 3;
hasGroup() - Method in interface alluxio.proto.dataserver.Protocol.CreateUfsFileOptionsOrBuilder
optional string group = 3;
hasGroup() - Method in class alluxio.proto.journal.File.InodeDirectoryEntry.Builder
optional string group = 9;
hasGroup() - Method in class alluxio.proto.journal.File.InodeDirectoryEntry
optional string group = 9;
hasGroup() - Method in interface alluxio.proto.journal.File.InodeDirectoryEntryOrBuilder
optional string group = 9;
hasGroup() - Method in class alluxio.proto.journal.File.InodeFileEntry.Builder
optional string group = 15;
hasGroup() - Method in class alluxio.proto.journal.File.InodeFileEntry
optional string group = 15;
hasGroup() - Method in interface alluxio.proto.journal.File.InodeFileEntryOrBuilder
optional string group = 15;
hasGroup() - Method in class alluxio.proto.journal.File.SetAttributeEntry.Builder
optional string group = 7;
hasGroup() - Method in class alluxio.proto.journal.File.SetAttributeEntry
optional string group = 7;
hasGroup() - Method in interface alluxio.proto.journal.File.SetAttributeEntryOrBuilder
optional string group = 7;
hashCode() - Method in class alluxio.AlluxioURI
 
hashCode() - Method in class alluxio.client.block.options.GetWorkerReportOptions
 
hashCode() - Method in class alluxio.client.block.options.LockBlockOptions
 
hashCode() - Method in class alluxio.client.block.policy.DeterministicHashPolicy
 
hashCode() - Method in class alluxio.client.block.policy.options.CreateOptions
 
hashCode() - Method in class alluxio.client.block.policy.options.GetWorkerOptions
 
hashCode() - Method in class alluxio.client.file.options.CancelUfsFileOptions
 
hashCode() - Method in class alluxio.client.file.options.CheckConsistencyOptions
 
hashCode() - Method in class alluxio.client.file.options.CloseUfsFileOptions
 
hashCode() - Method in class alluxio.client.file.options.CompleteFileOptions
 
hashCode() - Method in class alluxio.client.file.options.CompleteUfsFileOptions
 
hashCode() - Method in class alluxio.client.file.options.CreateDirectoryOptions
 
hashCode() - Method in class alluxio.client.file.options.CreateFileOptions
 
hashCode() - Method in class alluxio.client.file.options.CreateUfsFileOptions
 
hashCode() - Method in class alluxio.client.file.options.DeleteOptions
 
hashCode() - Method in class alluxio.client.file.options.ExistsOptions
 
hashCode() - Method in class alluxio.client.file.options.FreeOptions
 
hashCode() - Method in class alluxio.client.file.options.GetStatusOptions
 
hashCode() - Method in class alluxio.client.file.options.InStreamOptions
 
hashCode() - Method in class alluxio.client.file.options.ListStatusOptions
 
hashCode() - Method in class alluxio.client.file.options.LoadMetadataOptions
Deprecated.
 
hashCode() - Method in class alluxio.client.file.options.MountOptions
 
hashCode() - Method in class alluxio.client.file.options.OpenFileOptions
 
hashCode() - Method in class alluxio.client.file.options.OpenUfsFileOptions
 
hashCode() - Method in class alluxio.client.file.options.OutStreamOptions
 
hashCode() - Method in class alluxio.client.file.options.RenameOptions
 
hashCode() - Method in class alluxio.client.file.options.SetAttributeOptions
 
hashCode() - Method in class alluxio.client.file.options.UnmountOptions
 
hashCode() - Method in class alluxio.client.file.options.UpdateUfsModeOptions
 
hashCode() - Method in class alluxio.client.file.policy.LocalFirstAvoidEvictionPolicy
 
hashCode() - Method in class alluxio.client.file.policy.LocalFirstPolicy
 
hashCode() - Method in class alluxio.client.file.policy.MostAvailableFirstPolicy
 
hashCode() - Method in class alluxio.client.file.policy.RoundRobinPolicy
 
hashCode() - Method in class alluxio.client.file.policy.SpecificHostPolicy
 
hashCode() - Method in class alluxio.client.file.URIStatus
 
hashCode() - Method in class alluxio.client.keyvalue.KeyValuePair
 
hashCode() - Method in class alluxio.client.lineage.options.CreateLineageOptions
 
hashCode() - Method in class alluxio.client.lineage.options.DeleteLineageOptions
 
hashCode() - Method in class alluxio.client.lineage.options.GetLineageInfoListOptions
 
hashCode() - Method in class alluxio.collections.Pair
 
hashCode() - Method in class alluxio.master.block.meta.MasterBlockLocation
 
hashCode() - Method in class alluxio.master.file.meta.Inode
 
hashCode() - Method in class alluxio.master.file.meta.InodeTree
 
hashCode() - Method in class alluxio.master.file.meta.options.MountInfo
 
hashCode() - Method in class alluxio.master.file.meta.TtlBucket
Returns the hash code for the TtlBucket.
hashCode() - Method in class alluxio.master.file.options.CheckConsistencyOptions
 
hashCode() - Method in class alluxio.master.file.options.CompleteFileOptions
 
hashCode() - Method in class alluxio.master.file.options.CreateDirectoryOptions
 
hashCode() - Method in class alluxio.master.file.options.CreateFileOptions
 
hashCode() - Method in class alluxio.master.file.options.CreatePathOptions
 
hashCode() - Method in class alluxio.master.file.options.DeleteOptions
 
hashCode() - Method in class alluxio.master.file.options.FreeOptions
 
hashCode() - Method in class alluxio.master.file.options.GetStatusOptions
 
hashCode() - Method in class alluxio.master.file.options.ListStatusOptions
 
hashCode() - Method in class alluxio.master.file.options.LoadMetadataOptions
 
hashCode() - Method in class alluxio.master.file.options.MountOptions
 
hashCode() - Method in class alluxio.master.file.options.RenameOptions
 
hashCode() - Method in class alluxio.master.file.options.SetAttributeOptions
 
hashCode() - Method in class alluxio.master.file.options.SyncMetadataOptions
 
hashCode() - Method in class alluxio.master.file.options.WorkerHeartbeatOptions
 
hashCode() - Method in class alluxio.master.journal.options.JournalReaderOptions
 
hashCode() - Method in class alluxio.master.journal.options.JournalWriterOptions
 
hashCode() - Method in class alluxio.master.PollingMasterInquireClient.MultiMasterConnectDetails
 
hashCode() - Method in class alluxio.master.SingleMasterInquireClient.SingleMasterConnectDetails
 
hashCode() - Method in class alluxio.master.ZkMasterInquireClient.ZkMasterConnectDetails
 
hashCode() - Method in class alluxio.metrics.Metric
 
hashCode() - Method in class alluxio.metrics.MetricsFilter
 
hashCode() - Method in class alluxio.PropertyKey
 
hashCode() - Method in class alluxio.proxy.s3.ListBucketOptions
 
hashCode() - Method in class alluxio.security.authorization.Mode
 
hashCode() - Method in class alluxio.security.User
 
hashCode() - Method in class alluxio.SessionInfo
 
hashCode() - Method in class alluxio.StandardURI
 
hashCode() - Method in class alluxio.thrift.AccessBlockTOptions
 
hashCode() - Method in class alluxio.thrift.AccessBlockTResponse
 
hashCode() - Method in class alluxio.thrift.AlluxioService.getServiceVersion_args
 
hashCode() - Method in class alluxio.thrift.AlluxioService.getServiceVersion_result
 
hashCode() - Method in exception alluxio.thrift.AlluxioTException
 
hashCode() - Method in class alluxio.thrift.BackupTOptions
 
hashCode() - Method in class alluxio.thrift.BackupTResponse
 
hashCode() - Method in class alluxio.thrift.BlockHeartbeatTOptions
 
hashCode() - Method in class alluxio.thrift.BlockHeartbeatTResponse
 
hashCode() - Method in class alluxio.thrift.BlockInfo
 
hashCode() - Method in class alluxio.thrift.BlockLocation
 
hashCode() - Method in class alluxio.thrift.BlockMasterClientService.getBlockInfo_args
 
hashCode() - Method in class alluxio.thrift.BlockMasterClientService.getBlockInfo_result
 
hashCode() - Method in class alluxio.thrift.BlockMasterClientService.getBlockMasterInfo_args
 
hashCode() - Method in class alluxio.thrift.BlockMasterClientService.getBlockMasterInfo_result
 
hashCode() - Method in class alluxio.thrift.BlockMasterClientService.getCapacityBytes_args
 
hashCode() - Method in class alluxio.thrift.BlockMasterClientService.getCapacityBytes_result
 
hashCode() - Method in class alluxio.thrift.BlockMasterClientService.getUsedBytes_args
 
hashCode() - Method in class alluxio.thrift.BlockMasterClientService.getUsedBytes_result
 
hashCode() - Method in class alluxio.thrift.BlockMasterClientService.getWorkerInfoList_args
 
hashCode() - Method in class alluxio.thrift.BlockMasterClientService.getWorkerInfoList_result
 
hashCode() - Method in class alluxio.thrift.BlockMasterClientService.getWorkerReport_args
 
hashCode() - Method in class alluxio.thrift.BlockMasterClientService.getWorkerReport_result
 
hashCode() - Method in class alluxio.thrift.BlockMasterInfo
 
hashCode() - Method in class alluxio.thrift.BlockMasterWorkerService.blockHeartbeat_args
 
hashCode() - Method in class alluxio.thrift.BlockMasterWorkerService.blockHeartbeat_result
 
hashCode() - Method in class alluxio.thrift.BlockMasterWorkerService.commitBlock_args
 
hashCode() - Method in class alluxio.thrift.BlockMasterWorkerService.commitBlock_result
 
hashCode() - Method in class alluxio.thrift.BlockMasterWorkerService.getWorkerId_args
 
hashCode() - Method in class alluxio.thrift.BlockMasterWorkerService.getWorkerId_result
 
hashCode() - Method in class alluxio.thrift.BlockMasterWorkerService.registerWorker_args
 
hashCode() - Method in class alluxio.thrift.BlockMasterWorkerService.registerWorker_result
 
hashCode() - Method in class alluxio.thrift.BlockWorkerClientService.accessBlock_args
 
hashCode() - Method in class alluxio.thrift.BlockWorkerClientService.accessBlock_result
 
hashCode() - Method in class alluxio.thrift.BlockWorkerClientService.cacheBlock_args
 
hashCode() - Method in class alluxio.thrift.BlockWorkerClientService.cacheBlock_result
 
hashCode() - Method in class alluxio.thrift.BlockWorkerClientService.cancelBlock_args
 
hashCode() - Method in class alluxio.thrift.BlockWorkerClientService.cancelBlock_result
 
hashCode() - Method in class alluxio.thrift.BlockWorkerClientService.lockBlock_args
 
hashCode() - Method in class alluxio.thrift.BlockWorkerClientService.lockBlock_result
 
hashCode() - Method in class alluxio.thrift.BlockWorkerClientService.promoteBlock_args
 
hashCode() - Method in class alluxio.thrift.BlockWorkerClientService.promoteBlock_result
 
hashCode() - Method in class alluxio.thrift.BlockWorkerClientService.removeBlock_args
 
hashCode() - Method in class alluxio.thrift.BlockWorkerClientService.removeBlock_result
 
hashCode() - Method in class alluxio.thrift.BlockWorkerClientService.requestBlockLocation_args
 
hashCode() - Method in class alluxio.thrift.BlockWorkerClientService.requestBlockLocation_result
 
hashCode() - Method in class alluxio.thrift.BlockWorkerClientService.requestSpace_args
 
hashCode() - Method in class alluxio.thrift.BlockWorkerClientService.requestSpace_result
 
hashCode() - Method in class alluxio.thrift.BlockWorkerClientService.sessionBlockHeartbeat_args
 
hashCode() - Method in class alluxio.thrift.BlockWorkerClientService.sessionBlockHeartbeat_result
 
hashCode() - Method in class alluxio.thrift.BlockWorkerClientService.unlockBlock_args
 
hashCode() - Method in class alluxio.thrift.BlockWorkerClientService.unlockBlock_result
 
hashCode() - Method in class alluxio.thrift.CacheBlockTOptions
 
hashCode() - Method in class alluxio.thrift.CacheBlockTResponse
 
hashCode() - Method in class alluxio.thrift.CancelBlockTOptions
 
hashCode() - Method in class alluxio.thrift.CancelBlockTResponse
 
hashCode() - Method in class alluxio.thrift.CancelUfsFileTOptions
 
hashCode() - Method in class alluxio.thrift.CancelUfsFileTResponse
 
hashCode() - Method in class alluxio.thrift.CheckConsistencyTOptions
 
hashCode() - Method in class alluxio.thrift.CheckConsistencyTResponse
 
hashCode() - Method in class alluxio.thrift.CloseUfsFileTOptions
 
hashCode() - Method in class alluxio.thrift.CloseUfsFileTResponse
 
hashCode() - Method in class alluxio.thrift.Command
 
hashCode() - Method in class alluxio.thrift.CommandLineJobInfo
 
hashCode() - Method in class alluxio.thrift.CommitBlockTOptions
 
hashCode() - Method in class alluxio.thrift.CommitBlockTResponse
 
hashCode() - Method in class alluxio.thrift.CompleteFileTOptions
 
hashCode() - Method in class alluxio.thrift.CompleteFileTResponse
 
hashCode() - Method in class alluxio.thrift.CompletePartitionTOptions
 
hashCode() - Method in class alluxio.thrift.CompletePartitionTResponse
 
hashCode() - Method in class alluxio.thrift.CompleteStoreTOptions
 
hashCode() - Method in class alluxio.thrift.CompleteStoreTResponse
 
hashCode() - Method in class alluxio.thrift.CompleteUfsFileTOptions
 
hashCode() - Method in class alluxio.thrift.CompleteUfsFileTReponse
 
hashCode() - Method in class alluxio.thrift.ConfigCheckReport
 
hashCode() - Method in class alluxio.thrift.ConfigProperty
 
hashCode() - Method in class alluxio.thrift.CreateDirectoryTOptions
 
hashCode() - Method in class alluxio.thrift.CreateDirectoryTResponse
 
hashCode() - Method in class alluxio.thrift.CreateFileTOptions
 
hashCode() - Method in class alluxio.thrift.CreateFileTResponse
 
hashCode() - Method in class alluxio.thrift.CreateLineageTOptions
 
hashCode() - Method in class alluxio.thrift.CreateLineageTResponse
 
hashCode() - Method in class alluxio.thrift.CreateStoreTOptions
 
hashCode() - Method in class alluxio.thrift.CreateStoreTResponse
 
hashCode() - Method in class alluxio.thrift.CreateUfsFileTOptions
 
hashCode() - Method in class alluxio.thrift.CreateUfsFileTResponse
 
hashCode() - Method in class alluxio.thrift.DeleteLineageTOptions
 
hashCode() - Method in class alluxio.thrift.DeleteLineageTResponse
 
hashCode() - Method in class alluxio.thrift.DeleteStoreTOptions
 
hashCode() - Method in class alluxio.thrift.DeleteStoreTResponse
 
hashCode() - Method in class alluxio.thrift.DeleteTOptions
 
hashCode() - Method in class alluxio.thrift.DeleteTResponse
 
hashCode() - Method in class alluxio.thrift.DependencyInfo
 
hashCode() - Method in class alluxio.thrift.FileBlockInfo
 
hashCode() - Method in class alluxio.thrift.FileInfo
 
hashCode() - Method in class alluxio.thrift.FileSystemCommand
 
hashCode() - Method in class alluxio.thrift.FileSystemCommandOptions
 
hashCode() - Method in class alluxio.thrift.FileSystemHeartbeatTOptions
 
hashCode() - Method in class alluxio.thrift.FileSystemHeartbeatTResponse
 
hashCode() - Method in class alluxio.thrift.FileSystemMasterClientService.checkConsistency_args
 
hashCode() - Method in class alluxio.thrift.FileSystemMasterClientService.checkConsistency_result
 
hashCode() - Method in class alluxio.thrift.FileSystemMasterClientService.completeFile_args
 
hashCode() - Method in class alluxio.thrift.FileSystemMasterClientService.completeFile_result
 
hashCode() - Method in class alluxio.thrift.FileSystemMasterClientService.createDirectory_args
 
hashCode() - Method in class alluxio.thrift.FileSystemMasterClientService.createDirectory_result
 
hashCode() - Method in class alluxio.thrift.FileSystemMasterClientService.createFile_args
 
hashCode() - Method in class alluxio.thrift.FileSystemMasterClientService.createFile_result
 
hashCode() - Method in class alluxio.thrift.FileSystemMasterClientService.free_args
 
hashCode() - Method in class alluxio.thrift.FileSystemMasterClientService.free_result
 
hashCode() - Method in class alluxio.thrift.FileSystemMasterClientService.getFilePath_args
 
hashCode() - Method in class alluxio.thrift.FileSystemMasterClientService.getFilePath_result
 
hashCode() - Method in class alluxio.thrift.FileSystemMasterClientService.getMountTable_args
 
hashCode() - Method in class alluxio.thrift.FileSystemMasterClientService.getMountTable_result
 
hashCode() - Method in class alluxio.thrift.FileSystemMasterClientService.getNewBlockIdForFile_args
 
hashCode() - Method in class alluxio.thrift.FileSystemMasterClientService.getNewBlockIdForFile_result
 
hashCode() - Method in class alluxio.thrift.FileSystemMasterClientService.getStatus_args
 
hashCode() - Method in class alluxio.thrift.FileSystemMasterClientService.getStatus_result
 
hashCode() - Method in class alluxio.thrift.FileSystemMasterClientService.listStatus_args
 
hashCode() - Method in class alluxio.thrift.FileSystemMasterClientService.listStatus_result
 
hashCode() - Method in class alluxio.thrift.FileSystemMasterClientService.loadMetadata_args
 
hashCode() - Method in class alluxio.thrift.FileSystemMasterClientService.loadMetadata_result
 
hashCode() - Method in class alluxio.thrift.FileSystemMasterClientService.mount_args
 
hashCode() - Method in class alluxio.thrift.FileSystemMasterClientService.mount_result
 
hashCode() - Method in class alluxio.thrift.FileSystemMasterClientService.remove_args
 
hashCode() - Method in class alluxio.thrift.FileSystemMasterClientService.remove_result
 
hashCode() - Method in class alluxio.thrift.FileSystemMasterClientService.rename_args
 
hashCode() - Method in class alluxio.thrift.FileSystemMasterClientService.rename_result
 
hashCode() - Method in class alluxio.thrift.FileSystemMasterClientService.scheduleAsyncPersistence_args
 
hashCode() - Method in class alluxio.thrift.FileSystemMasterClientService.scheduleAsyncPersistence_result
 
hashCode() - Method in class alluxio.thrift.FileSystemMasterClientService.setAttribute_args
 
hashCode() - Method in class alluxio.thrift.FileSystemMasterClientService.setAttribute_result
 
hashCode() - Method in class alluxio.thrift.FileSystemMasterClientService.unmount_args
 
hashCode() - Method in class alluxio.thrift.FileSystemMasterClientService.unmount_result
 
hashCode() - Method in class alluxio.thrift.FileSystemMasterClientService.updateUfsMode_args
 
hashCode() - Method in class alluxio.thrift.FileSystemMasterClientService.updateUfsMode_result
 
hashCode() - Method in class alluxio.thrift.FileSystemMasterCommonTOptions
 
hashCode() - Method in class alluxio.thrift.FileSystemMasterWorkerService.fileSystemHeartbeat_args
 
hashCode() - Method in class alluxio.thrift.FileSystemMasterWorkerService.fileSystemHeartbeat_result
 
hashCode() - Method in class alluxio.thrift.FileSystemMasterWorkerService.getFileInfo_args
 
hashCode() - Method in class alluxio.thrift.FileSystemMasterWorkerService.getFileInfo_result
 
hashCode() - Method in class alluxio.thrift.FileSystemMasterWorkerService.getPinnedFileIds_args
 
hashCode() - Method in class alluxio.thrift.FileSystemMasterWorkerService.getPinnedFileIds_result
 
hashCode() - Method in class alluxio.thrift.FileSystemMasterWorkerService.getUfsInfo_args
 
hashCode() - Method in class alluxio.thrift.FileSystemMasterWorkerService.getUfsInfo_result
 
hashCode() - Method in class alluxio.thrift.FileSystemWorkerClientService.cancelUfsFile_args
 
hashCode() - Method in class alluxio.thrift.FileSystemWorkerClientService.cancelUfsFile_result
 
hashCode() - Method in class alluxio.thrift.FileSystemWorkerClientService.closeUfsFile_args
 
hashCode() - Method in class alluxio.thrift.FileSystemWorkerClientService.closeUfsFile_result
 
hashCode() - Method in class alluxio.thrift.FileSystemWorkerClientService.completeUfsFile_args
 
hashCode() - Method in class alluxio.thrift.FileSystemWorkerClientService.completeUfsFile_result
 
hashCode() - Method in class alluxio.thrift.FileSystemWorkerClientService.createUfsFile_args
 
hashCode() - Method in class alluxio.thrift.FileSystemWorkerClientService.createUfsFile_result
 
hashCode() - Method in class alluxio.thrift.FileSystemWorkerClientService.openUfsFile_args
 
hashCode() - Method in class alluxio.thrift.FileSystemWorkerClientService.openUfsFile_result
 
hashCode() - Method in class alluxio.thrift.FileSystemWorkerClientService.sessionFileSystemHeartbeat_args
 
hashCode() - Method in class alluxio.thrift.FileSystemWorkerClientService.sessionFileSystemHeartbeat_result
 
hashCode() - Method in class alluxio.thrift.FreeTOptions
 
hashCode() - Method in class alluxio.thrift.FreeTResponse
 
hashCode() - Method in class alluxio.thrift.GetBlockInfoTOptions
 
hashCode() - Method in class alluxio.thrift.GetBlockInfoTResponse
 
hashCode() - Method in class alluxio.thrift.GetBlockMasterInfoTOptions
 
hashCode() - Method in class alluxio.thrift.GetBlockMasterInfoTResponse
 
hashCode() - Method in class alluxio.thrift.GetCapacityBytesTOptions
 
hashCode() - Method in class alluxio.thrift.GetCapacityBytesTResponse
 
hashCode() - Method in class alluxio.thrift.GetConfigReportTOptions
 
hashCode() - Method in class alluxio.thrift.GetConfigReportTResponse
 
hashCode() - Method in class alluxio.thrift.GetConfigurationTOptions
 
hashCode() - Method in class alluxio.thrift.GetConfigurationTResponse
 
hashCode() - Method in class alluxio.thrift.GetFileInfoTOptions
 
hashCode() - Method in class alluxio.thrift.GetFileInfoTResponse
 
hashCode() - Method in class alluxio.thrift.GetFilePathTOptions
 
hashCode() - Method in class alluxio.thrift.GetFilePathTResponse
 
hashCode() - Method in class alluxio.thrift.GetLineageInfoListTOptions
 
hashCode() - Method in class alluxio.thrift.GetLineageInfoListTResponse
 
hashCode() - Method in class alluxio.thrift.GetMasterIdTOptions
 
hashCode() - Method in class alluxio.thrift.GetMasterIdTResponse
 
hashCode() - Method in class alluxio.thrift.GetMasterInfoTOptions
 
hashCode() - Method in class alluxio.thrift.GetMasterInfoTResponse
 
hashCode() - Method in class alluxio.thrift.GetMetricsTOptions
 
hashCode() - Method in class alluxio.thrift.GetMetricsTResponse
 
hashCode() - Method in class alluxio.thrift.GetMountTableTResponse
 
hashCode() - Method in class alluxio.thrift.GetNewBlockIdForFileTOptions
 
hashCode() - Method in class alluxio.thrift.GetNewBlockIdForFileTResponse
 
hashCode() - Method in class alluxio.thrift.GetNextKeysTOptions
 
hashCode() - Method in class alluxio.thrift.GetNextKeysTResponse
 
hashCode() - Method in class alluxio.thrift.GetPartitionInfoTOptions
 
hashCode() - Method in class alluxio.thrift.GetPartitionInfoTResponse
 
hashCode() - Method in class alluxio.thrift.GetPinnedFileIdsTOptions
 
hashCode() - Method in class alluxio.thrift.GetPinnedFileIdsTResponse
 
hashCode() - Method in class alluxio.thrift.GetServiceVersionTOptions
 
hashCode() - Method in class alluxio.thrift.GetServiceVersionTResponse
 
hashCode() - Method in class alluxio.thrift.GetSizeTOptions
 
hashCode() - Method in class alluxio.thrift.GetSizeTResponse
 
hashCode() - Method in class alluxio.thrift.GetStatusTOptions
 
hashCode() - Method in class alluxio.thrift.GetStatusTResponse
 
hashCode() - Method in class alluxio.thrift.GetTOptions
 
hashCode() - Method in class alluxio.thrift.GetTResponse
 
hashCode() - Method in class alluxio.thrift.GetUfsInfoTOptions
 
hashCode() - Method in class alluxio.thrift.GetUfsInfoTResponse
 
hashCode() - Method in class alluxio.thrift.GetUsedBytesTOptions
 
hashCode() - Method in class alluxio.thrift.GetUsedBytesTResponse
 
hashCode() - Method in class alluxio.thrift.GetWorkerIdTOptions
 
hashCode() - Method in class alluxio.thrift.GetWorkerIdTResponse
 
hashCode() - Method in class alluxio.thrift.GetWorkerInfoListTOptions
 
hashCode() - Method in class alluxio.thrift.GetWorkerInfoListTResponse
 
hashCode() - Method in class alluxio.thrift.GetWorkerReportTOptions
 
hashCode() - Method in class alluxio.thrift.InconsistentProperty
 
hashCode() - Method in class alluxio.thrift.JobConfInfo
 
hashCode() - Method in class alluxio.thrift.KeyValueMasterClientService.completePartition_args
 
hashCode() - Method in class alluxio.thrift.KeyValueMasterClientService.completePartition_result
 
hashCode() - Method in class alluxio.thrift.KeyValueMasterClientService.completeStore_args
 
hashCode() - Method in class alluxio.thrift.KeyValueMasterClientService.completeStore_result
 
hashCode() - Method in class alluxio.thrift.KeyValueMasterClientService.createStore_args
 
hashCode() - Method in class alluxio.thrift.KeyValueMasterClientService.createStore_result
 
hashCode() - Method in class alluxio.thrift.KeyValueMasterClientService.deleteStore_args
 
hashCode() - Method in class alluxio.thrift.KeyValueMasterClientService.deleteStore_result
 
hashCode() - Method in class alluxio.thrift.KeyValueMasterClientService.getPartitionInfo_args
 
hashCode() - Method in class alluxio.thrift.KeyValueMasterClientService.getPartitionInfo_result
 
hashCode() - Method in class alluxio.thrift.KeyValueMasterClientService.mergeStore_args
 
hashCode() - Method in class alluxio.thrift.KeyValueMasterClientService.mergeStore_result
 
hashCode() - Method in class alluxio.thrift.KeyValueMasterClientService.renameStore_args
 
hashCode() - Method in class alluxio.thrift.KeyValueMasterClientService.renameStore_result
 
hashCode() - Method in class alluxio.thrift.KeyValueWorkerClientService.get_args
 
hashCode() - Method in class alluxio.thrift.KeyValueWorkerClientService.get_result
 
hashCode() - Method in class alluxio.thrift.KeyValueWorkerClientService.getNextKeys_args
 
hashCode() - Method in class alluxio.thrift.KeyValueWorkerClientService.getNextKeys_result
 
hashCode() - Method in class alluxio.thrift.KeyValueWorkerClientService.getSize_args
 
hashCode() - Method in class alluxio.thrift.KeyValueWorkerClientService.getSize_result
 
hashCode() - Method in class alluxio.thrift.LineageInfo
 
hashCode() - Method in class alluxio.thrift.LineageMasterClientService.createLineage_args
 
hashCode() - Method in class alluxio.thrift.LineageMasterClientService.createLineage_result
 
hashCode() - Method in class alluxio.thrift.LineageMasterClientService.deleteLineage_args
 
hashCode() - Method in class alluxio.thrift.LineageMasterClientService.deleteLineage_result
 
hashCode() - Method in class alluxio.thrift.LineageMasterClientService.getLineageInfoList_args
 
hashCode() - Method in class alluxio.thrift.LineageMasterClientService.getLineageInfoList_result
 
hashCode() - Method in class alluxio.thrift.LineageMasterClientService.reinitializeFile_args
 
hashCode() - Method in class alluxio.thrift.LineageMasterClientService.reinitializeFile_result
 
hashCode() - Method in class alluxio.thrift.LineageMasterClientService.reportLostFile_args
 
hashCode() - Method in class alluxio.thrift.LineageMasterClientService.reportLostFile_result
 
hashCode() - Method in class alluxio.thrift.ListStatusTOptions
 
hashCode() - Method in class alluxio.thrift.ListStatusTResponse
 
hashCode() - Method in class alluxio.thrift.LoadMetadataTOptions
 
hashCode() - Method in class alluxio.thrift.LoadMetadataTResponse
 
hashCode() - Method in class alluxio.thrift.LocalityTier
 
hashCode() - Method in class alluxio.thrift.LockBlockTOptions
 
hashCode() - Method in class alluxio.thrift.LockBlockTResponse
 
hashCode() - Method in class alluxio.thrift.MasterHeartbeatTOptions
 
hashCode() - Method in class alluxio.thrift.MasterHeartbeatTResponse
 
hashCode() - Method in class alluxio.thrift.MasterInfo
 
hashCode() - Method in class alluxio.thrift.MasterNetAddress
 
hashCode() - Method in class alluxio.thrift.MergeStoreTOptions
 
hashCode() - Method in class alluxio.thrift.MergeStoreTResponse
 
hashCode() - Method in class alluxio.thrift.MetaMasterClientService.backup_args
 
hashCode() - Method in class alluxio.thrift.MetaMasterClientService.backup_result
 
hashCode() - Method in class alluxio.thrift.MetaMasterClientService.getConfigReport_args
 
hashCode() - Method in class alluxio.thrift.MetaMasterClientService.getConfigReport_result
 
hashCode() - Method in class alluxio.thrift.MetaMasterClientService.getConfiguration_args
 
hashCode() - Method in class alluxio.thrift.MetaMasterClientService.getConfiguration_result
 
hashCode() - Method in class alluxio.thrift.MetaMasterClientService.getMasterInfo_args
 
hashCode() - Method in class alluxio.thrift.MetaMasterClientService.getMasterInfo_result
 
hashCode() - Method in class alluxio.thrift.MetaMasterClientService.getMetrics_args
 
hashCode() - Method in class alluxio.thrift.MetaMasterClientService.getMetrics_result
 
hashCode() - Method in class alluxio.thrift.MetaMasterMasterService.getMasterId_args
 
hashCode() - Method in class alluxio.thrift.MetaMasterMasterService.getMasterId_result
 
hashCode() - Method in class alluxio.thrift.MetaMasterMasterService.masterHeartbeat_args
 
hashCode() - Method in class alluxio.thrift.MetaMasterMasterService.masterHeartbeat_result
 
hashCode() - Method in class alluxio.thrift.MetaMasterMasterService.registerMaster_args
 
hashCode() - Method in class alluxio.thrift.MetaMasterMasterService.registerMaster_result
 
hashCode() - Method in class alluxio.thrift.Metric
 
hashCode() - Method in class alluxio.thrift.MetricsHeartbeatTOptions
 
hashCode() - Method in class alluxio.thrift.MetricsHeartbeatTResponse
 
hashCode() - Method in class alluxio.thrift.MetricsMasterClientService.metricsHeartbeat_args
 
hashCode() - Method in class alluxio.thrift.MetricsMasterClientService.metricsHeartbeat_result
 
hashCode() - Method in class alluxio.thrift.MetricValue
 
hashCode() - Method in class alluxio.thrift.MountPointInfo
 
hashCode() - Method in class alluxio.thrift.MountTOptions
 
hashCode() - Method in class alluxio.thrift.MountTResponse
 
hashCode() - Method in class alluxio.thrift.OpenUfsFileTOptions
 
hashCode() - Method in class alluxio.thrift.OpenUfsFileTResponse
 
hashCode() - Method in class alluxio.thrift.OptionalString
 
hashCode() - Method in class alluxio.thrift.PartitionInfo
 
hashCode() - Method in class alluxio.thrift.PersistCommandOptions
 
hashCode() - Method in class alluxio.thrift.PersistFile
 
hashCode() - Method in class alluxio.thrift.PromoteBlockTOptions
 
hashCode() - Method in class alluxio.thrift.PromoteBlockTResponse
 
hashCode() - Method in class alluxio.thrift.RegisterMasterTOptions
 
hashCode() - Method in class alluxio.thrift.RegisterMasterTResponse
 
hashCode() - Method in class alluxio.thrift.RegisterWorkerTOptions
 
hashCode() - Method in class alluxio.thrift.RegisterWorkerTResponse
 
hashCode() - Method in class alluxio.thrift.ReinitializeFileTOptions
 
hashCode() - Method in class alluxio.thrift.ReinitializeFileTResponse
 
hashCode() - Method in class alluxio.thrift.RemoveBlockTOptions
 
hashCode() - Method in class alluxio.thrift.RemoveBlockTResponse
 
hashCode() - Method in class alluxio.thrift.RenameStoreTOptions
 
hashCode() - Method in class alluxio.thrift.RenameStoreTResponse
 
hashCode() - Method in class alluxio.thrift.RenameTOptions
 
hashCode() - Method in class alluxio.thrift.RenameTResponse
 
hashCode() - Method in class alluxio.thrift.ReportLostFileTOptions
 
hashCode() - Method in class alluxio.thrift.ReportLostFileTResponse
 
hashCode() - Method in class alluxio.thrift.RequestBlockLocationTOptions
 
hashCode() - Method in class alluxio.thrift.RequestBlockLocationTResponse
 
hashCode() - Method in class alluxio.thrift.RequestSpaceTOptions
 
hashCode() - Method in class alluxio.thrift.RequestSpaceTResponse
 
hashCode() - Method in class alluxio.thrift.ScheduleAsyncPersistenceTOptions
 
hashCode() - Method in class alluxio.thrift.ScheduleAsyncPersistenceTResponse
 
hashCode() - Method in class alluxio.thrift.SessionBlockHeartbeatTOptions
 
hashCode() - Method in class alluxio.thrift.SessionBlockHeartbeatTResponse
 
hashCode() - Method in class alluxio.thrift.SessionFileSystemHeartbeatTOptions
 
hashCode() - Method in class alluxio.thrift.SessionFileSystemHeartbeatTResponse
 
hashCode() - Method in class alluxio.thrift.SetAttributeTOptions
 
hashCode() - Method in class alluxio.thrift.SetAttributeTResponse
 
hashCode() - Method in class alluxio.thrift.SyncMetadataTOptions
 
hashCode() - Method in class alluxio.thrift.SyncMetadataTResponse
 
hashCode() - Method in class alluxio.thrift.TieredIdentity
 
hashCode() - Method in class alluxio.thrift.UfsInfo
 
hashCode() - Method in class alluxio.thrift.UnlockBlockTOptions
 
hashCode() - Method in class alluxio.thrift.UnlockBlockTResponse
 
hashCode() - Method in class alluxio.thrift.UnmountTOptions
 
hashCode() - Method in class alluxio.thrift.UnmountTResponse
 
hashCode() - Method in class alluxio.thrift.UpdateUfsModeTOptions
 
hashCode() - Method in class alluxio.thrift.UpdateUfsModeTResponse
 
hashCode() - Method in class alluxio.thrift.WorkerInfo
 
hashCode() - Method in class alluxio.thrift.WorkerNetAddress
 
hashCode() - Method in class alluxio.underfs.AbstractUfsManager.Key
 
hashCode() - Method in class alluxio.underfs.options.CreateOptions
 
hashCode() - Method in class alluxio.underfs.options.DeleteOptions
 
hashCode() - Method in class alluxio.underfs.options.FileLocationOptions
 
hashCode() - Method in class alluxio.underfs.options.ListOptions
 
hashCode() - Method in class alluxio.underfs.options.MkdirsOptions
 
hashCode() - Method in class alluxio.underfs.options.OpenOptions
 
hashCode() - Method in class alluxio.underfs.UfsStatus
 
hashCode() - Method in class alluxio.util.UnixMountInfo
 
hashCode() - Method in class alluxio.util.UnixMountInfo.Options
 
hashCode() - Method in class alluxio.util.WaitForOptions
 
hashCode() - Method in class alluxio.web.WebInterfaceWorkersServlet.NodeInfo
 
hashCode() - Method in class alluxio.wire.Address
 
hashCode() - Method in class alluxio.wire.AlluxioMasterInfo
 
hashCode() - Method in class alluxio.wire.AlluxioProxyInfo
 
hashCode() - Method in class alluxio.wire.AlluxioWorkerInfo
 
hashCode() - Method in class alluxio.wire.BlockInfo
 
hashCode() - Method in class alluxio.wire.BlockLocation
 
hashCode() - Method in class alluxio.wire.BlockMasterInfo
 
hashCode() - Method in class alluxio.wire.Capacity
 
hashCode() - Method in class alluxio.wire.CommandLineJobInfo
 
hashCode() - Method in class alluxio.wire.CommonOptions
 
hashCode() - Method in class alluxio.wire.ConfigProperty
 
hashCode() - Method in class alluxio.wire.FileBlockInfo
 
hashCode() - Method in class alluxio.wire.FileInfo
 
hashCode() - Method in class alluxio.wire.GetConfigurationOptions
 
hashCode() - Method in class alluxio.wire.InconsistentProperty
 
hashCode() - Method in class alluxio.wire.JobConfInfo
 
hashCode() - Method in class alluxio.wire.LineageInfo
 
hashCode() - Method in class alluxio.wire.MasterInfo
 
hashCode() - Method in class alluxio.wire.MountPointInfo
 
hashCode() - Method in class alluxio.wire.StartupConsistencyCheck
 
hashCode() - Method in class alluxio.wire.TieredIdentity
 
hashCode() - Method in class alluxio.wire.TieredIdentity.LocalityTier
 
hashCode() - Method in class alluxio.wire.WorkerInfo
 
hashCode() - Method in class alluxio.wire.WorkerNetAddress
 
hashCode() - Method in class alluxio.worker.block.BlockStoreLocation
 
hasId() - Method in class alluxio.proto.dataserver.Protocol.WriteRequest.Builder
optional int64 id = 2;
hasId() - Method in class alluxio.proto.dataserver.Protocol.WriteRequest
optional int64 id = 2;
hasId() - Method in interface alluxio.proto.dataserver.Protocol.WriteRequestOrBuilder
optional int64 id = 2;
hasId() - Method in class alluxio.proto.journal.File.CompleteFileEntry.Builder
optional int64 id = 2;
hasId() - Method in class alluxio.proto.journal.File.CompleteFileEntry
optional int64 id = 2;
hasId() - Method in interface alluxio.proto.journal.File.CompleteFileEntryOrBuilder
optional int64 id = 2;
hasId() - Method in class alluxio.proto.journal.File.DeleteFileEntry.Builder
optional int64 id = 1;
hasId() - Method in class alluxio.proto.journal.File.DeleteFileEntry
optional int64 id = 1;
hasId() - Method in interface alluxio.proto.journal.File.DeleteFileEntryOrBuilder
optional int64 id = 1;
hasId() - Method in class alluxio.proto.journal.File.InodeDirectoryEntry.Builder
optional int64 id = 1;
hasId() - Method in class alluxio.proto.journal.File.InodeDirectoryEntry
optional int64 id = 1;
hasId() - Method in interface alluxio.proto.journal.File.InodeDirectoryEntryOrBuilder
optional int64 id = 1;
hasId() - Method in class alluxio.proto.journal.File.InodeFileEntry.Builder
optional int64 id = 1;
hasId() - Method in class alluxio.proto.journal.File.InodeFileEntry
optional int64 id = 1;
hasId() - Method in interface alluxio.proto.journal.File.InodeFileEntryOrBuilder
optional int64 id = 1;
hasId() - Method in class alluxio.proto.journal.File.InodeLastModificationTimeEntry.Builder
optional int64 id = 1;
hasId() - Method in class alluxio.proto.journal.File.InodeLastModificationTimeEntry
optional int64 id = 1;
hasId() - Method in interface alluxio.proto.journal.File.InodeLastModificationTimeEntryOrBuilder
optional int64 id = 1;
hasId() - Method in class alluxio.proto.journal.File.PersistDirectoryEntry.Builder
optional int64 id = 1;
hasId() - Method in class alluxio.proto.journal.File.PersistDirectoryEntry
optional int64 id = 1;
hasId() - Method in interface alluxio.proto.journal.File.PersistDirectoryEntryOrBuilder
optional int64 id = 1;
hasId() - Method in class alluxio.proto.journal.File.PersistFileEntry.Builder
optional int64 id = 1;
hasId() - Method in class alluxio.proto.journal.File.PersistFileEntry
optional int64 id = 1;
hasId() - Method in interface alluxio.proto.journal.File.PersistFileEntryOrBuilder
optional int64 id = 1;
hasId() - Method in class alluxio.proto.journal.File.RenameEntry.Builder
optional int64 id = 1;
hasId() - Method in class alluxio.proto.journal.File.RenameEntry
optional int64 id = 1;
hasId() - Method in interface alluxio.proto.journal.File.RenameEntryOrBuilder
optional int64 id = 1;
hasId() - Method in class alluxio.proto.journal.File.SetAttributeEntry.Builder
optional int64 id = 1;
hasId() - Method in class alluxio.proto.journal.File.SetAttributeEntry
optional int64 id = 1;
hasId() - Method in interface alluxio.proto.journal.File.SetAttributeEntryOrBuilder
optional int64 id = 1;
hasId() - Method in class alluxio.proto.journal.Lineage.LineageEntry.Builder
optional int64 id = 1;
hasId() - Method in class alluxio.proto.journal.Lineage.LineageEntry
optional int64 id = 1;
hasId() - Method in interface alluxio.proto.journal.Lineage.LineageEntryOrBuilder
optional int64 id = 1;
hasInodeDirectory() - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
optional .alluxio.proto.journal.InodeDirectoryEntry inode_directory = 9;
hasInodeDirectory() - Method in class alluxio.proto.journal.Journal.JournalEntry
optional .alluxio.proto.journal.InodeDirectoryEntry inode_directory = 9;
hasInodeDirectory() - Method in interface alluxio.proto.journal.Journal.JournalEntryOrBuilder
optional .alluxio.proto.journal.InodeDirectoryEntry inode_directory = 9;
hasInodeDirectoryIdGenerator() - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
optional .alluxio.proto.journal.InodeDirectoryIdGeneratorEntry inode_directory_id_generator = 10;
hasInodeDirectoryIdGenerator() - Method in class alluxio.proto.journal.Journal.JournalEntry
optional .alluxio.proto.journal.InodeDirectoryIdGeneratorEntry inode_directory_id_generator = 10;
hasInodeDirectoryIdGenerator() - Method in interface alluxio.proto.journal.Journal.JournalEntryOrBuilder
optional .alluxio.proto.journal.InodeDirectoryIdGeneratorEntry inode_directory_id_generator = 10;
hasInodeFile() - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
optional .alluxio.proto.journal.InodeFileEntry inode_file = 11;
hasInodeFile() - Method in class alluxio.proto.journal.Journal.JournalEntry
optional .alluxio.proto.journal.InodeFileEntry inode_file = 11;
hasInodeFile() - Method in interface alluxio.proto.journal.Journal.JournalEntryOrBuilder
optional .alluxio.proto.journal.InodeFileEntry inode_file = 11;
hasInodeLastModificationTime() - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
optional .alluxio.proto.journal.InodeLastModificationTimeEntry inode_last_modification_time = 12;
hasInodeLastModificationTime() - Method in class alluxio.proto.journal.Journal.JournalEntry
optional .alluxio.proto.journal.InodeLastModificationTimeEntry inode_last_modification_time = 12;
hasInodeLastModificationTime() - Method in interface alluxio.proto.journal.Journal.JournalEntryOrBuilder
optional .alluxio.proto.journal.InodeLastModificationTimeEntry inode_last_modification_time = 12;
hasJobCommand() - Method in class alluxio.proto.journal.Lineage.LineageEntry.Builder
optional string job_command = 4;
hasJobCommand() - Method in class alluxio.proto.journal.Lineage.LineageEntry
optional string job_command = 4;
hasJobCommand() - Method in interface alluxio.proto.journal.Lineage.LineageEntryOrBuilder
optional string job_command = 4;
hasJobOutputPath() - Method in class alluxio.proto.journal.Lineage.LineageEntry.Builder
optional string job_output_path = 5;
hasJobOutputPath() - Method in class alluxio.proto.journal.Lineage.LineageEntry
optional string job_output_path = 5;
hasJobOutputPath() - Method in interface alluxio.proto.journal.Lineage.LineageEntryOrBuilder
optional string job_output_path = 5;
hasKey() - Method in class alluxio.proto.journal.File.StringPairEntry.Builder
optional string key = 1;
hasKey() - Method in class alluxio.proto.journal.File.StringPairEntry
optional string key = 1;
hasKey() - Method in interface alluxio.proto.journal.File.StringPairEntryOrBuilder
optional string key = 1;
hasKeyCount() - Method in class alluxio.proto.journal.KeyValue.CompletePartitionEntry.Builder
optional int32 key_count = 5;
hasKeyCount() - Method in class alluxio.proto.journal.KeyValue.CompletePartitionEntry
optional int32 key_count = 5;
hasKeyCount() - Method in interface alluxio.proto.journal.KeyValue.CompletePartitionEntryOrBuilder
optional int32 key_count = 5;
hasKeyLimit() - Method in class alluxio.proto.journal.KeyValue.CompletePartitionEntry.Builder
optional string key_limit = 3;
hasKeyLimit() - Method in class alluxio.proto.journal.KeyValue.CompletePartitionEntry
optional string key_limit = 3;
hasKeyLimit() - Method in interface alluxio.proto.journal.KeyValue.CompletePartitionEntryOrBuilder
optional string key_limit = 3;
hasKeyStart() - Method in class alluxio.proto.journal.KeyValue.CompletePartitionEntry.Builder
optional string key_start = 2;
hasKeyStart() - Method in class alluxio.proto.journal.KeyValue.CompletePartitionEntry
optional string key_start = 2;
hasKeyStart() - Method in interface alluxio.proto.journal.KeyValue.CompletePartitionEntryOrBuilder
optional string key_start = 2;
hasLastModificationTimeMs() - Method in class alluxio.proto.journal.File.InodeDirectoryEntry.Builder
optional int64 last_modification_time_ms = 7;
hasLastModificationTimeMs() - Method in class alluxio.proto.journal.File.InodeDirectoryEntry
optional int64 last_modification_time_ms = 7;
hasLastModificationTimeMs() - Method in interface alluxio.proto.journal.File.InodeDirectoryEntryOrBuilder
optional int64 last_modification_time_ms = 7;
hasLastModificationTimeMs() - Method in class alluxio.proto.journal.File.InodeFileEntry.Builder
optional int64 last_modification_time_ms = 7;
hasLastModificationTimeMs() - Method in class alluxio.proto.journal.File.InodeFileEntry
optional int64 last_modification_time_ms = 7;
hasLastModificationTimeMs() - Method in interface alluxio.proto.journal.File.InodeFileEntryOrBuilder
optional int64 last_modification_time_ms = 7;
hasLastModificationTimeMs() - Method in class alluxio.proto.journal.File.InodeLastModificationTimeEntry.Builder
optional int64 last_modification_time_ms = 2;
hasLastModificationTimeMs() - Method in class alluxio.proto.journal.File.InodeLastModificationTimeEntry
optional int64 last_modification_time_ms = 2;
hasLastModificationTimeMs() - Method in interface alluxio.proto.journal.File.InodeLastModificationTimeEntryOrBuilder
optional int64 last_modification_time_ms = 2;
hasLength() - Method in class alluxio.proto.dataserver.Protocol.AsyncCacheRequest.Builder
optional int64 length = 5;
hasLength() - Method in class alluxio.proto.dataserver.Protocol.AsyncCacheRequest
optional int64 length = 5;
hasLength() - Method in interface alluxio.proto.dataserver.Protocol.AsyncCacheRequestOrBuilder
optional int64 length = 5;
hasLength() - Method in class alluxio.proto.dataserver.Protocol.ReadRequest.Builder
optional int64 length = 3;
hasLength() - Method in class alluxio.proto.dataserver.Protocol.ReadRequest
optional int64 length = 3;
hasLength() - Method in interface alluxio.proto.dataserver.Protocol.ReadRequestOrBuilder
optional int64 length = 3;
hasLength() - Method in class alluxio.proto.journal.Block.BlockInfoEntry.Builder
optional int64 length = 2;
hasLength() - Method in class alluxio.proto.journal.Block.BlockInfoEntry
optional int64 length = 2;
hasLength() - Method in interface alluxio.proto.journal.Block.BlockInfoEntryOrBuilder
optional int64 length = 2;
hasLength() - Method in class alluxio.proto.journal.File.CompleteFileEntry.Builder
optional int64 length = 3;
hasLength() - Method in class alluxio.proto.journal.File.CompleteFileEntry
optional int64 length = 3;
hasLength() - Method in interface alluxio.proto.journal.File.CompleteFileEntryOrBuilder
optional int64 length = 3;
hasLength() - Method in class alluxio.proto.journal.File.InodeFileEntry.Builder
optional int64 length = 9;
hasLength() - Method in class alluxio.proto.journal.File.InodeFileEntry
optional int64 length = 9;
hasLength() - Method in interface alluxio.proto.journal.File.InodeFileEntryOrBuilder
optional int64 length = 9;
hasLength() - Method in class alluxio.proto.journal.File.PersistFileEntry.Builder
optional int64 length = 2;
hasLength() - Method in class alluxio.proto.journal.File.PersistFileEntry
optional int64 length = 2;
hasLength() - Method in interface alluxio.proto.journal.File.PersistFileEntryOrBuilder
optional int64 length = 2;
hasLineage() - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
optional .alluxio.proto.journal.LineageEntry lineage = 13;
hasLineage() - Method in class alluxio.proto.journal.Journal.JournalEntry
optional .alluxio.proto.journal.LineageEntry lineage = 13;
hasLineage() - Method in interface alluxio.proto.journal.Journal.JournalEntryOrBuilder
optional .alluxio.proto.journal.LineageEntry lineage = 13;
hasLineageId() - Method in class alluxio.proto.journal.Lineage.DeleteLineageEntry.Builder
optional int64 lineage_id = 1;
hasLineageId() - Method in class alluxio.proto.journal.Lineage.DeleteLineageEntry
optional int64 lineage_id = 1;
hasLineageId() - Method in interface alluxio.proto.journal.Lineage.DeleteLineageEntryOrBuilder
optional int64 lineage_id = 1;
hasLineageIdGenerator() - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
optional .alluxio.proto.journal.LineageIdGeneratorEntry lineage_id_generator = 14;
hasLineageIdGenerator() - Method in class alluxio.proto.journal.Journal.JournalEntry
optional .alluxio.proto.journal.LineageIdGeneratorEntry lineage_id_generator = 14;
hasLineageIdGenerator() - Method in interface alluxio.proto.journal.Journal.JournalEntryOrBuilder
optional .alluxio.proto.journal.LineageIdGeneratorEntry lineage_id_generator = 14;
hasLocalWorker() - Method in class alluxio.client.file.FileSystemContext
 
hasMaxUfsReadConcurrency() - Method in class alluxio.proto.dataserver.Protocol.OpenUfsBlockOptions.Builder
optional int32 maxUfsReadConcurrency = 4;
hasMaxUfsReadConcurrency() - Method in class alluxio.proto.dataserver.Protocol.OpenUfsBlockOptions
optional int32 maxUfsReadConcurrency = 4;
hasMaxUfsReadConcurrency() - Method in interface alluxio.proto.dataserver.Protocol.OpenUfsBlockOptionsOrBuilder
optional int32 maxUfsReadConcurrency = 4;
hasMergeStore() - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
optional .alluxio.proto.journal.MergeStoreEntry merge_store = 26;
hasMergeStore() - Method in class alluxio.proto.journal.Journal.JournalEntry
optional .alluxio.proto.journal.MergeStoreEntry merge_store = 26;
hasMergeStore() - Method in interface alluxio.proto.journal.Journal.JournalEntryOrBuilder
optional .alluxio.proto.journal.MergeStoreEntry merge_store = 26;
hasMessage() - Method in class alluxio.proto.dataserver.Protocol.Response.Builder
optional string message = 2;
hasMessage() - Method in class alluxio.proto.dataserver.Protocol.Response
optional string message = 2;
hasMessage() - Method in interface alluxio.proto.dataserver.Protocol.ResponseOrBuilder
optional string message = 2;
hasMode() - Method in class alluxio.proto.dataserver.Protocol.CreateUfsFileOptions.Builder
optional int32 mode = 4;
hasMode() - Method in class alluxio.proto.dataserver.Protocol.CreateUfsFileOptions
optional int32 mode = 4;
hasMode() - Method in interface alluxio.proto.dataserver.Protocol.CreateUfsFileOptionsOrBuilder
optional int32 mode = 4;
hasMode() - Method in class alluxio.proto.journal.File.InodeDirectoryEntry.Builder
optional int32 mode = 10;
hasMode() - Method in class alluxio.proto.journal.File.InodeDirectoryEntry
optional int32 mode = 10;
hasMode() - Method in interface alluxio.proto.journal.File.InodeDirectoryEntryOrBuilder
optional int32 mode = 10;
hasMode() - Method in class alluxio.proto.journal.File.InodeFileEntry.Builder
optional int32 mode = 16;
hasMode() - Method in class alluxio.proto.journal.File.InodeFileEntry
optional int32 mode = 16;
hasMode() - Method in interface alluxio.proto.journal.File.InodeFileEntryOrBuilder
optional int32 mode = 16;
hasMountId() - Method in class alluxio.proto.dataserver.Protocol.CreateUfsFileOptions.Builder
optional int64 mount_id = 5;
hasMountId() - Method in class alluxio.proto.dataserver.Protocol.CreateUfsFileOptions
optional int64 mount_id = 5;
hasMountId() - Method in interface alluxio.proto.dataserver.Protocol.CreateUfsFileOptionsOrBuilder
optional int64 mount_id = 5;
hasMountId() - Method in class alluxio.proto.dataserver.Protocol.OpenUfsBlockOptions.Builder
optional int64 mountId = 5;
hasMountId() - Method in class alluxio.proto.dataserver.Protocol.OpenUfsBlockOptions
optional int64 mountId = 5;
hasMountId() - Method in interface alluxio.proto.dataserver.Protocol.OpenUfsBlockOptionsOrBuilder
optional int64 mountId = 5;
hasMountId() - Method in class alluxio.proto.journal.File.AddMountPointEntry.Builder
optional int64 mount_id = 6;
hasMountId() - Method in class alluxio.proto.journal.File.AddMountPointEntry
optional int64 mount_id = 6;
hasMountId() - Method in interface alluxio.proto.journal.File.AddMountPointEntryOrBuilder
optional int64 mount_id = 6;
hasMountPoint() - Method in class alluxio.proto.journal.File.InodeDirectoryEntry.Builder
optional bool mount_point = 11;
hasMountPoint() - Method in class alluxio.proto.journal.File.InodeDirectoryEntry
optional bool mount_point = 11;
hasMountPoint() - Method in interface alluxio.proto.journal.File.InodeDirectoryEntryOrBuilder
optional bool mount_point = 11;
hasName() - Method in class alluxio.proto.journal.File.InodeDirectoryEntry.Builder
optional string name = 3;
hasName() - Method in class alluxio.proto.journal.File.InodeDirectoryEntry
optional string name = 3;
hasName() - Method in interface alluxio.proto.journal.File.InodeDirectoryEntryOrBuilder
optional string name = 3;
hasName() - Method in class alluxio.proto.journal.File.InodeFileEntry.Builder
optional string name = 3;
hasName() - Method in class alluxio.proto.journal.File.InodeFileEntry
optional string name = 3;
hasName() - Method in interface alluxio.proto.journal.File.InodeFileEntryOrBuilder
optional string name = 3;
hasNewStoreId() - Method in class alluxio.proto.journal.KeyValue.RenameStoreEntry.Builder
optional int64 new_store_id = 2;
hasNewStoreId() - Method in class alluxio.proto.journal.KeyValue.RenameStoreEntry
optional int64 new_store_id = 2;
hasNewStoreId() - Method in interface alluxio.proto.journal.KeyValue.RenameStoreEntryOrBuilder
optional int64 new_store_id = 2;
hasNext() - Method in interface alluxio.client.keyvalue.KeyValueIterator
 
hasNext() - Method in class alluxio.client.keyvalue.KeyValueStoreIterator
 
hasNextContainerId() - Method in class alluxio.proto.journal.Block.BlockContainerIdGeneratorEntry.Builder
optional int64 next_container_id = 1;
hasNextContainerId() - Method in class alluxio.proto.journal.Block.BlockContainerIdGeneratorEntry
optional int64 next_container_id = 1;
hasNextContainerId() - Method in interface alluxio.proto.journal.Block.BlockContainerIdGeneratorEntryOrBuilder
optional int64 next_container_id = 1;
hasNoCache() - Method in class alluxio.proto.dataserver.Protocol.OpenUfsBlockOptions.Builder
optional bool no_cache = 6;
hasNoCache() - Method in class alluxio.proto.dataserver.Protocol.OpenUfsBlockOptions
optional bool no_cache = 6;
hasNoCache() - Method in interface alluxio.proto.dataserver.Protocol.OpenUfsBlockOptionsOrBuilder
optional bool no_cache = 6;
hasOffset() - Method in class alluxio.proto.dataserver.Protocol.ReadRequest.Builder
optional int64 offset = 2;
hasOffset() - Method in class alluxio.proto.dataserver.Protocol.ReadRequest
optional int64 offset = 2;
hasOffset() - Method in interface alluxio.proto.dataserver.Protocol.ReadRequestOrBuilder
optional int64 offset = 2;
hasOffset() - Method in class alluxio.proto.dataserver.Protocol.WriteRequest.Builder
optional int64 offset = 3;
hasOffset() - Method in class alluxio.proto.dataserver.Protocol.WriteRequest
optional int64 offset = 3;
hasOffset() - Method in interface alluxio.proto.dataserver.Protocol.WriteRequestOrBuilder
optional int64 offset = 3;
hasOffsetInFile() - Method in class alluxio.proto.dataserver.Protocol.OpenUfsBlockOptions.Builder
optional int64 offset_in_file = 2;
hasOffsetInFile() - Method in class alluxio.proto.dataserver.Protocol.OpenUfsBlockOptions
optional int64 offset_in_file = 2;
hasOffsetInFile() - Method in interface alluxio.proto.dataserver.Protocol.OpenUfsBlockOptionsOrBuilder
optional int64 offset_in_file = 2;
hasOldStoreId() - Method in class alluxio.proto.journal.KeyValue.RenameStoreEntry.Builder
optional int64 old_store_id = 1;
hasOldStoreId() - Method in class alluxio.proto.journal.KeyValue.RenameStoreEntry
optional int64 old_store_id = 1;
hasOldStoreId() - Method in interface alluxio.proto.journal.KeyValue.RenameStoreEntryOrBuilder
optional int64 old_store_id = 1;
hasOnlyReserveSpace() - Method in class alluxio.proto.dataserver.Protocol.LocalBlockCreateRequest.Builder
optional bool only_reserve_space = 5;
hasOnlyReserveSpace() - Method in class alluxio.proto.dataserver.Protocol.LocalBlockCreateRequest
optional bool only_reserve_space = 5;
hasOnlyReserveSpace() - Method in interface alluxio.proto.dataserver.Protocol.LocalBlockCreateRequestOrBuilder
optional bool only_reserve_space = 5;
hasOpenUfsBlockOptions() - Method in class alluxio.proto.dataserver.Protocol.AsyncCacheRequest.Builder
optional .alluxio.proto.dataserver.OpenUfsBlockOptions open_ufs_block_options = 4;
hasOpenUfsBlockOptions() - Method in class alluxio.proto.dataserver.Protocol.AsyncCacheRequest
optional .alluxio.proto.dataserver.OpenUfsBlockOptions open_ufs_block_options = 4;
hasOpenUfsBlockOptions() - Method in interface alluxio.proto.dataserver.Protocol.AsyncCacheRequestOrBuilder
optional .alluxio.proto.dataserver.OpenUfsBlockOptions open_ufs_block_options = 4;
hasOpenUfsBlockOptions() - Method in class alluxio.proto.dataserver.Protocol.ReadRequest.Builder
optional .alluxio.proto.dataserver.OpenUfsBlockOptions open_ufs_block_options = 6;
hasOpenUfsBlockOptions() - Method in class alluxio.proto.dataserver.Protocol.ReadRequest
optional .alluxio.proto.dataserver.OpenUfsBlockOptions open_ufs_block_options = 6;
hasOpenUfsBlockOptions() - Method in interface alluxio.proto.dataserver.Protocol.ReadRequestOrBuilder
optional .alluxio.proto.dataserver.OpenUfsBlockOptions open_ufs_block_options = 6;
hasOpTimeMs() - Method in class alluxio.proto.journal.File.CompleteFileEntry.Builder
optional int64 op_time_ms = 4;
hasOpTimeMs() - Method in class alluxio.proto.journal.File.CompleteFileEntry
optional int64 op_time_ms = 4;
hasOpTimeMs() - Method in interface alluxio.proto.journal.File.CompleteFileEntryOrBuilder
optional int64 op_time_ms = 4;
hasOpTimeMs() - Method in class alluxio.proto.journal.File.DeleteFileEntry.Builder
optional int64 op_time_ms = 3;
hasOpTimeMs() - Method in class alluxio.proto.journal.File.DeleteFileEntry
optional int64 op_time_ms = 3;
hasOpTimeMs() - Method in interface alluxio.proto.journal.File.DeleteFileEntryOrBuilder
optional int64 op_time_ms = 3;
hasOpTimeMs() - Method in class alluxio.proto.journal.File.PersistFileEntry.Builder
optional int64 op_time_ms = 3;
hasOpTimeMs() - Method in class alluxio.proto.journal.File.PersistFileEntry
optional int64 op_time_ms = 3;
hasOpTimeMs() - Method in interface alluxio.proto.journal.File.PersistFileEntryOrBuilder
optional int64 op_time_ms = 3;
hasOpTimeMs() - Method in class alluxio.proto.journal.File.RenameEntry.Builder
optional int64 op_time_ms = 3;
hasOpTimeMs() - Method in class alluxio.proto.journal.File.RenameEntry
optional int64 op_time_ms = 3;
hasOpTimeMs() - Method in interface alluxio.proto.journal.File.RenameEntryOrBuilder
optional int64 op_time_ms = 3;
hasOpTimeMs() - Method in class alluxio.proto.journal.File.SetAttributeEntry.Builder
optional int64 op_time_ms = 2;
hasOpTimeMs() - Method in class alluxio.proto.journal.File.SetAttributeEntry
optional int64 op_time_ms = 2;
hasOpTimeMs() - Method in interface alluxio.proto.journal.File.SetAttributeEntryOrBuilder
optional int64 op_time_ms = 2;
hasOutputFile(long) - Method in class alluxio.master.lineage.meta.LineageStore
Checks if there's an output file with given file id.
hasOwner() - Method in class alluxio.proto.dataserver.Protocol.CreateUfsFileOptions.Builder
optional string owner = 2;
hasOwner() - Method in class alluxio.proto.dataserver.Protocol.CreateUfsFileOptions
optional string owner = 2;
hasOwner() - Method in interface alluxio.proto.dataserver.Protocol.CreateUfsFileOptionsOrBuilder
optional string owner = 2;
hasOwner() - Method in class alluxio.proto.journal.File.InodeDirectoryEntry.Builder
optional string owner = 8;
hasOwner() - Method in class alluxio.proto.journal.File.InodeDirectoryEntry
optional string owner = 8;
hasOwner() - Method in interface alluxio.proto.journal.File.InodeDirectoryEntryOrBuilder
optional string owner = 8;
hasOwner() - Method in class alluxio.proto.journal.File.InodeFileEntry.Builder
optional string owner = 14;
hasOwner() - Method in class alluxio.proto.journal.File.InodeFileEntry
optional string owner = 14;
hasOwner() - Method in interface alluxio.proto.journal.File.InodeFileEntryOrBuilder
optional string owner = 14;
hasOwner() - Method in class alluxio.proto.journal.File.SetAttributeEntry.Builder
optional string owner = 6;
hasOwner() - Method in class alluxio.proto.journal.File.SetAttributeEntry
optional string owner = 6;
hasOwner() - Method in interface alluxio.proto.journal.File.SetAttributeEntryOrBuilder
optional string owner = 6;
hasPacketSize() - Method in class alluxio.proto.dataserver.Protocol.ReadRequest.Builder
optional int64 packet_size = 5;
hasPacketSize() - Method in class alluxio.proto.dataserver.Protocol.ReadRequest
optional int64 packet_size = 5;
hasPacketSize() - Method in interface alluxio.proto.dataserver.Protocol.ReadRequestOrBuilder
optional int64 packet_size = 5;
hasParentId() - Method in class alluxio.proto.journal.File.InodeDirectoryEntry.Builder
optional int64 parent_id = 2;
hasParentId() - Method in class alluxio.proto.journal.File.InodeDirectoryEntry
optional int64 parent_id = 2;
hasParentId() - Method in interface alluxio.proto.journal.File.InodeDirectoryEntryOrBuilder
optional int64 parent_id = 2;
hasParentId() - Method in class alluxio.proto.journal.File.InodeFileEntry.Builder
optional int64 parent_id = 2;
hasParentId() - Method in class alluxio.proto.journal.File.InodeFileEntry
optional int64 parent_id = 2;
hasParentId() - Method in interface alluxio.proto.journal.File.InodeFileEntryOrBuilder
optional int64 parent_id = 2;
hasPath() - Method in class alluxio.proto.dataserver.Protocol.LocalBlockCreateResponse.Builder
optional string path = 1;
hasPath() - Method in class alluxio.proto.dataserver.Protocol.LocalBlockCreateResponse
optional string path = 1;
hasPath() - Method in interface alluxio.proto.dataserver.Protocol.LocalBlockCreateResponseOrBuilder
optional string path = 1;
hasPath() - Method in class alluxio.proto.dataserver.Protocol.LocalBlockOpenResponse.Builder
optional string path = 1;
hasPath() - Method in class alluxio.proto.dataserver.Protocol.LocalBlockOpenResponse
optional string path = 1;
hasPath() - Method in interface alluxio.proto.dataserver.Protocol.LocalBlockOpenResponseOrBuilder
optional string path = 1;
hasPath() - Method in class alluxio.proto.journal.File.ReinitializeFileEntry.Builder
optional string path = 1;
hasPath() - Method in class alluxio.proto.journal.File.ReinitializeFileEntry
optional string path = 1;
hasPath() - Method in interface alluxio.proto.journal.File.ReinitializeFileEntryOrBuilder
optional string path = 1;
hasPayload() - Method in class alluxio.network.protocol.RPCMessage
Returns true if the message has a payload.
hasPayload() - Method in class alluxio.network.protocol.RPCProtoMessage
 
hasPermission() - Method in class alluxio.proto.journal.File.SetAttributeEntry.Builder
optional int32 permission = 8;
hasPermission() - Method in class alluxio.proto.journal.File.SetAttributeEntry
optional int32 permission = 8;
hasPermission() - Method in interface alluxio.proto.journal.File.SetAttributeEntryOrBuilder
optional int32 permission = 8;
hasPersistDirectory() - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
optional .alluxio.proto.journal.PersistDirectoryEntry persist_directory = 15;
hasPersistDirectory() - Method in class alluxio.proto.journal.Journal.JournalEntry
optional .alluxio.proto.journal.PersistDirectoryEntry persist_directory = 15;
hasPersistDirectory() - Method in interface alluxio.proto.journal.Journal.JournalEntryOrBuilder
optional .alluxio.proto.journal.PersistDirectoryEntry persist_directory = 15;
hasPersisted() - Method in class alluxio.proto.journal.File.SetAttributeEntry.Builder
optional bool persisted = 5;
hasPersisted() - Method in class alluxio.proto.journal.File.SetAttributeEntry
optional bool persisted = 5;
hasPersisted() - Method in interface alluxio.proto.journal.File.SetAttributeEntryOrBuilder
optional bool persisted = 5;
hasPersistenceState() - Method in class alluxio.proto.journal.File.InodeDirectoryEntry.Builder
optional string persistence_state = 4;
hasPersistenceState() - Method in class alluxio.proto.journal.File.InodeDirectoryEntry
optional string persistence_state = 4;
hasPersistenceState() - Method in interface alluxio.proto.journal.File.InodeDirectoryEntryOrBuilder
optional string persistence_state = 4;
hasPersistenceState() - Method in class alluxio.proto.journal.File.InodeFileEntry.Builder
optional string persistence_state = 4;
hasPersistenceState() - Method in class alluxio.proto.journal.File.InodeFileEntry
optional string persistence_state = 4;
hasPersistenceState() - Method in interface alluxio.proto.journal.File.InodeFileEntryOrBuilder
optional string persistence_state = 4;
hasPinned() - Method in class alluxio.proto.journal.File.InodeDirectoryEntry.Builder
optional bool pinned = 5;
hasPinned() - Method in class alluxio.proto.journal.File.InodeDirectoryEntry
optional bool pinned = 5;
hasPinned() - Method in interface alluxio.proto.journal.File.InodeDirectoryEntryOrBuilder
optional bool pinned = 5;
hasPinned() - Method in class alluxio.proto.journal.File.InodeFileEntry.Builder
optional bool pinned = 5;
hasPinned() - Method in class alluxio.proto.journal.File.InodeFileEntry
optional bool pinned = 5;
hasPinned() - Method in interface alluxio.proto.journal.File.InodeFileEntryOrBuilder
optional bool pinned = 5;
hasPinned() - Method in class alluxio.proto.journal.File.SetAttributeEntry.Builder
optional bool pinned = 3;
hasPinned() - Method in class alluxio.proto.journal.File.SetAttributeEntry
optional bool pinned = 3;
hasPinned() - Method in interface alluxio.proto.journal.File.SetAttributeEntryOrBuilder
optional bool pinned = 3;
hasPrefix(String, String) - Static method in class alluxio.util.io.PathUtils
Checks whether the given path contains the given prefix.
hasPromote() - Method in class alluxio.proto.dataserver.Protocol.LocalBlockOpenRequest.Builder
optional bool promote = 2;
hasPromote() - Method in class alluxio.proto.dataserver.Protocol.LocalBlockOpenRequest
optional bool promote = 2;
hasPromote() - Method in interface alluxio.proto.dataserver.Protocol.LocalBlockOpenRequestOrBuilder
optional bool promote = 2;
hasPromote() - Method in class alluxio.proto.dataserver.Protocol.ReadRequest.Builder
optional bool promote = 7;
hasPromote() - Method in class alluxio.proto.dataserver.Protocol.ReadRequest
optional bool promote = 7;
hasPromote() - Method in interface alluxio.proto.dataserver.Protocol.ReadRequestOrBuilder
optional bool promote = 7;
hasReadOnly() - Method in class alluxio.proto.journal.File.AddMountPointEntry.Builder
optional bool readOnly = 3;
hasReadOnly() - Method in class alluxio.proto.journal.File.AddMountPointEntry
optional bool readOnly = 3;
hasReadOnly() - Method in interface alluxio.proto.journal.File.AddMountPointEntryOrBuilder
optional bool readOnly = 3;
hasRecursive() - Method in class alluxio.proto.journal.File.DeleteFileEntry.Builder
optional bool recursive = 2;
hasRecursive() - Method in class alluxio.proto.journal.File.DeleteFileEntry
optional bool recursive = 2;
hasRecursive() - Method in interface alluxio.proto.journal.File.DeleteFileEntryOrBuilder
optional bool recursive = 2;
hasReinitializeFile() - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
optional .alluxio.proto.journal.ReinitializeFileEntry reinitialize_file = 18;
hasReinitializeFile() - Method in class alluxio.proto.journal.Journal.JournalEntry
optional .alluxio.proto.journal.ReinitializeFileEntry reinitialize_file = 18;
hasReinitializeFile() - Method in interface alluxio.proto.journal.Journal.JournalEntryOrBuilder
optional .alluxio.proto.journal.ReinitializeFileEntry reinitialize_file = 18;
hasRename() - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
optional .alluxio.proto.journal.RenameEntry rename = 19;
hasRename() - Method in class alluxio.proto.journal.Journal.JournalEntry
optional .alluxio.proto.journal.RenameEntry rename = 19;
hasRename() - Method in interface alluxio.proto.journal.Journal.JournalEntryOrBuilder
optional .alluxio.proto.journal.RenameEntry rename = 19;
hasRenameStore() - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
optional .alluxio.proto.journal.RenameStoreEntry rename_store = 28;
hasRenameStore() - Method in class alluxio.proto.journal.Journal.JournalEntry
optional .alluxio.proto.journal.RenameStoreEntry rename_store = 28;
hasRenameStore() - Method in interface alluxio.proto.journal.Journal.JournalEntryOrBuilder
optional .alluxio.proto.journal.RenameStoreEntry rename_store = 28;
hasScheme() - Method in class alluxio.AlluxioURI
Tells if this AlluxioURI has scheme or not.
hasSequenceNumber() - Method in class alluxio.proto.journal.File.InodeDirectoryIdGeneratorEntry.Builder
optional int64 sequence_number = 2;
hasSequenceNumber() - Method in class alluxio.proto.journal.File.InodeDirectoryIdGeneratorEntry
optional int64 sequence_number = 2;
hasSequenceNumber() - Method in interface alluxio.proto.journal.File.InodeDirectoryIdGeneratorEntryOrBuilder
optional int64 sequence_number = 2;
hasSequenceNumber() - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
optional int64 sequence_number = 1;
hasSequenceNumber() - Method in class alluxio.proto.journal.Journal.JournalEntry
optional int64 sequence_number = 1;
hasSequenceNumber() - Method in interface alluxio.proto.journal.Journal.JournalEntryOrBuilder
optional int64 sequence_number = 1;
hasSequenceNumber() - Method in class alluxio.proto.journal.Lineage.LineageIdGeneratorEntry.Builder
optional int64 sequence_number = 1;
hasSequenceNumber() - Method in class alluxio.proto.journal.Lineage.LineageIdGeneratorEntry
optional int64 sequence_number = 1;
hasSequenceNumber() - Method in interface alluxio.proto.journal.Lineage.LineageIdGeneratorEntryOrBuilder
optional int64 sequence_number = 1;
hasSetAttribute() - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
optional .alluxio.proto.journal.SetAttributeEntry set_attribute = 27;
hasSetAttribute() - Method in class alluxio.proto.journal.Journal.JournalEntry
optional .alluxio.proto.journal.SetAttributeEntry set_attribute = 27;
hasSetAttribute() - Method in interface alluxio.proto.journal.Journal.JournalEntryOrBuilder
optional .alluxio.proto.journal.SetAttributeEntry set_attribute = 27;
hasShared() - Method in class alluxio.proto.journal.File.AddMountPointEntry.Builder
optional bool shared = 5;
hasShared() - Method in class alluxio.proto.journal.File.AddMountPointEntry
optional bool shared = 5;
hasShared() - Method in interface alluxio.proto.journal.File.AddMountPointEntryOrBuilder
optional bool shared = 5;
hasSourceHost() - Method in class alluxio.proto.dataserver.Protocol.AsyncCacheRequest.Builder
optional string source_host = 2;
hasSourceHost() - Method in class alluxio.proto.dataserver.Protocol.AsyncCacheRequest
optional string source_host = 2;
hasSourceHost() - Method in interface alluxio.proto.dataserver.Protocol.AsyncCacheRequestOrBuilder
optional string source_host = 2;
hasSourcePort() - Method in class alluxio.proto.dataserver.Protocol.AsyncCacheRequest.Builder
optional int32 source_port = 3;
hasSourcePort() - Method in class alluxio.proto.dataserver.Protocol.AsyncCacheRequest
optional int32 source_port = 3;
hasSourcePort() - Method in interface alluxio.proto.dataserver.Protocol.AsyncCacheRequestOrBuilder
optional int32 source_port = 3;
hasSpaceToReserve() - Method in class alluxio.proto.dataserver.Protocol.LocalBlockCreateRequest.Builder
optional int64 space_to_reserve = 4;
hasSpaceToReserve() - Method in class alluxio.proto.dataserver.Protocol.LocalBlockCreateRequest
optional int64 space_to_reserve = 4;
hasSpaceToReserve() - Method in interface alluxio.proto.dataserver.Protocol.LocalBlockCreateRequestOrBuilder
optional int64 space_to_reserve = 4;
hasStatus() - Method in class alluxio.proto.dataserver.Protocol.Response.Builder
optional .alluxio.proto.status.PStatus status = 1;
hasStatus() - Method in class alluxio.proto.dataserver.Protocol.Response
optional .alluxio.proto.status.PStatus status = 1;
hasStatus() - Method in interface alluxio.proto.dataserver.Protocol.ResponseOrBuilder
optional .alluxio.proto.status.PStatus status = 1;
hasStoreId() - Method in class alluxio.proto.journal.KeyValue.CompletePartitionEntry.Builder
optional int64 store_id = 1;
hasStoreId() - Method in class alluxio.proto.journal.KeyValue.CompletePartitionEntry
optional int64 store_id = 1;
hasStoreId() - Method in interface alluxio.proto.journal.KeyValue.CompletePartitionEntryOrBuilder
optional int64 store_id = 1;
hasStoreId() - Method in class alluxio.proto.journal.KeyValue.CompleteStoreEntry.Builder
optional int64 store_id = 1;
hasStoreId() - Method in class alluxio.proto.journal.KeyValue.CompleteStoreEntry
optional int64 store_id = 1;
hasStoreId() - Method in interface alluxio.proto.journal.KeyValue.CompleteStoreEntryOrBuilder
optional int64 store_id = 1;
hasStoreId() - Method in class alluxio.proto.journal.KeyValue.CreateStoreEntry.Builder
optional int64 store_id = 1;
hasStoreId() - Method in class alluxio.proto.journal.KeyValue.CreateStoreEntry
optional int64 store_id = 1;
hasStoreId() - Method in interface alluxio.proto.journal.KeyValue.CreateStoreEntryOrBuilder
optional int64 store_id = 1;
hasStoreId() - Method in class alluxio.proto.journal.KeyValue.DeleteStoreEntry.Builder
optional int64 store_id = 1;
hasStoreId() - Method in class alluxio.proto.journal.KeyValue.DeleteStoreEntry
optional int64 store_id = 1;
hasStoreId() - Method in interface alluxio.proto.journal.KeyValue.DeleteStoreEntryOrBuilder
optional int64 store_id = 1;
hasTempBlockMeta(long) - Method in class alluxio.worker.block.BlockMetadataManager
Checks if the storage has a given temp block.
hasTempBlockMeta(long) - Method in class alluxio.worker.block.meta.StorageDir
Checks if a temp block is in this storage dir.
hasTier() - Method in class alluxio.proto.dataserver.Protocol.LocalBlockCreateRequest.Builder
optional int32 tier = 3;
hasTier() - Method in class alluxio.proto.dataserver.Protocol.LocalBlockCreateRequest
optional int32 tier = 3;
hasTier() - Method in interface alluxio.proto.dataserver.Protocol.LocalBlockCreateRequestOrBuilder
optional int32 tier = 3;
hasTier() - Method in class alluxio.proto.dataserver.Protocol.WriteRequest.Builder
optional int32 tier = 4;
hasTier() - Method in class alluxio.proto.dataserver.Protocol.WriteRequest
optional int32 tier = 4;
hasTier() - Method in interface alluxio.proto.dataserver.Protocol.WriteRequestOrBuilder
optional int32 tier = 4;
hasToStoreId() - Method in class alluxio.proto.journal.KeyValue.MergeStoreEntry.Builder
optional int64 to_store_id = 2;
hasToStoreId() - Method in class alluxio.proto.journal.KeyValue.MergeStoreEntry
optional int64 to_store_id = 2;
hasToStoreId() - Method in interface alluxio.proto.journal.KeyValue.MergeStoreEntryOrBuilder
optional int64 to_store_id = 2;
hasTtl() - Method in class alluxio.proto.journal.File.InodeDirectoryEntry.Builder
optional int64 ttl = 13;
hasTtl() - Method in class alluxio.proto.journal.File.InodeDirectoryEntry
optional int64 ttl = 13;
hasTtl() - Method in interface alluxio.proto.journal.File.InodeDirectoryEntryOrBuilder
optional int64 ttl = 13;
hasTtl() - Method in class alluxio.proto.journal.File.InodeFileEntry.Builder
optional int64 ttl = 13;
hasTtl() - Method in class alluxio.proto.journal.File.InodeFileEntry
optional int64 ttl = 13;
hasTtl() - Method in interface alluxio.proto.journal.File.InodeFileEntryOrBuilder
optional int64 ttl = 13;
hasTtl() - Method in class alluxio.proto.journal.File.ReinitializeFileEntry.Builder
optional int64 ttl = 3;
hasTtl() - Method in class alluxio.proto.journal.File.ReinitializeFileEntry
optional int64 ttl = 3;
hasTtl() - Method in interface alluxio.proto.journal.File.ReinitializeFileEntryOrBuilder
optional int64 ttl = 3;
hasTtl() - Method in class alluxio.proto.journal.File.SetAttributeEntry.Builder
optional int64 ttl = 4;
hasTtl() - Method in class alluxio.proto.journal.File.SetAttributeEntry
optional int64 ttl = 4;
hasTtl() - Method in interface alluxio.proto.journal.File.SetAttributeEntryOrBuilder
optional int64 ttl = 4;
hasTtlAction() - Method in class alluxio.proto.journal.File.InodeDirectoryEntry.Builder
optional .alluxio.proto.journal.PTtlAction ttlAction = 14 [default = DELETE];
hasTtlAction() - Method in class alluxio.proto.journal.File.InodeDirectoryEntry
optional .alluxio.proto.journal.PTtlAction ttlAction = 14 [default = DELETE];
hasTtlAction() - Method in interface alluxio.proto.journal.File.InodeDirectoryEntryOrBuilder
optional .alluxio.proto.journal.PTtlAction ttlAction = 14 [default = DELETE];
hasTtlAction() - Method in class alluxio.proto.journal.File.InodeFileEntry.Builder
optional .alluxio.proto.journal.PTtlAction ttlAction = 17 [default = DELETE];
hasTtlAction() - Method in class alluxio.proto.journal.File.InodeFileEntry
optional .alluxio.proto.journal.PTtlAction ttlAction = 17 [default = DELETE];
hasTtlAction() - Method in interface alluxio.proto.journal.File.InodeFileEntryOrBuilder
optional .alluxio.proto.journal.PTtlAction ttlAction = 17 [default = DELETE];
hasTtlAction() - Method in class alluxio.proto.journal.File.ReinitializeFileEntry.Builder
optional .alluxio.proto.journal.PTtlAction ttlAction = 4 [default = DELETE];
hasTtlAction() - Method in class alluxio.proto.journal.File.ReinitializeFileEntry
optional .alluxio.proto.journal.PTtlAction ttlAction = 4 [default = DELETE];
hasTtlAction() - Method in interface alluxio.proto.journal.File.ReinitializeFileEntryOrBuilder
optional .alluxio.proto.journal.PTtlAction ttlAction = 4 [default = DELETE];
hasTtlAction() - Method in class alluxio.proto.journal.File.SetAttributeEntry.Builder
optional .alluxio.proto.journal.PTtlAction ttlAction = 9 [default = DELETE];
hasTtlAction() - Method in class alluxio.proto.journal.File.SetAttributeEntry
optional .alluxio.proto.journal.PTtlAction ttlAction = 9 [default = DELETE];
hasTtlAction() - Method in interface alluxio.proto.journal.File.SetAttributeEntryOrBuilder
optional .alluxio.proto.journal.PTtlAction ttlAction = 9 [default = DELETE];
hasType() - Method in class alluxio.proto.dataserver.Protocol.ReadResponse.Builder
optional .alluxio.proto.dataserver.ReadResponse.Type type = 1;
hasType() - Method in class alluxio.proto.dataserver.Protocol.ReadResponse
optional .alluxio.proto.dataserver.ReadResponse.Type type = 1;
hasType() - Method in interface alluxio.proto.dataserver.Protocol.ReadResponseOrBuilder
optional .alluxio.proto.dataserver.ReadResponse.Type type = 1;
hasType() - Method in class alluxio.proto.dataserver.Protocol.WriteRequest.Builder
optional .alluxio.proto.dataserver.RequestType type = 1;
hasType() - Method in class alluxio.proto.dataserver.Protocol.WriteRequest
optional .alluxio.proto.dataserver.RequestType type = 1;
hasType() - Method in interface alluxio.proto.dataserver.Protocol.WriteRequestOrBuilder
optional .alluxio.proto.dataserver.RequestType type = 1;
hasUfsFingerprint() - Method in class alluxio.proto.journal.File.CompleteFileEntry.Builder
optional string ufs_fingerprint = 5;
hasUfsFingerprint() - Method in class alluxio.proto.journal.File.CompleteFileEntry
optional string ufs_fingerprint = 5;
hasUfsFingerprint() - Method in interface alluxio.proto.journal.File.CompleteFileEntryOrBuilder
optional string ufs_fingerprint = 5;
hasUfsFingerprint() - Method in class alluxio.proto.journal.File.InodeFileEntry.Builder
optional string ufs_fingerprint = 18;
hasUfsFingerprint() - Method in class alluxio.proto.journal.File.InodeFileEntry
optional string ufs_fingerprint = 18;
hasUfsFingerprint() - Method in interface alluxio.proto.journal.File.InodeFileEntryOrBuilder
optional string ufs_fingerprint = 18;
hasUfsFingerprint() - Method in class alluxio.proto.journal.File.SetAttributeEntry.Builder
optional string ufs_fingerprint = 10;
hasUfsFingerprint() - Method in class alluxio.proto.journal.File.SetAttributeEntry
optional string ufs_fingerprint = 10;
hasUfsFingerprint() - Method in interface alluxio.proto.journal.File.SetAttributeEntryOrBuilder
optional string ufs_fingerprint = 10;
hasUfsMode() - Method in class alluxio.proto.journal.File.UpdateUfsModeEntry.Builder
optional .alluxio.proto.journal.UfsMode ufsMode = 2 [default = READ_WRITE];
hasUfsMode() - Method in class alluxio.proto.journal.File.UpdateUfsModeEntry
optional .alluxio.proto.journal.UfsMode ufsMode = 2 [default = READ_WRITE];
hasUfsMode() - Method in interface alluxio.proto.journal.File.UpdateUfsModeEntryOrBuilder
optional .alluxio.proto.journal.UfsMode ufsMode = 2 [default = READ_WRITE];
hasUfsPath() - Method in class alluxio.proto.dataserver.Protocol.CreateUfsFileOptions.Builder
optional string ufs_path = 1;
hasUfsPath() - Method in class alluxio.proto.dataserver.Protocol.CreateUfsFileOptions
optional string ufs_path = 1;
hasUfsPath() - Method in interface alluxio.proto.dataserver.Protocol.CreateUfsFileOptionsOrBuilder
optional string ufs_path = 1;
hasUfsPath() - Method in class alluxio.proto.dataserver.Protocol.OpenUfsBlockOptions.Builder
optional string ufs_path = 1;
hasUfsPath() - Method in class alluxio.proto.dataserver.Protocol.OpenUfsBlockOptions
optional string ufs_path = 1;
hasUfsPath() - Method in interface alluxio.proto.dataserver.Protocol.OpenUfsBlockOptionsOrBuilder
optional string ufs_path = 1;
hasUfsPath() - Method in class alluxio.proto.journal.File.AddMountPointEntry.Builder
optional string ufs_path = 2;
hasUfsPath() - Method in class alluxio.proto.journal.File.AddMountPointEntry
optional string ufs_path = 2;
hasUfsPath() - Method in interface alluxio.proto.journal.File.AddMountPointEntryOrBuilder
optional string ufs_path = 2;
hasUfsPath() - Method in class alluxio.proto.journal.File.UpdateUfsModeEntry.Builder
optional string ufsPath = 1;
hasUfsPath() - Method in class alluxio.proto.journal.File.UpdateUfsModeEntry
optional string ufsPath = 1;
hasUfsPath() - Method in interface alluxio.proto.journal.File.UpdateUfsModeEntryOrBuilder
optional string ufsPath = 1;
hasUpdateUfsMode() - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
optional .alluxio.proto.journal.UpdateUfsModeEntry update_ufs_mode = 30;
hasUpdateUfsMode() - Method in class alluxio.proto.journal.Journal.JournalEntry
optional .alluxio.proto.journal.UpdateUfsModeEntry update_ufs_mode = 30;
hasUpdateUfsMode() - Method in interface alluxio.proto.journal.Journal.JournalEntryOrBuilder
optional .alluxio.proto.journal.UpdateUfsModeEntry update_ufs_mode = 30;
hasUser() - Method in class alluxio.proto.dataserver.Protocol.OpenUfsBlockOptions.Builder
optional string user = 7;
hasUser() - Method in class alluxio.proto.dataserver.Protocol.OpenUfsBlockOptions
optional string user = 7;
hasUser() - Method in interface alluxio.proto.dataserver.Protocol.OpenUfsBlockOptionsOrBuilder
optional string user = 7;
hasValue() - Method in class alluxio.proto.journal.File.StringPairEntry.Builder
optional string value = 2;
hasValue() - Method in class alluxio.proto.journal.File.StringPairEntry
optional string value = 2;
hasValue() - Method in interface alluxio.proto.journal.File.StringPairEntryOrBuilder
optional string value = 2;
hasWindowsDrive(String, boolean) - Static method in class alluxio.AlluxioURI
Checks if the path is a windows path.
HdfsFileInputStream - Class in alluxio.hadoop
An input stream for reading a file from HDFS.
HdfsFileInputStream(FileSystemContext, AlluxioURI, FileSystem.Statistics) - Constructor for class alluxio.hadoop.HdfsFileInputStream
Constructs a new stream for reading a file from HDFS.
HdfsUnderFileInputStream - Class in alluxio.underfs.hdfs
The input stream of HDFS as under filesystem.
HdfsUnderFileOutputStream - Class in alluxio.underfs.hdfs
Output stream implementation for HdfsUnderFileSystem.
HdfsUnderFileOutputStream(FSDataOutputStream) - Constructor for class alluxio.underfs.hdfs.HdfsUnderFileOutputStream
Basic constructor.
HdfsUnderFileSystem - Class in alluxio.underfs.hdfs
HDFS UnderFileSystem implementation.
HdfsUnderFileSystem(AlluxioURI, UnderFileSystemConfiguration, Configuration) - Constructor for class alluxio.underfs.hdfs.HdfsUnderFileSystem
Constructs a new HDFS UnderFileSystem.
HdfsUnderFileSystemFactory - Class in alluxio.underfs.hdfs
Factory for creating HdfsUnderFileSystem.
HdfsUnderFileSystemFactory() - Constructor for class alluxio.underfs.hdfs.HdfsUnderFileSystemFactory
Constructs a new HdfsUnderFileSystemFactory.
HdfsValidationTask - Class in alluxio.cli.validation
Abstract class for validating HDFS-related configurations.
HdfsValidationTask() - Constructor for class alluxio.cli.validation.HdfsValidationTask
Constructor of HdfsValidationTask.
HdfsWorker(int, int, int, ByteBuffer, boolean, String) - Constructor for class alluxio.examples.Performance.HdfsWorker
 
HeadCommand - Class in alluxio.cli.fs.command
Prints the file's first n bytes (by default, 1KB) to the console.
HeadCommand(FileSystem) - Constructor for class alluxio.cli.fs.command.HeadCommand
 
HEADER - Static variable in class alluxio.Constants
 
HEADER_COS - Static variable in class alluxio.Constants
 
HEADER_FT - Static variable in class alluxio.Constants
 
HEADER_GCS - Static variable in class alluxio.Constants
 
HEADER_OSS - Static variable in class alluxio.Constants
 
HEADER_S3 - Static variable in class alluxio.Constants
 
HEADER_S3A - Static variable in class alluxio.Constants
 
HEADER_SWIFT - Static variable in class alluxio.Constants
 
HealthCheckClient - Interface in alluxio
Client for checking service availability.
heartbeat() - Method in class alluxio.client.metrics.ClientMasterSync
 
heartbeat(List<Metric>) - Method in class alluxio.client.metrics.MetricsMasterClient
The method the worker should periodically execute to heartbeat back to the master.
heartbeat() - Method in interface alluxio.heartbeat.HeartbeatExecutor
Implements the heartbeat logic.
heartbeat() - Method in class alluxio.master.file.BlockIntegrityChecker
 
heartbeat() - Method in class alluxio.master.lineage.checkpoint.CheckpointSchedulingExecutor
 
heartbeat() - Method in class alluxio.master.lineage.recompute.RecomputeExecutor
 
heartbeat() - Method in class alluxio.master.meta.MetaMasterSync
Heartbeats to the leader master node.
heartbeat(long) - Method in class alluxio.master.meta.RetryHandlingMetaMasterMasterClient
Sends a heartbeat to the leader master.
heartbeat() - Method in class alluxio.SessionInfo
Performs a session heartbeat.
heartbeat(long, Map<String, Long>, List<Long>, Map<String, List<Long>>, List<Metric>) - Method in class alluxio.worker.block.BlockMasterClient
The method the worker should periodically execute to heartbeat back to the master.
heartbeat() - Method in class alluxio.worker.block.BlockMasterSync
Heartbeats to the master node about the change in the worker's managed space.
heartbeat() - Method in class alluxio.worker.block.PinListSync
 
heartbeat() - Method in class alluxio.worker.block.SpaceReserver
 
heartbeat(long, List<Long>) - Method in class alluxio.worker.file.FileSystemMasterClient
Heartbeats to the master.
heartbeat(long, List<Long>, FileSystemHeartbeatTOptions) - Method in class alluxio.worker.file.FileSystemMasterClient
Heartbeats to the master.
HeartbeatContext - Class in alluxio.heartbeat
This is a static class for storing and retrieving heartbeat related information.
HeartbeatExecutor - Interface in alluxio.heartbeat
An interface for a heartbeat execution.
HeartbeatHandler - Class in alluxio.worker.netty
A handler for heartbeat events.
HeartbeatHandler() - Constructor for class alluxio.worker.netty.HeartbeatHandler
Constructs a new heartbeat handler.
HeartbeatScheduler - Class in alluxio.heartbeat
This class can be used for controlling heartbeat execution of a thread.
HeartbeatThread - Class in alluxio.heartbeat
Thread class to execute a heartbeat periodically.
HeartbeatThread(String, HeartbeatExecutor, long) - Constructor for class alluxio.heartbeat.HeartbeatThread
Creates a Runnable to execute heartbeats for the given HeartbeatExecutor.
HeartbeatTimer - Interface in alluxio.heartbeat
An interface for heartbeat timers.
HELP_OPTION_NAME - Static variable in class alluxio.cli.fsadmin.command.DoctorCommand
 
HELP_OPTION_NAME - Static variable in class alluxio.cli.fsadmin.command.ReportCommand
 
HelpCommand - Class in alluxio.cli.fs.command
Command for print help message for the given command.
HelpCommand(FileSystem) - Constructor for class alluxio.cli.fs.command.HelpCommand
 
HFSUtils - Class in alluxio.util
Utility method called in alluxio-mount.sh to calculate space for Mac OS X HFS+.
HiveIntegrationChecker - Class in alluxio.checker
Some Hive queries to test the integration of Hive with Alluxio.
HiveIntegrationChecker() - Constructor for class alluxio.checker.HiveIntegrationChecker
 
HiveIntegrationChecker.Mode - Enum in alluxio.checker
Hive and Alluxio integration mode.
HiveIntegrationChecker.ModeConverter - Class in alluxio.checker
Converts input string USER_MODE to enum Mode.
HOME - Static variable in class alluxio.PropertyKey
 
HOME - Static variable in class alluxio.PropertyKey.Name
 
HOUR - Static variable in class alluxio.Constants
 
HOUR_MS - Static variable in class alluxio.Constants
 
HttpUtils - Class in alluxio.util.network
Utility methods for working with http.
HttpUtils.IProcessInputStream - Interface in alluxio.util.network
This interface should be implemented by the http response body stream processor.

I

IBM_JAVA - Static variable in class alluxio.util.OSUtils
Indicates the current java vendor is IBM java or not.
ID_FIELD_NUMBER - Static variable in class alluxio.proto.dataserver.Protocol.WriteRequest
 
ID_FIELD_NUMBER - Static variable in class alluxio.proto.journal.File.CompleteFileEntry
 
ID_FIELD_NUMBER - Static variable in class alluxio.proto.journal.File.DeleteFileEntry
 
ID_FIELD_NUMBER - Static variable in class alluxio.proto.journal.File.InodeDirectoryEntry
 
ID_FIELD_NUMBER - Static variable in class alluxio.proto.journal.File.InodeFileEntry
 
ID_FIELD_NUMBER - Static variable in class alluxio.proto.journal.File.InodeLastModificationTimeEntry
 
ID_FIELD_NUMBER - Static variable in class alluxio.proto.journal.File.PersistDirectoryEntry
 
ID_FIELD_NUMBER - Static variable in class alluxio.proto.journal.File.PersistFileEntry
 
ID_FIELD_NUMBER - Static variable in class alluxio.proto.journal.File.RenameEntry
 
ID_FIELD_NUMBER - Static variable in class alluxio.proto.journal.File.SetAttributeEntry
 
ID_FIELD_NUMBER - Static variable in class alluxio.proto.journal.Lineage.LineageEntry
 
ID_PARAM - Static variable in class alluxio.proxy.StreamsRestServiceHandler
 
IdentityUserGroupsMapping - Class in alluxio.security.group.provider
A simple implementation of GroupMappingService that returns a group which is same name with the given user name.
IdentityUserGroupsMapping() - Constructor for class alluxio.security.group.provider.IdentityUserGroupsMapping
Constructs a new IdentityUserGroupsMapping.
IdleReadHandler - Class in alluxio.worker.netty
Closes the channel if it has been idle for too long.
IdleReadHandler() - Constructor for class alluxio.worker.netty.IdleReadHandler
Creates a new idle read handler.
IdleWriteHandler - Class in alluxio.network.netty
Sends a keep-alive to the server whenever the channel has been idle for a period of time.
IdleWriteHandler() - Constructor for class alluxio.network.netty.IdleWriteHandler
Creates a new idle write handler.
idList() - Method in class alluxio.worker.file.FileDataManager.PersistedFilesInfo
 
IdUtils - Class in alluxio.util
Utility methods for working with an id in Alluxio.
IMPERSONATION_HDFS_USER - Static variable in class alluxio.Constants
 
IMPERSONATION_NONE - Static variable in class alluxio.Constants
 
ImpersonationAuthenticator - Class in alluxio.security.authentication
An authenticator for impersonation users.
ImpersonationAuthenticator() - Constructor for class alluxio.security.authentication.ImpersonationAuthenticator
Constructs a new ImpersonationAuthenticator.
imply(Mode.Bits) - Method in enum alluxio.security.authorization.Mode.Bits
Checks whether these bits imply the given bits.
IN_ALLUXIO_STATE_DIR - Static variable in class alluxio.cli.fs.command.LsCommand
 
IN_ALLUXIO_STATE_FILE_FORMAT - Static variable in class alluxio.cli.fs.command.LsCommand
 
InconsistentProperty - Class in alluxio.thrift
 
InconsistentProperty() - Constructor for class alluxio.thrift.InconsistentProperty
 
InconsistentProperty(String, Map<OptionalString, List<String>>) - Constructor for class alluxio.thrift.InconsistentProperty
 
InconsistentProperty(InconsistentProperty) - Constructor for class alluxio.thrift.InconsistentProperty
Performs a deep copy on other.
InconsistentProperty - Class in alluxio.wire
Records a property that is required or recommended to be consistent but is not within its scope.
InconsistentProperty() - Constructor for class alluxio.wire.InconsistentProperty
Creates a new instance of InconsistentProperty.
InconsistentProperty(InconsistentProperty) - Constructor for class alluxio.wire.InconsistentProperty
Creates a new instance of InconsistentProperty from thrift representation.
InconsistentProperty._Fields - Enum in alluxio.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
increaseUsageCount() - Method in class alluxio.worker.block.io.LocalFileBlockReader
increase the file reader usage count.
Index - Interface in alluxio.client.keyvalue
Interface of key-value index.
IndexDefinition<T> - Class in alluxio.collections
A class representing the definition of an index for this IndexedSet.
IndexDefinition(boolean) - Constructor for class alluxio.collections.IndexDefinition
Constructs a new IndexDefinition instance.
IndexedSet<T> - Class in alluxio.collections
A set of objects that are indexed and thus can be queried by specific fields of the object.
IndexedSet(IndexDefinition<T>, IndexDefinition<T>...) - Constructor for class alluxio.collections.IndexedSet
Constructs a new IndexedSet instance with at least one field as the index.
indexHash(byte[]) - Method in class alluxio.client.keyvalue.LinearProbingIndex
Hashes a key in byte array to a bucket index in non-negative integer value.
indexHash(ByteBuffer) - Method in class alluxio.client.keyvalue.LinearProbingIndex
Hashes a key in ByteBuffer to a bucket index in non-negative integer value.
info(String) - Method in class alluxio.util.logging.SamplingLogger
 
info(String, Object) - Method in class alluxio.util.logging.SamplingLogger
 
info(String, Object, Object) - Method in class alluxio.util.logging.SamplingLogger
 
info(String, Object...) - Method in class alluxio.util.logging.SamplingLogger
 
info(String, Throwable) - Method in class alluxio.util.logging.SamplingLogger
 
info(Marker, String) - Method in class alluxio.util.logging.SamplingLogger
 
info(Marker, String, Object) - Method in class alluxio.util.logging.SamplingLogger
 
info(Marker, String, Object, Object) - Method in class alluxio.util.logging.SamplingLogger
 
info(Marker, String, Object...) - Method in class alluxio.util.logging.SamplingLogger
 
info(Marker, String, Throwable) - Method in class alluxio.util.logging.SamplingLogger
 
initConfiguration() - Method in class alluxio.master.AbstractLocalAlluxioCluster
Creates a default Configuration for testing.
initFromBackup(InputStream) - Method in class alluxio.master.BackupManager
Restores master state from the specified backup.
initFromJournalEntry(File.InodeDirectoryIdGeneratorEntry) - Method in class alluxio.master.file.meta.InodeDirectoryIdGenerator
Initializes the object using a journal entry.
initFromJournalEntry(Lineage.LineageIdGeneratorEntry) - Method in class alluxio.master.lineage.meta.LineageIdGenerator
Constructs the generator from a journal entry.
initialize(Subject, CallbackHandler, Map<String, ?>, Map<String, ?>) - Method in class alluxio.security.login.AlluxioLoginModule
 
initialize(Subject, CallbackHandler, Map<String, ?>, Map<String, ?>) - Method in class alluxio.security.login.AppLoginModule
 
initializeRoot(String, String, Mode, JournalContext) - Method in class alluxio.master.file.meta.InodeTree
Initializes the root of the inode tree.
InitiateMultipartUploadResult - Class in alluxio.proxy.s3
Result returned after requests for initiating a multipart upload.
InitiateMultipartUploadResult() - Constructor for class alluxio.proxy.s3.InitiateMultipartUploadResult
Constructs an InitiateMultipartUploadResult with fields initialized to empty strings.
InitiateMultipartUploadResult(String, String, String) - Constructor for class alluxio.proxy.s3.InitiateMultipartUploadResult
Constructs an InitiateMultipartUploadResult with the specified values.
initiateOrCompleteMultipartUpload(String, String, String, Long) - Method in class alluxio.proxy.s3.S3RestServiceHandler
 
initReportFile() - Static method in class alluxio.checker.CheckerUtils
 
initRequestContext(BlockWriteRequestContext) - Method in class alluxio.worker.netty.BlockWriteHandler
 
initRequestContext(UfsFileWriteRequestContext) - Method in class alluxio.worker.netty.UfsFileWriteHandler
 
inList(String) - Method in class alluxio.collections.PrefixList
Checks whether a prefix of path is in the prefix list.
Inode<T> - Class in alluxio.master.file.meta
Inode is an abstract class, with information shared by all types of Inodes.
Inode(long, boolean) - Constructor for class alluxio.master.file.meta.Inode
 
INODE_DIRECTORY_FIELD_NUMBER - Static variable in class alluxio.proto.journal.Journal.JournalEntry
 
INODE_DIRECTORY_ID_GENERATOR_FIELD_NUMBER - Static variable in class alluxio.proto.journal.Journal.JournalEntry
 
INODE_FILE_FIELD_NUMBER - Static variable in class alluxio.proto.journal.Journal.JournalEntry
 
INODE_LAST_MODIFICATION_TIME_FIELD_NUMBER - Static variable in class alluxio.proto.journal.Journal.JournalEntry
 
InodeDirectory - Class in alluxio.master.file.meta
Alluxio file system's directory representation in the file system master.
InodeDirectoryIdGenerator - Class in alluxio.master.file.meta
Inode id management for directory inodes.
InodeDirectoryIdGenerator(ContainerIdGenerable) - Constructor for class alluxio.master.file.meta.InodeDirectoryIdGenerator
 
InodeFile - Class in alluxio.master.file.meta
Alluxio file system's file representation in the file system master.
inodeIdExists(long) - Method in class alluxio.master.file.meta.InodeTree
 
InodeLockList - Class in alluxio.master.file.meta
Manages the locks for a list of Inode.
InodeLockList() - Constructor for class alluxio.master.file.meta.InodeLockList
Creates a new instance of InodeLockList.
inodePathExists(AlluxioURI) - Method in class alluxio.master.file.meta.InodeTree
 
InodePathPair - Class in alluxio.master.file.meta
This class represents a pair of LockedInodePaths.
InodePermissionChecker - Interface in alluxio.master.file
Checks and gets permitted actions on Inodes.
InodeTree - Class in alluxio.master.file.meta
Represents the tree of Inodes.
InodeTree(ContainerIdGenerable, InodeDirectoryIdGenerator, MountTable) - Constructor for class alluxio.master.file.meta.InodeTree
 
InodeTree.CreatePathResult - Class in alluxio.master.file.meta
Represents the results of creating a path in the inode tree.
InodeTree.LockMode - Enum in alluxio.master.file.meta
The type of lock to lock inode paths with.
inodeUfsIsContentSynced(Inode, Fingerprint) - Static method in class alluxio.master.file.meta.UfsSyncUtils
Returns true if the given inode's content is synced with the ufs status.
inodeUfsIsMetadataSynced(Inode, Fingerprint) - Static method in class alluxio.master.file.meta.UfsSyncUtils
Returns true if the given inode's metadata matches the ufs fingerprint.
INPUT_FILES_FIELD_NUMBER - Static variable in class alluxio.proto.journal.Lineage.LineageEntry
 
insert(byte[], byte[]) - Method in interface alluxio.client.keyvalue.PayloadWriter
Inserts a key and a value into the payload buffer, returns an offset indicating where the key and value data is stored in payload buffer.
insert(Inode<?>) - Method in class alluxio.master.file.meta.TtlBucketList
Inserts an Inode to the appropriate bucket where its ttl end time lies in the bucket's interval, if no appropriate bucket exists, a new bucket will be created to contain this inode, if ttl value is Constants.NO_TTL, the inode won't be inserted to any buckets and nothing will happen.
InstallCommand - Class in alluxio.cli.extensions.command
Install a new extension.
InstallCommand() - Constructor for class alluxio.cli.extensions.command.InstallCommand
Constructs a new instance of InstallCommand.
INSTANCE - Static variable in class alluxio.master.file.NoopBlockDeletionContext
 
INSTANCE - Static variable in class alluxio.master.file.NoopUfsDeleter
 
INSTANCE - Static variable in class alluxio.master.journal.NoopJournalContext
 
INSTANCE - Static variable in class alluxio.time.ThreadSleeper
 
InstancedConfiguration - Class in alluxio.conf
Alluxio configuration.
InstancedConfiguration(AlluxioProperties) - Constructor for class alluxio.conf.InstancedConfiguration
 
InstancedConfiguration(InstancedConfiguration) - Constructor for class alluxio.conf.InstancedConfiguration
 
instant() - Method in class alluxio.clock.ElapsedTimeClock
 
instant() - Method in class alluxio.clock.SystemClock
 
InStreamOptions - Class in alluxio.client.file.options
Information for reading a file.
InStreamOptions(URIStatus) - Constructor for class alluxio.client.file.options.InStreamOptions
Creates with the default OpenFileOptions.
InStreamOptions(URIStatus, OpenFileOptions) - Constructor for class alluxio.client.file.options.InStreamOptions
Creates based on the arguments provided.
intAsUnsignedByteValue(int) - Static method in class alluxio.util.io.BufferUtils
Gets the unsigned byte value of an integer.
INTEGRATION_MASTER_RESOURCE_CPU - Static variable in class alluxio.PropertyKey
 
INTEGRATION_MASTER_RESOURCE_CPU - Static variable in class alluxio.PropertyKey.Name
 
INTEGRATION_MASTER_RESOURCE_MEM - Static variable in class alluxio.PropertyKey
 
INTEGRATION_MASTER_RESOURCE_MEM - Static variable in class alluxio.PropertyKey.Name
 
INTEGRATION_MESOS_ALLUXIO_JAR_URL - Static variable in class alluxio.PropertyKey
 
INTEGRATION_MESOS_ALLUXIO_JAR_URL - Static variable in class alluxio.PropertyKey.Name
 
INTEGRATION_MESOS_ALLUXIO_MASTER_NAME - Static variable in class alluxio.PropertyKey
 
INTEGRATION_MESOS_ALLUXIO_MASTER_NAME - Static variable in class alluxio.PropertyKey.Name
 
INTEGRATION_MESOS_ALLUXIO_MASTER_NODE_COUNT - Static variable in class alluxio.PropertyKey
 
INTEGRATION_MESOS_ALLUXIO_MASTER_NODE_COUNT - Static variable in class alluxio.PropertyKey.Name
 
INTEGRATION_MESOS_ALLUXIO_WORKER_NAME - Static variable in class alluxio.PropertyKey
 
INTEGRATION_MESOS_ALLUXIO_WORKER_NAME - Static variable in class alluxio.PropertyKey.Name
 
INTEGRATION_MESOS_JDK_PATH - Static variable in class alluxio.PropertyKey
 
INTEGRATION_MESOS_JDK_PATH - Static variable in class alluxio.PropertyKey.Name
 
INTEGRATION_MESOS_JDK_URL - Static variable in class alluxio.PropertyKey
 
INTEGRATION_MESOS_JDK_URL - Static variable in class alluxio.PropertyKey.Name
 
INTEGRATION_MESOS_PRINCIPAL - Static variable in class alluxio.PropertyKey
 
INTEGRATION_MESOS_PRINCIPAL - Static variable in class alluxio.PropertyKey.Name
 
INTEGRATION_MESOS_ROLE - Static variable in class alluxio.PropertyKey
 
INTEGRATION_MESOS_ROLE - Static variable in class alluxio.PropertyKey.Name
 
INTEGRATION_MESOS_SECRET - Static variable in class alluxio.PropertyKey
 
INTEGRATION_MESOS_SECRET - Static variable in class alluxio.PropertyKey.Name
 
INTEGRATION_MESOS_USER - Static variable in class alluxio.PropertyKey
 
INTEGRATION_MESOS_USER - Static variable in class alluxio.PropertyKey.Name
 
INTEGRATION_WORKER_RESOURCE_CPU - Static variable in class alluxio.PropertyKey
 
INTEGRATION_WORKER_RESOURCE_CPU - Static variable in class alluxio.PropertyKey.Name
 
INTEGRATION_WORKER_RESOURCE_MEM - Static variable in class alluxio.PropertyKey
 
INTEGRATION_WORKER_RESOURCE_MEM - Static variable in class alluxio.PropertyKey.Name
 
INTEGRATION_YARN_WORKERS_PER_HOST_MAX - Static variable in class alluxio.PropertyKey
 
INTEGRATION_YARN_WORKERS_PER_HOST_MAX - Static variable in class alluxio.PropertyKey.Name
 
INTERNAL_ERROR - Static variable in class alluxio.proxy.s3.S3ErrorCode
 
INTERNAL_ERROR - Static variable in class alluxio.proxy.s3.S3ErrorCode.Name
 
INTERNAL_SESSION_ID_BASE - Static variable in class alluxio.Sessions
 
INTERNAL_VALUE - Static variable in enum alluxio.proto.status.Status.PStatus
INTERNAL = 13;
InternalException - Exception in alluxio.exception.status
Exception representing an internal error.
InternalException(String) - Constructor for exception alluxio.exception.status.InternalException
 
InternalException(Throwable) - Constructor for exception alluxio.exception.status.InternalException
 
InternalException(String, Throwable) - Constructor for exception alluxio.exception.status.InternalException
 
internalGetFieldAccessorTable() - Method in class alluxio.proto.dataserver.Protocol.AsyncCacheRequest.Builder
 
internalGetFieldAccessorTable() - Method in class alluxio.proto.dataserver.Protocol.AsyncCacheRequest
 
internalGetFieldAccessorTable() - Method in class alluxio.proto.dataserver.Protocol.CreateUfsFileOptions.Builder
 
internalGetFieldAccessorTable() - Method in class alluxio.proto.dataserver.Protocol.CreateUfsFileOptions
 
internalGetFieldAccessorTable() - Method in class alluxio.proto.dataserver.Protocol.Heartbeat.Builder
 
internalGetFieldAccessorTable() - Method in class alluxio.proto.dataserver.Protocol.Heartbeat
 
internalGetFieldAccessorTable() - Method in class alluxio.proto.dataserver.Protocol.LocalBlockCloseRequest.Builder
 
internalGetFieldAccessorTable() - Method in class alluxio.proto.dataserver.Protocol.LocalBlockCloseRequest
 
internalGetFieldAccessorTable() - Method in class alluxio.proto.dataserver.Protocol.LocalBlockCompleteRequest.Builder
 
internalGetFieldAccessorTable() - Method in class alluxio.proto.dataserver.Protocol.LocalBlockCompleteRequest
 
internalGetFieldAccessorTable() - Method in class alluxio.proto.dataserver.Protocol.LocalBlockCreateRequest.Builder
 
internalGetFieldAccessorTable() - Method in class alluxio.proto.dataserver.Protocol.LocalBlockCreateRequest
 
internalGetFieldAccessorTable() - Method in class alluxio.proto.dataserver.Protocol.LocalBlockCreateResponse.Builder
 
internalGetFieldAccessorTable() - Method in class alluxio.proto.dataserver.Protocol.LocalBlockCreateResponse
 
internalGetFieldAccessorTable() - Method in class alluxio.proto.dataserver.Protocol.LocalBlockOpenRequest.Builder
 
internalGetFieldAccessorTable() - Method in class alluxio.proto.dataserver.Protocol.LocalBlockOpenRequest
 
internalGetFieldAccessorTable() - Method in class alluxio.proto.dataserver.Protocol.LocalBlockOpenResponse.Builder
 
internalGetFieldAccessorTable() - Method in class alluxio.proto.dataserver.Protocol.LocalBlockOpenResponse
 
internalGetFieldAccessorTable() - Method in class alluxio.proto.dataserver.Protocol.OpenUfsBlockOptions.Builder
 
internalGetFieldAccessorTable() - Method in class alluxio.proto.dataserver.Protocol.OpenUfsBlockOptions
 
internalGetFieldAccessorTable() - Method in class alluxio.proto.dataserver.Protocol.ReadRequest.Builder
 
internalGetFieldAccessorTable() - Method in class alluxio.proto.dataserver.Protocol.ReadRequest
 
internalGetFieldAccessorTable() - Method in class alluxio.proto.dataserver.Protocol.ReadResponse.Builder
 
internalGetFieldAccessorTable() - Method in class alluxio.proto.dataserver.Protocol.ReadResponse
 
internalGetFieldAccessorTable() - Method in class alluxio.proto.dataserver.Protocol.Response.Builder
 
internalGetFieldAccessorTable() - Method in class alluxio.proto.dataserver.Protocol.Response
 
internalGetFieldAccessorTable() - Method in class alluxio.proto.dataserver.Protocol.WriteRequest.Builder
 
internalGetFieldAccessorTable() - Method in class alluxio.proto.dataserver.Protocol.WriteRequest
 
internalGetFieldAccessorTable() - Method in class alluxio.proto.journal.Block.BlockContainerIdGeneratorEntry.Builder
 
internalGetFieldAccessorTable() - Method in class alluxio.proto.journal.Block.BlockContainerIdGeneratorEntry
 
internalGetFieldAccessorTable() - Method in class alluxio.proto.journal.Block.BlockInfoEntry.Builder
 
internalGetFieldAccessorTable() - Method in class alluxio.proto.journal.Block.BlockInfoEntry
 
internalGetFieldAccessorTable() - Method in class alluxio.proto.journal.Block.DeleteBlockEntry.Builder
 
internalGetFieldAccessorTable() - Method in class alluxio.proto.journal.Block.DeleteBlockEntry
 
internalGetFieldAccessorTable() - Method in class alluxio.proto.journal.File.AddMountPointEntry.Builder
 
internalGetFieldAccessorTable() - Method in class alluxio.proto.journal.File.AddMountPointEntry
 
internalGetFieldAccessorTable() - Method in class alluxio.proto.journal.File.AsyncPersistRequestEntry.Builder
 
internalGetFieldAccessorTable() - Method in class alluxio.proto.journal.File.AsyncPersistRequestEntry
 
internalGetFieldAccessorTable() - Method in class alluxio.proto.journal.File.CompleteFileEntry.Builder
 
internalGetFieldAccessorTable() - Method in class alluxio.proto.journal.File.CompleteFileEntry
 
internalGetFieldAccessorTable() - Method in class alluxio.proto.journal.File.DeleteFileEntry.Builder
 
internalGetFieldAccessorTable() - Method in class alluxio.proto.journal.File.DeleteFileEntry
 
internalGetFieldAccessorTable() - Method in class alluxio.proto.journal.File.DeleteMountPointEntry.Builder
 
internalGetFieldAccessorTable() - Method in class alluxio.proto.journal.File.DeleteMountPointEntry
 
internalGetFieldAccessorTable() - Method in class alluxio.proto.journal.File.InodeDirectoryEntry.Builder
 
internalGetFieldAccessorTable() - Method in class alluxio.proto.journal.File.InodeDirectoryEntry
 
internalGetFieldAccessorTable() - Method in class alluxio.proto.journal.File.InodeDirectoryIdGeneratorEntry.Builder
 
internalGetFieldAccessorTable() - Method in class alluxio.proto.journal.File.InodeDirectoryIdGeneratorEntry
 
internalGetFieldAccessorTable() - Method in class alluxio.proto.journal.File.InodeFileEntry.Builder
 
internalGetFieldAccessorTable() - Method in class alluxio.proto.journal.File.InodeFileEntry
 
internalGetFieldAccessorTable() - Method in class alluxio.proto.journal.File.InodeLastModificationTimeEntry.Builder
 
internalGetFieldAccessorTable() - Method in class alluxio.proto.journal.File.InodeLastModificationTimeEntry
 
internalGetFieldAccessorTable() - Method in class alluxio.proto.journal.File.PersistDirectoryEntry.Builder
 
internalGetFieldAccessorTable() - Method in class alluxio.proto.journal.File.PersistDirectoryEntry
 
internalGetFieldAccessorTable() - Method in class alluxio.proto.journal.File.PersistFileEntry.Builder
 
internalGetFieldAccessorTable() - Method in class alluxio.proto.journal.File.PersistFileEntry
 
internalGetFieldAccessorTable() - Method in class alluxio.proto.journal.File.ReinitializeFileEntry.Builder
 
internalGetFieldAccessorTable() - Method in class alluxio.proto.journal.File.ReinitializeFileEntry
 
internalGetFieldAccessorTable() - Method in class alluxio.proto.journal.File.RenameEntry.Builder
 
internalGetFieldAccessorTable() - Method in class alluxio.proto.journal.File.RenameEntry
 
internalGetFieldAccessorTable() - Method in class alluxio.proto.journal.File.SetAttributeEntry.Builder
 
internalGetFieldAccessorTable() - Method in class alluxio.proto.journal.File.SetAttributeEntry
 
internalGetFieldAccessorTable() - Method in class alluxio.proto.journal.File.StringPairEntry.Builder
 
internalGetFieldAccessorTable() - Method in class alluxio.proto.journal.File.StringPairEntry
 
internalGetFieldAccessorTable() - Method in class alluxio.proto.journal.File.UpdateUfsModeEntry.Builder
 
internalGetFieldAccessorTable() - Method in class alluxio.proto.journal.File.UpdateUfsModeEntry
 
internalGetFieldAccessorTable() - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
 
internalGetFieldAccessorTable() - Method in class alluxio.proto.journal.Journal.JournalEntry
 
internalGetFieldAccessorTable() - Method in class alluxio.proto.journal.KeyValue.CompletePartitionEntry.Builder
 
internalGetFieldAccessorTable() - Method in class alluxio.proto.journal.KeyValue.CompletePartitionEntry
 
internalGetFieldAccessorTable() - Method in class alluxio.proto.journal.KeyValue.CompleteStoreEntry.Builder
 
internalGetFieldAccessorTable() - Method in class alluxio.proto.journal.KeyValue.CompleteStoreEntry
 
internalGetFieldAccessorTable() - Method in class alluxio.proto.journal.KeyValue.CreateStoreEntry.Builder
 
internalGetFieldAccessorTable() - Method in class alluxio.proto.journal.KeyValue.CreateStoreEntry
 
internalGetFieldAccessorTable() - Method in class alluxio.proto.journal.KeyValue.DeleteStoreEntry.Builder
 
internalGetFieldAccessorTable() - Method in class alluxio.proto.journal.KeyValue.DeleteStoreEntry
 
internalGetFieldAccessorTable() - Method in class alluxio.proto.journal.KeyValue.MergeStoreEntry.Builder
 
internalGetFieldAccessorTable() - Method in class alluxio.proto.journal.KeyValue.MergeStoreEntry
 
internalGetFieldAccessorTable() - Method in class alluxio.proto.journal.KeyValue.RenameStoreEntry.Builder
 
internalGetFieldAccessorTable() - Method in class alluxio.proto.journal.KeyValue.RenameStoreEntry
 
internalGetFieldAccessorTable() - Method in class alluxio.proto.journal.Lineage.DeleteLineageEntry.Builder
 
internalGetFieldAccessorTable() - Method in class alluxio.proto.journal.Lineage.DeleteLineageEntry
 
internalGetFieldAccessorTable() - Method in class alluxio.proto.journal.Lineage.LineageEntry.Builder
 
internalGetFieldAccessorTable() - Method in class alluxio.proto.journal.Lineage.LineageEntry
 
internalGetFieldAccessorTable() - Method in class alluxio.proto.journal.Lineage.LineageIdGeneratorEntry.Builder
 
internalGetFieldAccessorTable() - Method in class alluxio.proto.journal.Lineage.LineageIdGeneratorEntry
 
internalGetValueMap() - Static method in enum alluxio.proto.dataserver.Protocol.ReadResponse.Type
 
internalGetValueMap() - Static method in enum alluxio.proto.dataserver.Protocol.RequestType
 
internalGetValueMap() - Static method in enum alluxio.proto.journal.File.PTtlAction
 
internalGetValueMap() - Static method in enum alluxio.proto.journal.File.UfsMode
 
internalGetValueMap() - Static method in enum alluxio.proto.status.Status.PStatus
 
INVALID_ARGUMENT_VALUE - Static variable in enum alluxio.proto.status.Status.PStatus
INVALID_ARGUMENT = 3;
INVALID_BUCKET_NAME - Static variable in class alluxio.proxy.s3.S3ErrorCode
 
INVALID_BUCKET_NAME - Static variable in class alluxio.proxy.s3.S3ErrorCode.Name
 
INVALID_CONTENT_HASH - Static variable in class alluxio.underfs.UfsFileStatus
 
INVALID_FILE_ID - Static variable in class alluxio.util.IdUtils
 
INVALID_LOCK_ID - Static variable in class alluxio.worker.block.BlockLockManager
Invalid lock ID.
INVALID_MODE - Static variable in class alluxio.Constants
 
INVALID_MOUNT_ID - Static variable in class alluxio.util.IdUtils
 
INVALID_NESTED_BUCKET_NAME - Static variable in class alluxio.proxy.s3.S3ErrorCode
 
INVALID_UFS_FINGERPRINT - Static variable in class alluxio.Constants
 
INVALID_WORKER_ID - Static variable in class alluxio.util.IdUtils
 
InvalidArgumentException - Exception in alluxio.exception.status
Exception indicating that a client specified an invalid argument.
InvalidArgumentException(String) - Constructor for exception alluxio.exception.status.InvalidArgumentException
 
InvalidArgumentException(Throwable) - Constructor for exception alluxio.exception.status.InvalidArgumentException
 
InvalidArgumentException(String, Throwable) - Constructor for exception alluxio.exception.status.InvalidArgumentException
 
invalidate(long) - Method in class alluxio.master.file.meta.LazyUfsBlockLocationCache
 
invalidate(long) - Method in interface alluxio.master.file.meta.UfsBlockLocationCache
Invalidates the UFS locations for the block.
invalidate(Integer) - Method in class alluxio.StreamCache
 
invalidate(CachedSeekableInputStream) - Method in class alluxio.worker.block.UfsInputStreamManager
Invalidates an input stream from the cache.
InvalidFileSizeException - Exception in alluxio.exception
The exception thrown when the file of a size is invalid.
InvalidFileSizeException(String) - Constructor for exception alluxio.exception.InvalidFileSizeException
Constructs a new exception with the specified detail message.
InvalidFileSizeException(String, Throwable) - Constructor for exception alluxio.exception.InvalidFileSizeException
Constructs a new exception with the specified detail message and cause.
InvalidFileSizeException(ExceptionMessage, Object...) - Constructor for exception alluxio.exception.InvalidFileSizeException
Constructs a new exception with the specified exception message and multiple parameters.
InvalidFileSizeException(ExceptionMessage, Throwable, Object...) - Constructor for exception alluxio.exception.InvalidFileSizeException
Constructs a new exception with the specified exception message, the cause and multiple parameters.
InvalidJournalEntryException - Exception in alluxio.exception
The exception thrown when we have seen an invalid journal entry.
InvalidJournalEntryException(String) - Constructor for exception alluxio.exception.InvalidJournalEntryException
Constructs a new exception with the specified detail message.
InvalidJournalEntryException(String, Throwable) - Constructor for exception alluxio.exception.InvalidJournalEntryException
Constructs a new exception with the specified detail message and cause.
InvalidJournalEntryException(ExceptionMessage, Object...) - Constructor for exception alluxio.exception.InvalidJournalEntryException
Constructs a new exception with the specified exception message and multiple parameters.
InvalidJournalEntryException(ExceptionMessage, Throwable, Object...) - Constructor for exception alluxio.exception.InvalidJournalEntryException
Constructs a new exception with the specified exception message, the cause and multiple parameters.
InvalidPathException - Exception in alluxio.exception
The exception thrown when the path in Alluxio is invalid.
InvalidPathException(String) - Constructor for exception alluxio.exception.InvalidPathException
Constructs a new exception with the specified detail message.
InvalidPathException(String, Throwable) - Constructor for exception alluxio.exception.InvalidPathException
Constructs a new exception with the specified detail message and cause.
InvalidPathException(ExceptionMessage, Object...) - Constructor for exception alluxio.exception.InvalidPathException
Constructs a new exception with the specified exception message and multiple parameters.
InvalidPathException(ExceptionMessage, Throwable, Object...) - Constructor for exception alluxio.exception.InvalidPathException
Constructs a new exception with the specified exception message, the cause and multiple parameters.
InvalidWorkerStateException - Exception in alluxio.exception
The exception thrown when a worker is in an invalid state, i.e.
InvalidWorkerStateException(String) - Constructor for exception alluxio.exception.InvalidWorkerStateException
Constructs a new exception with the specified detail message.
InvalidWorkerStateException(String, Throwable) - Constructor for exception alluxio.exception.InvalidWorkerStateException
Constructs a new exception with the specified detail message and cause.
InvalidWorkerStateException(ExceptionMessage, Object...) - Constructor for exception alluxio.exception.InvalidWorkerStateException
Constructs a new exception with the specified exception message and multiple parameters.
InvalidWorkerStateException(ExceptionMessage, Throwable, Object...) - Constructor for exception alluxio.exception.InvalidWorkerStateException
Constructs a new exception with the specified exception message, the cause and multiple parameters.
invokeAll(List<Callable<T>>, long, TimeUnit) - Static method in class alluxio.util.CommonUtils
Executes the given callables, waiting for them to complete (or time out).
invokeAll(Collection<? extends Callable<T>>) - Method in class alluxio.util.executor.ControllableScheduler
 
invokeAll(Collection<? extends Callable<T>>, long, TimeUnit) - Method in class alluxio.util.executor.ControllableScheduler
 
invokeAny(Collection<? extends Callable<T>>) - Method in class alluxio.util.executor.ControllableScheduler
 
invokeAny(Collection<? extends Callable<T>>, long, TimeUnit) - Method in class alluxio.util.executor.ControllableScheduler
 
io() - Method in class alluxio.examples.Performance.HdfsWorker
Creates IO utilization.
is64Bit() - Static method in class alluxio.util.OSUtils
 
isAbsent(AlluxioURI) - Method in class alluxio.master.file.meta.AsyncUfsAbsentPathCache
 
isAbsent(AlluxioURI) - Method in class alluxio.master.file.meta.NoopUfsAbsentPathCache
 
isAbsent(AlluxioURI) - Method in interface alluxio.master.file.meta.UfsAbsentPathCache
Returns true if the given path is absent, according to this cache.
isAbsolute() - Method in class alluxio.AlluxioURI
Tells whether or not the AlluxioURI is absolute.
isAbsolute() - Method in class alluxio.StandardURI
 
isAbsolute() - Method in interface alluxio.URI
Tells whether or not the URI is absolute.
isAddressReachable(String, int) - Static method in class alluxio.cli.validation.Utils
Validates whether a network address is reachable.
isAIX() - Static method in class alluxio.util.OSUtils
 
isAllowExists() - Method in class alluxio.client.file.options.CreateDirectoryOptions
 
isAllowExists() - Method in class alluxio.master.file.options.CreateDirectoryOptions
 
isAllowExists() - Method in class alluxio.thrift.CreateDirectoryTOptions
 
isAlluxioOnly() - Method in class alluxio.client.file.options.DeleteOptions
 
isAlluxioOnly() - Method in class alluxio.master.file.options.DeleteOptions
 
isAlluxioOnly() - Method in class alluxio.thrift.DeleteTOptions
 
isAlluxioRunning(String) - Static method in class alluxio.cli.validation.Utils
Checks whether an Alluxio service is running.
isAsync() - Method in enum alluxio.client.WriteType
 
isAsyncCacheRequest() - Method in class alluxio.util.proto.ProtoMessage
 
isAsyncPersist() - Method in enum alluxio.client.UnderStorageType
 
isAuthenticationEnabled() - Static method in class alluxio.util.SecurityUtils
Checks if authentication is enabled.
isAuthorizationEnabled() - Static method in class alluxio.util.SecurityUtils
Checks if authorization is enabled.
isBlockEvictable(long) - Method in class alluxio.worker.block.BlockMetadataManagerView
Tests if the block is evictable.
isBlockLocked(long) - Method in class alluxio.worker.block.BlockMetadataManagerView
Tests if the block is locked.
isBlockMarked(long) - Method in class alluxio.worker.block.BlockMetadataManagerView
Tests if the block is marked to move out of its current dir in this view.
isBlockPinned(long) - Method in class alluxio.worker.block.BlockMetadataManagerView
Tests if the block is pinned.
isBuiltIn() - Method in class alluxio.PropertyKey
 
isCache() - Method in enum alluxio.client.ReadType
 
isCache() - Method in enum alluxio.client.WriteType
 
isCacheable() - Method in class alluxio.client.file.URIStatus
 
isCacheable() - Method in class alluxio.master.file.meta.InodeFile
 
isCacheable() - Method in class alluxio.master.file.options.CreateFileOptions
 
isCacheable() - Method in class alluxio.thrift.FileInfo
 
isCacheable() - Method in class alluxio.wire.FileInfo
 
isCancel() - Method in class alluxio.worker.netty.ReadRequestContext
 
isCascade() - Method in class alluxio.client.lineage.options.DeleteLineageOptions
 
isCascade() - Method in class alluxio.thrift.LineageMasterClientService.deleteLineage_args
whether to delete the lineage in cascade
isClosed() - Method in interface alluxio.worker.block.io.BlockReader
 
isClosed() - Method in class alluxio.worker.block.io.LocalFileBlockReader
 
isClosed() - Method in class alluxio.worker.block.RemoteBlockReader
 
isClosed() - Method in class alluxio.worker.block.UnderFileSystemBlockReader
 
isClosed() - Method in interface alluxio.worker.DataServer
Checks if the DataServer is closed.
isClosed() - Method in class alluxio.worker.netty.NettyDataServer
 
isComplete() - Method in class alluxio.security.authentication.PlainSaslServer
 
isCompleted() - Method in class alluxio.client.file.URIStatus
 
isCompleted() - Method in class alluxio.master.file.meta.InodeFile
 
isCompleted(Lineage, FileSystemMasterView) - Static method in class alluxio.master.lineage.meta.LineageStateUtils
Checks if all the output files of the given lineage are completed.
isCompleted() - Method in class alluxio.thrift.FileInfo
 
isCompleted() - Method in class alluxio.wire.FileInfo
 
isConnected() - Method in class alluxio.AbstractClient
 
isConnected() - Method in interface alluxio.Client
Returns the connected status of the client.
isCreateAncestors() - Method in class alluxio.master.file.options.LoadMetadataOptions
 
isDebugEnabled() - Method in class alluxio.util.logging.SamplingLogger
 
isDebugEnabled(Marker) - Method in class alluxio.util.logging.SamplingLogger
 
isDeleted() - Method in class alluxio.master.file.meta.Inode
 
isDeprecated(String) - Static method in class alluxio.PropertyKey
 
isDirectChildrenLoaded() - Method in class alluxio.master.file.meta.InodeDirectory
 
isDirectory() - Method in class alluxio.master.file.meta.Inode
 
isDirectory(String) - Method in class alluxio.underfs.cos.COSUnderFileSystem
 
isDirectory(String) - Method in class alluxio.underfs.hdfs.HdfsUnderFileSystem
 
isDirectory(String) - Method in class alluxio.underfs.local.LocalUnderFileSystem
 
isDirectory(String) - Method in class alluxio.underfs.ObjectUnderFileSystem
 
isDirectory() - Method in class alluxio.underfs.UfsStatus
 
isDirectory(String) - Method in interface alluxio.underfs.UnderFileSystem
Checks if a directory exists in under file system.
isDirectory(String) - Method in class alluxio.underfs.UnderFileSystemWithLogging
 
isDirectoryInSync(AlluxioURI) - Method in class alluxio.master.file.UfsSyncChecker
Based on directories for which UfsSyncChecker.checkDirectory(InodeDirectory, AlluxioURI) was called, this method returns whether any un-synced entries were found.
isDomainSocketSupported(WorkerNetAddress) - Static method in class alluxio.util.network.NettyUtils
 
isDoneUnsafe() - Method in class alluxio.worker.netty.ReadRequestContext
 
isDoneUnsafe() - Method in class alluxio.worker.netty.WriteRequestContext
 
isEmpty() - Method in class alluxio.collections.ConcurrentHashSet
 
isEmpty() - Method in class alluxio.master.file.meta.CompositeInodeLockList
 
isEmpty() - Method in class alluxio.master.file.meta.InodeLockList
 
isEmpty() - Method in interface alluxio.master.journal.JournalSystem
Returns whether the journal is formatted and has not had any entries written to it yet.
isEmpty() - Method in class alluxio.master.journal.noop.NoopJournalSystem
 
isEmpty() - Method in class alluxio.master.journal.ufs.UfsJournalSystem
 
isEmpty() - Method in class alluxio.master.lineage.checkpoint.CheckpointPlan
 
isEmpty() - Method in class alluxio.master.lineage.recompute.RecomputePlan
 
isEmpty() - Method in class alluxio.util.executor.ControllableQueue
 
isEmpty() - Method in class alluxio.worker.block.evictor.EvictionPlan
Whether the plan is empty, an empty plan means both toMove and toEvict are empty, also, an empty plan indicates no action (move or evict) needs to be taken to meet the requirement.
isEnabled() - Method in class alluxio.master.block.BlockMasterFactory
 
isEnabled() - Method in class alluxio.master.file.FileSystemMasterFactory
 
isEnabled() - Method in class alluxio.master.keyvalue.KeyValueMasterFactory
 
isEnabled() - Method in class alluxio.master.lineage.LineageMasterFactory
 
isEnabled() - Method in interface alluxio.master.MasterFactory
 
isEnabled() - Method in class alluxio.master.meta.MetaMasterFactory
 
isEnabled() - Method in class alluxio.master.metrics.MetricsMasterFactory
 
isEnabled() - Method in class alluxio.worker.block.BlockWorkerFactory
 
isEnabled() - Method in class alluxio.worker.file.FileSystemWorkerFactory
 
isEnabled() - Method in class alluxio.worker.keyvalue.KeyValueWorkerFactory
 
isEnabled() - Method in interface alluxio.worker.WorkerFactory
 
isEnsureAtomic() - Method in class alluxio.underfs.options.CreateOptions
 
isEof() - Method in class alluxio.worker.netty.ReadRequestContext
 
isErrorEnabled() - Method in class alluxio.util.logging.SamplingLogger
 
isErrorEnabled(Marker) - Method in class alluxio.util.logging.SamplingLogger
 
isFile() - Method in class alluxio.master.file.meta.Inode
 
isFile(String) - Method in class alluxio.underfs.hdfs.HdfsUnderFileSystem
 
isFile(String) - Method in class alluxio.underfs.local.LocalUnderFileSystem
 
isFile(String) - Method in class alluxio.underfs.ObjectUnderFileSystem
 
isFile() - Method in class alluxio.underfs.UfsStatus
 
isFile(String) - Method in interface alluxio.underfs.UnderFileSystem
Checks if a file exists in under file system.
isFile(String) - Method in class alluxio.underfs.UnderFileSystemWithLogging
 
isFilePersisted(long) - Method in class alluxio.worker.file.FileDataManager
Checks if the given file is persisted.
isFolder() - Method in class alluxio.client.file.URIStatus
 
isFolder() - Method in class alluxio.thrift.FileInfo
 
isFolder() - Method in class alluxio.wire.FileInfo
 
isForced() - Method in class alluxio.client.file.options.FreeOptions
 
isForced() - Method in class alluxio.master.file.options.FreeOptions
 
isForced() - Method in class alluxio.thrift.FreeTOptions
 
isFormatted() - Method in interface alluxio.master.journal.JournalSystem
 
isFormatted() - Method in class alluxio.master.journal.noop.NoopJournalSystem
 
isFormatted() - Method in class alluxio.master.journal.ufs.UfsJournal
 
isFormatted() - Method in class alluxio.master.journal.ufs.UfsJournalSystem
 
isFormatted() - Method in interface alluxio.master.journalv0.Journal
 
isFormatted() - Method in class alluxio.master.journalv0.ufs.UfsJournal
 
isGcs(UnderFileSystem) - Static method in class alluxio.util.UnderFileSystemUtils
 
isHdfs(UnderFileSystem) - Static method in class alluxio.util.UnderFileSystemUtils
 
isHealthy(BlockMasterClient) - Method in class alluxio.client.block.BlockMasterClientPool
 
isHealthy(FileSystemMasterClient) - Method in class alluxio.client.file.FileSystemMasterClientPool
 
isHealthy(Channel) - Method in class alluxio.network.netty.NettyChannelPool
Checks whether a channel is healthy.
isHealthy(T) - Method in class alluxio.resource.DynamicResourcePool
Checks whether a resource is healthy or not.
isHeartbeat() - Method in class alluxio.util.proto.ProtoMessage
 
isHidden() - Method in class alluxio.PropertyKey
 
isIgnoredSiteProperty() - Method in class alluxio.PropertyKey
 
isInCheckpointing(Lineage, FileSystemMasterView) - Static method in class alluxio.master.lineage.meta.LineageStateUtils
 
isInfoEnabled() - Method in class alluxio.util.logging.SamplingLogger
 
isInfoEnabled(Marker) - Method in class alluxio.util.logging.SamplingLogger
 
isInitialized() - Method in class alluxio.proto.dataserver.Protocol.AsyncCacheRequest.Builder
 
isInitialized() - Method in class alluxio.proto.dataserver.Protocol.AsyncCacheRequest
 
isInitialized() - Method in class alluxio.proto.dataserver.Protocol.CreateUfsFileOptions.Builder
 
isInitialized() - Method in class alluxio.proto.dataserver.Protocol.CreateUfsFileOptions
 
isInitialized() - Method in class alluxio.proto.dataserver.Protocol.Heartbeat.Builder
 
isInitialized() - Method in class alluxio.proto.dataserver.Protocol.Heartbeat
 
isInitialized() - Method in class alluxio.proto.dataserver.Protocol.LocalBlockCloseRequest.Builder
 
isInitialized() - Method in class alluxio.proto.dataserver.Protocol.LocalBlockCloseRequest
 
isInitialized() - Method in class alluxio.proto.dataserver.Protocol.LocalBlockCompleteRequest.Builder
 
isInitialized() - Method in class alluxio.proto.dataserver.Protocol.LocalBlockCompleteRequest
 
isInitialized() - Method in class alluxio.proto.dataserver.Protocol.LocalBlockCreateRequest.Builder
 
isInitialized() - Method in class alluxio.proto.dataserver.Protocol.LocalBlockCreateRequest
 
isInitialized() - Method in class alluxio.proto.dataserver.Protocol.LocalBlockCreateResponse.Builder
 
isInitialized() - Method in class alluxio.proto.dataserver.Protocol.LocalBlockCreateResponse
 
isInitialized() - Method in class alluxio.proto.dataserver.Protocol.LocalBlockOpenRequest.Builder
 
isInitialized() - Method in class alluxio.proto.dataserver.Protocol.LocalBlockOpenRequest
 
isInitialized() - Method in class alluxio.proto.dataserver.Protocol.LocalBlockOpenResponse.Builder
 
isInitialized() - Method in class alluxio.proto.dataserver.Protocol.LocalBlockOpenResponse
 
isInitialized() - Method in class alluxio.proto.dataserver.Protocol.OpenUfsBlockOptions.Builder
 
isInitialized() - Method in class alluxio.proto.dataserver.Protocol.OpenUfsBlockOptions
 
isInitialized() - Method in class alluxio.proto.dataserver.Protocol.ReadRequest.Builder
 
isInitialized() - Method in class alluxio.proto.dataserver.Protocol.ReadRequest
 
isInitialized() - Method in class alluxio.proto.dataserver.Protocol.ReadResponse.Builder
 
isInitialized() - Method in class alluxio.proto.dataserver.Protocol.ReadResponse
 
isInitialized() - Method in class alluxio.proto.dataserver.Protocol.Response.Builder
 
isInitialized() - Method in class alluxio.proto.dataserver.Protocol.Response
 
isInitialized() - Method in class alluxio.proto.dataserver.Protocol.WriteRequest.Builder
 
isInitialized() - Method in class alluxio.proto.dataserver.Protocol.WriteRequest
 
isInitialized() - Method in class alluxio.proto.journal.Block.BlockContainerIdGeneratorEntry.Builder
 
isInitialized() - Method in class alluxio.proto.journal.Block.BlockContainerIdGeneratorEntry
 
isInitialized() - Method in class alluxio.proto.journal.Block.BlockInfoEntry.Builder
 
isInitialized() - Method in class alluxio.proto.journal.Block.BlockInfoEntry
 
isInitialized() - Method in class alluxio.proto.journal.Block.DeleteBlockEntry.Builder
 
isInitialized() - Method in class alluxio.proto.journal.Block.DeleteBlockEntry
 
isInitialized() - Method in class alluxio.proto.journal.File.AddMountPointEntry.Builder
 
isInitialized() - Method in class alluxio.proto.journal.File.AddMountPointEntry
 
isInitialized() - Method in class alluxio.proto.journal.File.AsyncPersistRequestEntry.Builder
 
isInitialized() - Method in class alluxio.proto.journal.File.AsyncPersistRequestEntry
 
isInitialized() - Method in class alluxio.proto.journal.File.CompleteFileEntry.Builder
 
isInitialized() - Method in class alluxio.proto.journal.File.CompleteFileEntry
 
isInitialized() - Method in class alluxio.proto.journal.File.DeleteFileEntry.Builder
 
isInitialized() - Method in class alluxio.proto.journal.File.DeleteFileEntry
 
isInitialized() - Method in class alluxio.proto.journal.File.DeleteMountPointEntry.Builder
 
isInitialized() - Method in class alluxio.proto.journal.File.DeleteMountPointEntry
 
isInitialized() - Method in class alluxio.proto.journal.File.InodeDirectoryEntry.Builder
 
isInitialized() - Method in class alluxio.proto.journal.File.InodeDirectoryEntry
 
isInitialized() - Method in class alluxio.proto.journal.File.InodeDirectoryIdGeneratorEntry.Builder
 
isInitialized() - Method in class alluxio.proto.journal.File.InodeDirectoryIdGeneratorEntry
 
isInitialized() - Method in class alluxio.proto.journal.File.InodeFileEntry.Builder
 
isInitialized() - Method in class alluxio.proto.journal.File.InodeFileEntry
 
isInitialized() - Method in class alluxio.proto.journal.File.InodeLastModificationTimeEntry.Builder
 
isInitialized() - Method in class alluxio.proto.journal.File.InodeLastModificationTimeEntry
 
isInitialized() - Method in class alluxio.proto.journal.File.PersistDirectoryEntry.Builder
 
isInitialized() - Method in class alluxio.proto.journal.File.PersistDirectoryEntry
 
isInitialized() - Method in class alluxio.proto.journal.File.PersistFileEntry.Builder
 
isInitialized() - Method in class alluxio.proto.journal.File.PersistFileEntry
 
isInitialized() - Method in class alluxio.proto.journal.File.ReinitializeFileEntry.Builder
 
isInitialized() - Method in class alluxio.proto.journal.File.ReinitializeFileEntry
 
isInitialized() - Method in class alluxio.proto.journal.File.RenameEntry.Builder
 
isInitialized() - Method in class alluxio.proto.journal.File.RenameEntry
 
isInitialized() - Method in class alluxio.proto.journal.File.SetAttributeEntry.Builder
 
isInitialized() - Method in class alluxio.proto.journal.File.SetAttributeEntry
 
isInitialized() - Method in class alluxio.proto.journal.File.StringPairEntry.Builder
 
isInitialized() - Method in class alluxio.proto.journal.File.StringPairEntry
 
isInitialized() - Method in class alluxio.proto.journal.File.UpdateUfsModeEntry.Builder
 
isInitialized() - Method in class alluxio.proto.journal.File.UpdateUfsModeEntry
 
isInitialized() - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
 
isInitialized() - Method in class alluxio.proto.journal.Journal.JournalEntry
 
isInitialized() - Method in class alluxio.proto.journal.KeyValue.CompletePartitionEntry.Builder
 
isInitialized() - Method in class alluxio.proto.journal.KeyValue.CompletePartitionEntry
 
isInitialized() - Method in class alluxio.proto.journal.KeyValue.CompleteStoreEntry.Builder
 
isInitialized() - Method in class alluxio.proto.journal.KeyValue.CompleteStoreEntry
 
isInitialized() - Method in class alluxio.proto.journal.KeyValue.CreateStoreEntry.Builder
 
isInitialized() - Method in class alluxio.proto.journal.KeyValue.CreateStoreEntry
 
isInitialized() - Method in class alluxio.proto.journal.KeyValue.DeleteStoreEntry.Builder
 
isInitialized() - Method in class alluxio.proto.journal.KeyValue.DeleteStoreEntry
 
isInitialized() - Method in class alluxio.proto.journal.KeyValue.MergeStoreEntry.Builder
 
isInitialized() - Method in class alluxio.proto.journal.KeyValue.MergeStoreEntry
 
isInitialized() - Method in class alluxio.proto.journal.KeyValue.RenameStoreEntry.Builder
 
isInitialized() - Method in class alluxio.proto.journal.KeyValue.RenameStoreEntry
 
isInitialized() - Method in class alluxio.proto.journal.Lineage.DeleteLineageEntry.Builder
 
isInitialized() - Method in class alluxio.proto.journal.Lineage.DeleteLineageEntry
 
isInitialized() - Method in class alluxio.proto.journal.Lineage.LineageEntry.Builder
 
isInitialized() - Method in class alluxio.proto.journal.Lineage.LineageEntry
 
isInitialized() - Method in class alluxio.proto.journal.Lineage.LineageIdGeneratorEntry.Builder
 
isInitialized() - Method in class alluxio.proto.journal.Lineage.LineageIdGeneratorEntry
 
isInSafeMode() - Method in class alluxio.master.AlluxioMasterProcess
 
isInSafeMode() - Method in class alluxio.master.DefaultSafeModeManager
 
isInSafeMode() - Method in interface alluxio.master.MasterProcess
 
isInSafeMode() - Method in class alluxio.master.meta.DefaultMetaMaster
 
isInSafeMode() - Method in interface alluxio.master.meta.MetaMaster
 
isInSafeMode() - Method in interface alluxio.master.SafeModeManager
 
isInTier(String) - Method in class alluxio.master.block.meta.MasterBlockInfo
 
isInTier(String) - Method in class alluxio.web.UIFileBlockInfo
 
isLinux() - Static method in class alluxio.util.OSUtils
 
isLoadDirectChildren() - Method in class alluxio.thrift.ListStatusTOptions
 
isLocal(UnderFileSystem) - Static method in class alluxio.util.UnderFileSystemUtils
 
isLocalBlockCloseRequest() - Method in class alluxio.util.proto.ProtoMessage
 
isLocalBlockCompleteRequest() - Method in class alluxio.util.proto.ProtoMessage
 
isLocalBlockCreateRequest() - Method in class alluxio.util.proto.ProtoMessage
 
isLocalBlockCreateResponse() - Method in class alluxio.util.proto.ProtoMessage
 
isLocalBlockOpenRequest() - Method in class alluxio.util.proto.ProtoMessage
 
isLocalBlockOpenResponse() - Method in class alluxio.util.proto.ProtoMessage
 
isLocalFileSystem() - Method in class alluxio.thrift.BackupTOptions
 
isLocalFilesystem(String) - Static method in class alluxio.util.URIUtils
 
isLocalFileSystem() - Method in class alluxio.wire.BackupOptions
 
isLocalHost(WorkerNetAddress) - Static method in class alluxio.util.CommonUtils
 
isMacOS() - Static method in class alluxio.util.OSUtils
 
isMarkedToMoveOut(long) - Method in class alluxio.worker.block.meta.StorageDirView
Returns an indication whether the given block is marked to be moved out.
isMetadataLoad() - Method in class alluxio.master.file.options.CreatePathOptions
 
isMountingPoint(String, String[]) - Static method in class alluxio.cli.validation.Utils
Checks whether a path is the mounting point of a RAM disk volume.
isMountPoint() - Method in class alluxio.client.file.URIStatus
 
isMountPoint() - Method in class alluxio.master.file.meta.InodeDirectory
 
isMountPoint(AlluxioURI) - Method in class alluxio.master.file.meta.MountTable
 
isMountPoint() - Method in class alluxio.master.file.options.CreatePathOptions
 
isMountPoint() - Method in class alluxio.thrift.FileInfo
 
isMountPoint() - Method in class alluxio.wire.FileInfo
 
isNested(String) - Method in class alluxio.PropertyKey
 
isNoCache() - Method in class alluxio.worker.block.meta.UnderFileSystemBlockMeta
 
isObjectStorage() - Method in class alluxio.underfs.BaseUnderFileSystem
 
isObjectStorage() - Method in class alluxio.underfs.ObjectUnderFileSystem
 
isObjectStorage() - Method in interface alluxio.underfs.UnderFileSystem
 
isObjectStorage() - Method in class alluxio.underfs.UnderFileSystemWithLogging
 
isOneway() - Method in class alluxio.thrift.AlluxioService.AsyncProcessor.getServiceVersion
 
isOneway() - Method in class alluxio.thrift.AlluxioService.Processor.getServiceVersion
 
isOneway() - Method in class alluxio.thrift.BlockMasterClientService.AsyncProcessor.getBlockInfo
 
isOneway() - Method in class alluxio.thrift.BlockMasterClientService.AsyncProcessor.getBlockMasterInfo
 
isOneway() - Method in class alluxio.thrift.BlockMasterClientService.AsyncProcessor.getCapacityBytes
 
isOneway() - Method in class alluxio.thrift.BlockMasterClientService.AsyncProcessor.getUsedBytes
 
isOneway() - Method in class alluxio.thrift.BlockMasterClientService.AsyncProcessor.getWorkerInfoList
 
isOneway() - Method in class alluxio.thrift.BlockMasterClientService.AsyncProcessor.getWorkerReport
 
isOneway() - Method in class alluxio.thrift.BlockMasterClientService.Processor.getBlockInfo
 
isOneway() - Method in class alluxio.thrift.BlockMasterClientService.Processor.getBlockMasterInfo
 
isOneway() - Method in class alluxio.thrift.BlockMasterClientService.Processor.getCapacityBytes
 
isOneway() - Method in class alluxio.thrift.BlockMasterClientService.Processor.getUsedBytes
 
isOneway() - Method in class alluxio.thrift.BlockMasterClientService.Processor.getWorkerInfoList
 
isOneway() - Method in class alluxio.thrift.BlockMasterClientService.Processor.getWorkerReport
 
isOneway() - Method in class alluxio.thrift.BlockMasterWorkerService.AsyncProcessor.blockHeartbeat
 
isOneway() - Method in class alluxio.thrift.BlockMasterWorkerService.AsyncProcessor.commitBlock
 
isOneway() - Method in class alluxio.thrift.BlockMasterWorkerService.AsyncProcessor.getWorkerId
 
isOneway() - Method in class alluxio.thrift.BlockMasterWorkerService.AsyncProcessor.registerWorker
 
isOneway() - Method in class alluxio.thrift.BlockMasterWorkerService.Processor.blockHeartbeat
 
isOneway() - Method in class alluxio.thrift.BlockMasterWorkerService.Processor.commitBlock
 
isOneway() - Method in class alluxio.thrift.BlockMasterWorkerService.Processor.getWorkerId
 
isOneway() - Method in class alluxio.thrift.BlockMasterWorkerService.Processor.registerWorker
 
isOneway() - Method in class alluxio.thrift.BlockWorkerClientService.AsyncProcessor.accessBlock
 
isOneway() - Method in class alluxio.thrift.BlockWorkerClientService.AsyncProcessor.cacheBlock
 
isOneway() - Method in class alluxio.thrift.BlockWorkerClientService.AsyncProcessor.cancelBlock
 
isOneway() - Method in class alluxio.thrift.BlockWorkerClientService.AsyncProcessor.lockBlock
 
isOneway() - Method in class alluxio.thrift.BlockWorkerClientService.AsyncProcessor.promoteBlock
 
isOneway() - Method in class alluxio.thrift.BlockWorkerClientService.AsyncProcessor.removeBlock
 
isOneway() - Method in class alluxio.thrift.BlockWorkerClientService.AsyncProcessor.requestBlockLocation
 
isOneway() - Method in class alluxio.thrift.BlockWorkerClientService.AsyncProcessor.requestSpace
 
isOneway() - Method in class alluxio.thrift.BlockWorkerClientService.AsyncProcessor.sessionBlockHeartbeat
 
isOneway() - Method in class alluxio.thrift.BlockWorkerClientService.AsyncProcessor.unlockBlock
 
isOneway() - Method in class alluxio.thrift.BlockWorkerClientService.Processor.accessBlock
 
isOneway() - Method in class alluxio.thrift.BlockWorkerClientService.Processor.cacheBlock
 
isOneway() - Method in class alluxio.thrift.BlockWorkerClientService.Processor.cancelBlock
 
isOneway() - Method in class alluxio.thrift.BlockWorkerClientService.Processor.lockBlock
 
isOneway() - Method in class alluxio.thrift.BlockWorkerClientService.Processor.promoteBlock
 
isOneway() - Method in class alluxio.thrift.BlockWorkerClientService.Processor.removeBlock
 
isOneway() - Method in class alluxio.thrift.BlockWorkerClientService.Processor.requestBlockLocation
 
isOneway() - Method in class alluxio.thrift.BlockWorkerClientService.Processor.requestSpace
 
isOneway() - Method in class alluxio.thrift.BlockWorkerClientService.Processor.sessionBlockHeartbeat
 
isOneway() - Method in class alluxio.thrift.BlockWorkerClientService.Processor.unlockBlock
 
isOneway() - Method in class alluxio.thrift.FileSystemMasterClientService.AsyncProcessor.checkConsistency
 
isOneway() - Method in class alluxio.thrift.FileSystemMasterClientService.AsyncProcessor.completeFile
 
isOneway() - Method in class alluxio.thrift.FileSystemMasterClientService.AsyncProcessor.createDirectory
 
isOneway() - Method in class alluxio.thrift.FileSystemMasterClientService.AsyncProcessor.createFile
 
isOneway() - Method in class alluxio.thrift.FileSystemMasterClientService.AsyncProcessor.free
 
isOneway() - Method in class alluxio.thrift.FileSystemMasterClientService.AsyncProcessor.getFilePath
 
isOneway() - Method in class alluxio.thrift.FileSystemMasterClientService.AsyncProcessor.getMountTable
 
isOneway() - Method in class alluxio.thrift.FileSystemMasterClientService.AsyncProcessor.getNewBlockIdForFile
 
isOneway() - Method in class alluxio.thrift.FileSystemMasterClientService.AsyncProcessor.getStatus
 
isOneway() - Method in class alluxio.thrift.FileSystemMasterClientService.AsyncProcessor.listStatus
 
isOneway() - Method in class alluxio.thrift.FileSystemMasterClientService.AsyncProcessor.loadMetadata
 
isOneway() - Method in class alluxio.thrift.FileSystemMasterClientService.AsyncProcessor.mount
 
isOneway() - Method in class alluxio.thrift.FileSystemMasterClientService.AsyncProcessor.remove
 
isOneway() - Method in class alluxio.thrift.FileSystemMasterClientService.AsyncProcessor.rename
 
isOneway() - Method in class alluxio.thrift.FileSystemMasterClientService.AsyncProcessor.scheduleAsyncPersistence
 
isOneway() - Method in class alluxio.thrift.FileSystemMasterClientService.AsyncProcessor.setAttribute
 
isOneway() - Method in class alluxio.thrift.FileSystemMasterClientService.AsyncProcessor.unmount
 
isOneway() - Method in class alluxio.thrift.FileSystemMasterClientService.AsyncProcessor.updateUfsMode
 
isOneway() - Method in class alluxio.thrift.FileSystemMasterClientService.Processor.checkConsistency
 
isOneway() - Method in class alluxio.thrift.FileSystemMasterClientService.Processor.completeFile
 
isOneway() - Method in class alluxio.thrift.FileSystemMasterClientService.Processor.createDirectory
 
isOneway() - Method in class alluxio.thrift.FileSystemMasterClientService.Processor.createFile
 
isOneway() - Method in class alluxio.thrift.FileSystemMasterClientService.Processor.free
 
isOneway() - Method in class alluxio.thrift.FileSystemMasterClientService.Processor.getFilePath
 
isOneway() - Method in class alluxio.thrift.FileSystemMasterClientService.Processor.getMountTable
 
isOneway() - Method in class alluxio.thrift.FileSystemMasterClientService.Processor.getNewBlockIdForFile
 
isOneway() - Method in class alluxio.thrift.FileSystemMasterClientService.Processor.getStatus
 
isOneway() - Method in class alluxio.thrift.FileSystemMasterClientService.Processor.listStatus
 
isOneway() - Method in class alluxio.thrift.FileSystemMasterClientService.Processor.loadMetadata
 
isOneway() - Method in class alluxio.thrift.FileSystemMasterClientService.Processor.mount
 
isOneway() - Method in class alluxio.thrift.FileSystemMasterClientService.Processor.remove
 
isOneway() - Method in class alluxio.thrift.FileSystemMasterClientService.Processor.rename
 
isOneway() - Method in class alluxio.thrift.FileSystemMasterClientService.Processor.scheduleAsyncPersistence
 
isOneway() - Method in class alluxio.thrift.FileSystemMasterClientService.Processor.setAttribute
 
isOneway() - Method in class alluxio.thrift.FileSystemMasterClientService.Processor.unmount
 
isOneway() - Method in class alluxio.thrift.FileSystemMasterClientService.Processor.updateUfsMode
 
isOneway() - Method in class alluxio.thrift.FileSystemMasterWorkerService.AsyncProcessor.fileSystemHeartbeat
 
isOneway() - Method in class alluxio.thrift.FileSystemMasterWorkerService.AsyncProcessor.getFileInfo
 
isOneway() - Method in class alluxio.thrift.FileSystemMasterWorkerService.AsyncProcessor.getPinnedFileIds
 
isOneway() - Method in class alluxio.thrift.FileSystemMasterWorkerService.AsyncProcessor.getUfsInfo
 
isOneway() - Method in class alluxio.thrift.FileSystemMasterWorkerService.Processor.fileSystemHeartbeat
 
isOneway() - Method in class alluxio.thrift.FileSystemMasterWorkerService.Processor.getFileInfo
 
isOneway() - Method in class alluxio.thrift.FileSystemMasterWorkerService.Processor.getPinnedFileIds
 
isOneway() - Method in class alluxio.thrift.FileSystemMasterWorkerService.Processor.getUfsInfo
 
isOneway() - Method in class alluxio.thrift.FileSystemWorkerClientService.AsyncProcessor.cancelUfsFile
 
isOneway() - Method in class alluxio.thrift.FileSystemWorkerClientService.AsyncProcessor.closeUfsFile
 
isOneway() - Method in class alluxio.thrift.FileSystemWorkerClientService.AsyncProcessor.completeUfsFile
 
isOneway() - Method in class alluxio.thrift.FileSystemWorkerClientService.AsyncProcessor.createUfsFile
 
isOneway() - Method in class alluxio.thrift.FileSystemWorkerClientService.AsyncProcessor.openUfsFile
 
isOneway() - Method in class alluxio.thrift.FileSystemWorkerClientService.AsyncProcessor.sessionFileSystemHeartbeat
 
isOneway() - Method in class alluxio.thrift.FileSystemWorkerClientService.Processor.cancelUfsFile
 
isOneway() - Method in class alluxio.thrift.FileSystemWorkerClientService.Processor.closeUfsFile
 
isOneway() - Method in class alluxio.thrift.FileSystemWorkerClientService.Processor.completeUfsFile
 
isOneway() - Method in class alluxio.thrift.FileSystemWorkerClientService.Processor.createUfsFile
 
isOneway() - Method in class alluxio.thrift.FileSystemWorkerClientService.Processor.openUfsFile
 
isOneway() - Method in class alluxio.thrift.FileSystemWorkerClientService.Processor.sessionFileSystemHeartbeat
 
isOneway() - Method in class alluxio.thrift.KeyValueMasterClientService.AsyncProcessor.completePartition
 
isOneway() - Method in class alluxio.thrift.KeyValueMasterClientService.AsyncProcessor.completeStore
 
isOneway() - Method in class alluxio.thrift.KeyValueMasterClientService.AsyncProcessor.createStore
 
isOneway() - Method in class alluxio.thrift.KeyValueMasterClientService.AsyncProcessor.deleteStore
 
isOneway() - Method in class alluxio.thrift.KeyValueMasterClientService.AsyncProcessor.getPartitionInfo
 
isOneway() - Method in class alluxio.thrift.KeyValueMasterClientService.AsyncProcessor.mergeStore
 
isOneway() - Method in class alluxio.thrift.KeyValueMasterClientService.AsyncProcessor.renameStore
 
isOneway() - Method in class alluxio.thrift.KeyValueMasterClientService.Processor.completePartition
 
isOneway() - Method in class alluxio.thrift.KeyValueMasterClientService.Processor.completeStore
 
isOneway() - Method in class alluxio.thrift.KeyValueMasterClientService.Processor.createStore
 
isOneway() - Method in class alluxio.thrift.KeyValueMasterClientService.Processor.deleteStore
 
isOneway() - Method in class alluxio.thrift.KeyValueMasterClientService.Processor.getPartitionInfo
 
isOneway() - Method in class alluxio.thrift.KeyValueMasterClientService.Processor.mergeStore
 
isOneway() - Method in class alluxio.thrift.KeyValueMasterClientService.Processor.renameStore
 
isOneway() - Method in class alluxio.thrift.KeyValueWorkerClientService.AsyncProcessor.get
 
isOneway() - Method in class alluxio.thrift.KeyValueWorkerClientService.AsyncProcessor.getNextKeys
 
isOneway() - Method in class alluxio.thrift.KeyValueWorkerClientService.AsyncProcessor.getSize
 
isOneway() - Method in class alluxio.thrift.KeyValueWorkerClientService.Processor.get
 
isOneway() - Method in class alluxio.thrift.KeyValueWorkerClientService.Processor.getNextKeys
 
isOneway() - Method in class alluxio.thrift.KeyValueWorkerClientService.Processor.getSize
 
isOneway() - Method in class alluxio.thrift.LineageMasterClientService.AsyncProcessor.createLineage
 
isOneway() - Method in class alluxio.thrift.LineageMasterClientService.AsyncProcessor.deleteLineage
 
isOneway() - Method in class alluxio.thrift.LineageMasterClientService.AsyncProcessor.getLineageInfoList
 
isOneway() - Method in class alluxio.thrift.LineageMasterClientService.AsyncProcessor.reinitializeFile
 
isOneway() - Method in class alluxio.thrift.LineageMasterClientService.AsyncProcessor.reportLostFile
 
isOneway() - Method in class alluxio.thrift.LineageMasterClientService.Processor.createLineage
 
isOneway() - Method in class alluxio.thrift.LineageMasterClientService.Processor.deleteLineage
 
isOneway() - Method in class alluxio.thrift.LineageMasterClientService.Processor.getLineageInfoList
 
isOneway() - Method in class alluxio.thrift.LineageMasterClientService.Processor.reinitializeFile
 
isOneway() - Method in class alluxio.thrift.LineageMasterClientService.Processor.reportLostFile
 
isOneway() - Method in class alluxio.thrift.MetaMasterClientService.AsyncProcessor.backup
 
isOneway() - Method in class alluxio.thrift.MetaMasterClientService.AsyncProcessor.getConfigReport
 
isOneway() - Method in class alluxio.thrift.MetaMasterClientService.AsyncProcessor.getConfiguration
 
isOneway() - Method in class alluxio.thrift.MetaMasterClientService.AsyncProcessor.getMasterInfo
 
isOneway() - Method in class alluxio.thrift.MetaMasterClientService.AsyncProcessor.getMetrics
 
isOneway() - Method in class alluxio.thrift.MetaMasterClientService.Processor.backup
 
isOneway() - Method in class alluxio.thrift.MetaMasterClientService.Processor.getConfigReport
 
isOneway() - Method in class alluxio.thrift.MetaMasterClientService.Processor.getConfiguration
 
isOneway() - Method in class alluxio.thrift.MetaMasterClientService.Processor.getMasterInfo
 
isOneway() - Method in class alluxio.thrift.MetaMasterClientService.Processor.getMetrics
 
isOneway() - Method in class alluxio.thrift.MetaMasterMasterService.AsyncProcessor.getMasterId
 
isOneway() - Method in class alluxio.thrift.MetaMasterMasterService.AsyncProcessor.masterHeartbeat
 
isOneway() - Method in class alluxio.thrift.MetaMasterMasterService.AsyncProcessor.registerMaster
 
isOneway() - Method in class alluxio.thrift.MetaMasterMasterService.Processor.getMasterId
 
isOneway() - Method in class alluxio.thrift.MetaMasterMasterService.Processor.masterHeartbeat
 
isOneway() - Method in class alluxio.thrift.MetaMasterMasterService.Processor.registerMaster
 
isOneway() - Method in class alluxio.thrift.MetricsMasterClientService.AsyncProcessor.metricsHeartbeat
 
isOneway() - Method in class alluxio.thrift.MetricsMasterClientService.Processor.metricsHeartbeat
 
isOpen() - Method in class alluxio.network.thrift.BootstrapClientTransport
 
isOpen() - Method in class alluxio.network.thrift.BootstrapServerTransport
 
isOpen() - Method in class alluxio.network.thrift.PeekableTransport
 
isOss(UnderFileSystem) - Static method in class alluxio.util.UnderFileSystemUtils
 
isPacketReaderActive() - Method in class alluxio.worker.netty.ReadRequestContext
 
isPacketWriterActive() - Method in class alluxio.worker.netty.WriteRequestContext
 
isPathAbsolute() - Method in class alluxio.AlluxioURI
Tells whether or not the path component of the AlluxioURI is absolute.
isPersisted() - Method in class alluxio.client.file.URIStatus
 
isPersisted() - Method in class alluxio.master.file.meta.Inode
 
isPersisted() - Method in class alluxio.master.file.options.CreatePathOptions
 
isPersisted(Lineage, FileSystemMasterView) - Static method in class alluxio.master.lineage.meta.LineageStateUtils
 
isPersisted() - Method in class alluxio.thrift.CreateDirectoryTOptions
 
isPersisted() - Method in class alluxio.thrift.CreateFileTOptions
 
isPersisted() - Method in class alluxio.thrift.FileInfo
 
isPersisted() - Method in class alluxio.thrift.SetAttributeTOptions
 
isPersisted() - Method in class alluxio.wire.FileInfo
 
isPersisted() - Method in class alluxio.worker.netty.BlockReadRequest
 
isPinned() - Method in class alluxio.client.file.URIStatus
 
isPinned() - Method in class alluxio.master.file.meta.Inode
 
isPinned() - Method in class alluxio.thrift.FileInfo
 
isPinned() - Method in class alluxio.thrift.SetAttributeTOptions
 
isPinned() - Method in class alluxio.web.UIFileInfo
 
isPinned() - Method in class alluxio.wire.FileInfo
 
isPrimary() - Method in class alluxio.master.journal.options.JournalReaderOptions
 
isPrimary() - Method in class alluxio.master.journal.options.JournalWriterOptions
 
isPromote() - Method in enum alluxio.client.AlluxioStorageType
 
isPromote() - Method in enum alluxio.client.ReadType
 
isPromote() - Method in class alluxio.worker.netty.BlockReadRequest
 
isPromoted() - Method in class alluxio.thrift.PromoteBlockTResponse
 
isRawValue() - Method in class alluxio.thrift.GetConfigurationTOptions
 
isRawValue() - Method in class alluxio.wire.GetConfigurationOptions
 
isReadLocked() - Method in class alluxio.master.file.meta.Inode
 
isReadOnly() - Method in class alluxio.client.file.options.MountOptions
 
isReadOnly() - Method in class alluxio.master.file.options.MountOptions
 
isReadOnly() - Method in class alluxio.thrift.MountPointInfo
 
isReadOnly() - Method in class alluxio.thrift.MountTOptions
 
isReadOnly() - Method in class alluxio.underfs.UnderFileSystemConfiguration
 
isReadRequest() - Method in class alluxio.util.proto.ProtoMessage
 
isReadResponse() - Method in class alluxio.util.proto.ProtoMessage
 
isRecursive() - Method in class alluxio.client.file.options.CreateDirectoryOptions
 
isRecursive() - Method in class alluxio.client.file.options.CreateFileOptions
 
isRecursive() - Method in class alluxio.client.file.options.DeleteOptions
 
isRecursive() - Method in class alluxio.client.file.options.FreeOptions
 
isRecursive() - Method in class alluxio.client.file.options.ListStatusOptions
 
isRecursive() - Method in class alluxio.client.file.options.LoadMetadataOptions
Deprecated.
 
isRecursive() - Method in class alluxio.client.file.options.SetAttributeOptions
 
isRecursive() - Method in class alluxio.master.file.options.CreatePathOptions
 
isRecursive() - Method in class alluxio.master.file.options.DeleteOptions
 
isRecursive() - Method in class alluxio.master.file.options.FreeOptions
 
isRecursive() - Method in class alluxio.master.file.options.ListStatusOptions
 
isRecursive() - Method in class alluxio.master.file.options.SetAttributeOptions
 
isRecursive() - Method in class alluxio.thrift.CreateDirectoryTOptions
 
isRecursive() - Method in class alluxio.thrift.CreateFileTOptions
 
isRecursive() - Method in class alluxio.thrift.DeleteTOptions
 
isRecursive() - Method in class alluxio.thrift.FileSystemMasterClientService.free_args
whether to free recursively
isRecursive() - Method in class alluxio.thrift.FileSystemMasterClientService.loadMetadata_args
whether to load metadata recursively
isRecursive() - Method in class alluxio.thrift.FileSystemMasterClientService.remove_args
whether to remove recursively
isRecursive() - Method in class alluxio.thrift.FreeTOptions
 
isRecursive() - Method in class alluxio.thrift.ListStatusTOptions
 
isRecursive() - Method in class alluxio.thrift.SetAttributeTOptions
 
isRecursive() - Method in class alluxio.underfs.options.DeleteOptions
 
isRecursive() - Method in class alluxio.underfs.options.ListOptions
 
isRegistered() - Method in class alluxio.master.block.meta.MasterWorkerInfo
 
isResponse() - Method in class alluxio.util.proto.ProtoMessage
 
isRoot() - Method in class alluxio.AlluxioURI
Tells whether or not the AlluxioURI is root.
isRoot(T) - Method in class alluxio.collections.DirectedAcyclicGraph
Checks if a given payload is in a root of the DAG.
isRoot(String) - Method in class alluxio.underfs.ObjectUnderFileSystem
Checks if the path is the root.
isRoot(String) - Static method in class alluxio.util.io.PathUtils
Checks if the given path is the root.
isRootId(long) - Method in class alluxio.master.file.meta.InodeTree
 
isS3(UnderFileSystem) - Static method in class alluxio.util.UnderFileSystemUtils
 
isSafeMode() - Method in class alluxio.thrift.MasterInfo
 
isSafeMode() - Method in class alluxio.wire.MasterInfo
 
isSecurityEnabled() - Static method in class alluxio.util.SecurityUtils
Checks if security is enabled.
isSeekable() - Method in class alluxio.underfs.BaseUnderFileSystem
 
isSeekable() - Method in class alluxio.underfs.hdfs.HdfsUnderFileSystem
 
isSeekable() - Method in interface alluxio.underfs.UnderFileSystem
Denotes if the under storage supports seeking.
isSeekable() - Method in class alluxio.underfs.UnderFileSystemWithLogging
 
isServing() - Method in interface alluxio.HealthCheckClient
 
isServing() - Method in class alluxio.master.AlluxioMasterProcess
 
isServing() - Method in class alluxio.master.LocalAlluxioMaster
 
isServing() - Method in class alluxio.master.MasterHealthCheckClient
 
isServing() - Method in interface alluxio.master.MasterProcess
 
isServing() - Method in class alluxio.proxy.ProxyHealthCheckClient
 
isServing(String, int) - Static method in class alluxio.util.network.NetworkAddressUtils
 
isServing() - Method in class alluxio.worker.WorkerHealthCheckClient
 
isSet(PropertyKey) - Method in interface alluxio.AlluxioConfiguration
Checks if the configuration contains a value for the given key.
isSet(PropertyKey) - Method in class alluxio.conf.AlluxioProperties
Checks if there is a value set for the given key.
isSet(PropertyKey) - Method in class alluxio.conf.InstancedConfiguration
 
isSet(PropertyKey) - Static method in class alluxio.Configuration
Checks if the configuration contains a value for the given key.
isSet(AccessBlockTOptions._Fields) - Method in class alluxio.thrift.AccessBlockTOptions
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(AccessBlockTResponse._Fields) - Method in class alluxio.thrift.AccessBlockTResponse
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(AlluxioService.getServiceVersion_args._Fields) - Method in class alluxio.thrift.AlluxioService.getServiceVersion_args
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(AlluxioService.getServiceVersion_result._Fields) - Method in class alluxio.thrift.AlluxioService.getServiceVersion_result
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(AlluxioTException._Fields) - Method in exception alluxio.thrift.AlluxioTException
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(BackupTOptions._Fields) - Method in class alluxio.thrift.BackupTOptions
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(BackupTResponse._Fields) - Method in class alluxio.thrift.BackupTResponse
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(BlockHeartbeatTOptions._Fields) - Method in class alluxio.thrift.BlockHeartbeatTOptions
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(BlockHeartbeatTResponse._Fields) - Method in class alluxio.thrift.BlockHeartbeatTResponse
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(BlockInfo._Fields) - Method in class alluxio.thrift.BlockInfo
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(BlockLocation._Fields) - Method in class alluxio.thrift.BlockLocation
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(BlockMasterClientService.getBlockInfo_args._Fields) - Method in class alluxio.thrift.BlockMasterClientService.getBlockInfo_args
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(BlockMasterClientService.getBlockInfo_result._Fields) - Method in class alluxio.thrift.BlockMasterClientService.getBlockInfo_result
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(BlockMasterClientService.getBlockMasterInfo_args._Fields) - Method in class alluxio.thrift.BlockMasterClientService.getBlockMasterInfo_args
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(BlockMasterClientService.getBlockMasterInfo_result._Fields) - Method in class alluxio.thrift.BlockMasterClientService.getBlockMasterInfo_result
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(BlockMasterClientService.getCapacityBytes_args._Fields) - Method in class alluxio.thrift.BlockMasterClientService.getCapacityBytes_args
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(BlockMasterClientService.getCapacityBytes_result._Fields) - Method in class alluxio.thrift.BlockMasterClientService.getCapacityBytes_result
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(BlockMasterClientService.getUsedBytes_args._Fields) - Method in class alluxio.thrift.BlockMasterClientService.getUsedBytes_args
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(BlockMasterClientService.getUsedBytes_result._Fields) - Method in class alluxio.thrift.BlockMasterClientService.getUsedBytes_result
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(BlockMasterClientService.getWorkerInfoList_args._Fields) - Method in class alluxio.thrift.BlockMasterClientService.getWorkerInfoList_args
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(BlockMasterClientService.getWorkerInfoList_result._Fields) - Method in class alluxio.thrift.BlockMasterClientService.getWorkerInfoList_result
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(BlockMasterClientService.getWorkerReport_args._Fields) - Method in class alluxio.thrift.BlockMasterClientService.getWorkerReport_args
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(BlockMasterClientService.getWorkerReport_result._Fields) - Method in class alluxio.thrift.BlockMasterClientService.getWorkerReport_result
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(BlockMasterInfo._Fields) - Method in class alluxio.thrift.BlockMasterInfo
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(BlockMasterWorkerService.blockHeartbeat_args._Fields) - Method in class alluxio.thrift.BlockMasterWorkerService.blockHeartbeat_args
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(BlockMasterWorkerService.blockHeartbeat_result._Fields) - Method in class alluxio.thrift.BlockMasterWorkerService.blockHeartbeat_result
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(BlockMasterWorkerService.commitBlock_args._Fields) - Method in class alluxio.thrift.BlockMasterWorkerService.commitBlock_args
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(BlockMasterWorkerService.commitBlock_result._Fields) - Method in class alluxio.thrift.BlockMasterWorkerService.commitBlock_result
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(BlockMasterWorkerService.getWorkerId_args._Fields) - Method in class alluxio.thrift.BlockMasterWorkerService.getWorkerId_args
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(BlockMasterWorkerService.getWorkerId_result._Fields) - Method in class alluxio.thrift.BlockMasterWorkerService.getWorkerId_result
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(BlockMasterWorkerService.registerWorker_args._Fields) - Method in class alluxio.thrift.BlockMasterWorkerService.registerWorker_args
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(BlockMasterWorkerService.registerWorker_result._Fields) - Method in class alluxio.thrift.BlockMasterWorkerService.registerWorker_result
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(BlockWorkerClientService.accessBlock_args._Fields) - Method in class alluxio.thrift.BlockWorkerClientService.accessBlock_args
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(BlockWorkerClientService.accessBlock_result._Fields) - Method in class alluxio.thrift.BlockWorkerClientService.accessBlock_result
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(BlockWorkerClientService.cacheBlock_args._Fields) - Method in class alluxio.thrift.BlockWorkerClientService.cacheBlock_args
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(BlockWorkerClientService.cacheBlock_result._Fields) - Method in class alluxio.thrift.BlockWorkerClientService.cacheBlock_result
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(BlockWorkerClientService.cancelBlock_args._Fields) - Method in class alluxio.thrift.BlockWorkerClientService.cancelBlock_args
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(BlockWorkerClientService.cancelBlock_result._Fields) - Method in class alluxio.thrift.BlockWorkerClientService.cancelBlock_result
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(BlockWorkerClientService.lockBlock_args._Fields) - Method in class alluxio.thrift.BlockWorkerClientService.lockBlock_args
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(BlockWorkerClientService.lockBlock_result._Fields) - Method in class alluxio.thrift.BlockWorkerClientService.lockBlock_result
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(BlockWorkerClientService.promoteBlock_args._Fields) - Method in class alluxio.thrift.BlockWorkerClientService.promoteBlock_args
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(BlockWorkerClientService.promoteBlock_result._Fields) - Method in class alluxio.thrift.BlockWorkerClientService.promoteBlock_result
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(BlockWorkerClientService.removeBlock_args._Fields) - Method in class alluxio.thrift.BlockWorkerClientService.removeBlock_args
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(BlockWorkerClientService.removeBlock_result._Fields) - Method in class alluxio.thrift.BlockWorkerClientService.removeBlock_result
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(BlockWorkerClientService.requestBlockLocation_args._Fields) - Method in class alluxio.thrift.BlockWorkerClientService.requestBlockLocation_args
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(BlockWorkerClientService.requestBlockLocation_result._Fields) - Method in class alluxio.thrift.BlockWorkerClientService.requestBlockLocation_result
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(BlockWorkerClientService.requestSpace_args._Fields) - Method in class alluxio.thrift.BlockWorkerClientService.requestSpace_args
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(BlockWorkerClientService.requestSpace_result._Fields) - Method in class alluxio.thrift.BlockWorkerClientService.requestSpace_result
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(BlockWorkerClientService.sessionBlockHeartbeat_args._Fields) - Method in class alluxio.thrift.BlockWorkerClientService.sessionBlockHeartbeat_args
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(BlockWorkerClientService.sessionBlockHeartbeat_result._Fields) - Method in class alluxio.thrift.BlockWorkerClientService.sessionBlockHeartbeat_result
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(BlockWorkerClientService.unlockBlock_args._Fields) - Method in class alluxio.thrift.BlockWorkerClientService.unlockBlock_args
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(BlockWorkerClientService.unlockBlock_result._Fields) - Method in class alluxio.thrift.BlockWorkerClientService.unlockBlock_result
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(CacheBlockTOptions._Fields) - Method in class alluxio.thrift.CacheBlockTOptions
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(CacheBlockTResponse._Fields) - Method in class alluxio.thrift.CacheBlockTResponse
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(CancelBlockTOptions._Fields) - Method in class alluxio.thrift.CancelBlockTOptions
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(CancelBlockTResponse._Fields) - Method in class alluxio.thrift.CancelBlockTResponse
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(CancelUfsFileTOptions._Fields) - Method in class alluxio.thrift.CancelUfsFileTOptions
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(CancelUfsFileTResponse._Fields) - Method in class alluxio.thrift.CancelUfsFileTResponse
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(CheckConsistencyTOptions._Fields) - Method in class alluxio.thrift.CheckConsistencyTOptions
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(CheckConsistencyTResponse._Fields) - Method in class alluxio.thrift.CheckConsistencyTResponse
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(CloseUfsFileTOptions._Fields) - Method in class alluxio.thrift.CloseUfsFileTOptions
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(CloseUfsFileTResponse._Fields) - Method in class alluxio.thrift.CloseUfsFileTResponse
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(Command._Fields) - Method in class alluxio.thrift.Command
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(CommandLineJobInfo._Fields) - Method in class alluxio.thrift.CommandLineJobInfo
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(CommitBlockTOptions._Fields) - Method in class alluxio.thrift.CommitBlockTOptions
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(CommitBlockTResponse._Fields) - Method in class alluxio.thrift.CommitBlockTResponse
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(CompleteFileTOptions._Fields) - Method in class alluxio.thrift.CompleteFileTOptions
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(CompleteFileTResponse._Fields) - Method in class alluxio.thrift.CompleteFileTResponse
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(CompletePartitionTOptions._Fields) - Method in class alluxio.thrift.CompletePartitionTOptions
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(CompletePartitionTResponse._Fields) - Method in class alluxio.thrift.CompletePartitionTResponse
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(CompleteStoreTOptions._Fields) - Method in class alluxio.thrift.CompleteStoreTOptions
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(CompleteStoreTResponse._Fields) - Method in class alluxio.thrift.CompleteStoreTResponse
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(CompleteUfsFileTOptions._Fields) - Method in class alluxio.thrift.CompleteUfsFileTOptions
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(CompleteUfsFileTReponse._Fields) - Method in class alluxio.thrift.CompleteUfsFileTReponse
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(ConfigCheckReport._Fields) - Method in class alluxio.thrift.ConfigCheckReport
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(ConfigProperty._Fields) - Method in class alluxio.thrift.ConfigProperty
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(CreateDirectoryTOptions._Fields) - Method in class alluxio.thrift.CreateDirectoryTOptions
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(CreateDirectoryTResponse._Fields) - Method in class alluxio.thrift.CreateDirectoryTResponse
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(CreateFileTOptions._Fields) - Method in class alluxio.thrift.CreateFileTOptions
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(CreateFileTResponse._Fields) - Method in class alluxio.thrift.CreateFileTResponse
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(CreateLineageTOptions._Fields) - Method in class alluxio.thrift.CreateLineageTOptions
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(CreateLineageTResponse._Fields) - Method in class alluxio.thrift.CreateLineageTResponse
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(CreateStoreTOptions._Fields) - Method in class alluxio.thrift.CreateStoreTOptions
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(CreateStoreTResponse._Fields) - Method in class alluxio.thrift.CreateStoreTResponse
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(CreateUfsFileTOptions._Fields) - Method in class alluxio.thrift.CreateUfsFileTOptions
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(CreateUfsFileTResponse._Fields) - Method in class alluxio.thrift.CreateUfsFileTResponse
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(DeleteLineageTOptions._Fields) - Method in class alluxio.thrift.DeleteLineageTOptions
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(DeleteLineageTResponse._Fields) - Method in class alluxio.thrift.DeleteLineageTResponse
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(DeleteStoreTOptions._Fields) - Method in class alluxio.thrift.DeleteStoreTOptions
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(DeleteStoreTResponse._Fields) - Method in class alluxio.thrift.DeleteStoreTResponse
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(DeleteTOptions._Fields) - Method in class alluxio.thrift.DeleteTOptions
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(DeleteTResponse._Fields) - Method in class alluxio.thrift.DeleteTResponse
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(DependencyInfo._Fields) - Method in class alluxio.thrift.DependencyInfo
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(FileBlockInfo._Fields) - Method in class alluxio.thrift.FileBlockInfo
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(FileInfo._Fields) - Method in class alluxio.thrift.FileInfo
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(FileSystemCommand._Fields) - Method in class alluxio.thrift.FileSystemCommand
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(FileSystemHeartbeatTOptions._Fields) - Method in class alluxio.thrift.FileSystemHeartbeatTOptions
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(FileSystemHeartbeatTResponse._Fields) - Method in class alluxio.thrift.FileSystemHeartbeatTResponse
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(FileSystemMasterClientService.checkConsistency_args._Fields) - Method in class alluxio.thrift.FileSystemMasterClientService.checkConsistency_args
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(FileSystemMasterClientService.checkConsistency_result._Fields) - Method in class alluxio.thrift.FileSystemMasterClientService.checkConsistency_result
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(FileSystemMasterClientService.completeFile_args._Fields) - Method in class alluxio.thrift.FileSystemMasterClientService.completeFile_args
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(FileSystemMasterClientService.completeFile_result._Fields) - Method in class alluxio.thrift.FileSystemMasterClientService.completeFile_result
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(FileSystemMasterClientService.createDirectory_args._Fields) - Method in class alluxio.thrift.FileSystemMasterClientService.createDirectory_args
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(FileSystemMasterClientService.createDirectory_result._Fields) - Method in class alluxio.thrift.FileSystemMasterClientService.createDirectory_result
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(FileSystemMasterClientService.createFile_args._Fields) - Method in class alluxio.thrift.FileSystemMasterClientService.createFile_args
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(FileSystemMasterClientService.createFile_result._Fields) - Method in class alluxio.thrift.FileSystemMasterClientService.createFile_result
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(FileSystemMasterClientService.free_args._Fields) - Method in class alluxio.thrift.FileSystemMasterClientService.free_args
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(FileSystemMasterClientService.free_result._Fields) - Method in class alluxio.thrift.FileSystemMasterClientService.free_result
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(FileSystemMasterClientService.getFilePath_args._Fields) - Method in class alluxio.thrift.FileSystemMasterClientService.getFilePath_args
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(FileSystemMasterClientService.getFilePath_result._Fields) - Method in class alluxio.thrift.FileSystemMasterClientService.getFilePath_result
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(FileSystemMasterClientService.getMountTable_args._Fields) - Method in class alluxio.thrift.FileSystemMasterClientService.getMountTable_args
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(FileSystemMasterClientService.getMountTable_result._Fields) - Method in class alluxio.thrift.FileSystemMasterClientService.getMountTable_result
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(FileSystemMasterClientService.getNewBlockIdForFile_args._Fields) - Method in class alluxio.thrift.FileSystemMasterClientService.getNewBlockIdForFile_args
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(FileSystemMasterClientService.getNewBlockIdForFile_result._Fields) - Method in class alluxio.thrift.FileSystemMasterClientService.getNewBlockIdForFile_result
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(FileSystemMasterClientService.getStatus_args._Fields) - Method in class alluxio.thrift.FileSystemMasterClientService.getStatus_args
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(FileSystemMasterClientService.getStatus_result._Fields) - Method in class alluxio.thrift.FileSystemMasterClientService.getStatus_result
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(FileSystemMasterClientService.listStatus_args._Fields) - Method in class alluxio.thrift.FileSystemMasterClientService.listStatus_args
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(FileSystemMasterClientService.listStatus_result._Fields) - Method in class alluxio.thrift.FileSystemMasterClientService.listStatus_result
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(FileSystemMasterClientService.loadMetadata_args._Fields) - Method in class alluxio.thrift.FileSystemMasterClientService.loadMetadata_args
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(FileSystemMasterClientService.loadMetadata_result._Fields) - Method in class alluxio.thrift.FileSystemMasterClientService.loadMetadata_result
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(FileSystemMasterClientService.mount_args._Fields) - Method in class alluxio.thrift.FileSystemMasterClientService.mount_args
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(FileSystemMasterClientService.mount_result._Fields) - Method in class alluxio.thrift.FileSystemMasterClientService.mount_result
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(FileSystemMasterClientService.remove_args._Fields) - Method in class alluxio.thrift.FileSystemMasterClientService.remove_args
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(FileSystemMasterClientService.remove_result._Fields) - Method in class alluxio.thrift.FileSystemMasterClientService.remove_result
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(FileSystemMasterClientService.rename_args._Fields) - Method in class alluxio.thrift.FileSystemMasterClientService.rename_args
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(FileSystemMasterClientService.rename_result._Fields) - Method in class alluxio.thrift.FileSystemMasterClientService.rename_result
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(FileSystemMasterClientService.scheduleAsyncPersistence_args._Fields) - Method in class alluxio.thrift.FileSystemMasterClientService.scheduleAsyncPersistence_args
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(FileSystemMasterClientService.scheduleAsyncPersistence_result._Fields) - Method in class alluxio.thrift.FileSystemMasterClientService.scheduleAsyncPersistence_result
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(FileSystemMasterClientService.setAttribute_args._Fields) - Method in class alluxio.thrift.FileSystemMasterClientService.setAttribute_args
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(FileSystemMasterClientService.setAttribute_result._Fields) - Method in class alluxio.thrift.FileSystemMasterClientService.setAttribute_result
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(FileSystemMasterClientService.unmount_args._Fields) - Method in class alluxio.thrift.FileSystemMasterClientService.unmount_args
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(FileSystemMasterClientService.unmount_result._Fields) - Method in class alluxio.thrift.FileSystemMasterClientService.unmount_result
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(FileSystemMasterClientService.updateUfsMode_args._Fields) - Method in class alluxio.thrift.FileSystemMasterClientService.updateUfsMode_args
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(FileSystemMasterClientService.updateUfsMode_result._Fields) - Method in class alluxio.thrift.FileSystemMasterClientService.updateUfsMode_result
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(FileSystemMasterCommonTOptions._Fields) - Method in class alluxio.thrift.FileSystemMasterCommonTOptions
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(FileSystemMasterWorkerService.fileSystemHeartbeat_args._Fields) - Method in class alluxio.thrift.FileSystemMasterWorkerService.fileSystemHeartbeat_args
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(FileSystemMasterWorkerService.fileSystemHeartbeat_result._Fields) - Method in class alluxio.thrift.FileSystemMasterWorkerService.fileSystemHeartbeat_result
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(FileSystemMasterWorkerService.getFileInfo_args._Fields) - Method in class alluxio.thrift.FileSystemMasterWorkerService.getFileInfo_args
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(FileSystemMasterWorkerService.getFileInfo_result._Fields) - Method in class alluxio.thrift.FileSystemMasterWorkerService.getFileInfo_result
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(FileSystemMasterWorkerService.getPinnedFileIds_args._Fields) - Method in class alluxio.thrift.FileSystemMasterWorkerService.getPinnedFileIds_args
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(FileSystemMasterWorkerService.getPinnedFileIds_result._Fields) - Method in class alluxio.thrift.FileSystemMasterWorkerService.getPinnedFileIds_result
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(FileSystemMasterWorkerService.getUfsInfo_args._Fields) - Method in class alluxio.thrift.FileSystemMasterWorkerService.getUfsInfo_args
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(FileSystemMasterWorkerService.getUfsInfo_result._Fields) - Method in class alluxio.thrift.FileSystemMasterWorkerService.getUfsInfo_result
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(FileSystemWorkerClientService.cancelUfsFile_args._Fields) - Method in class alluxio.thrift.FileSystemWorkerClientService.cancelUfsFile_args
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(FileSystemWorkerClientService.cancelUfsFile_result._Fields) - Method in class alluxio.thrift.FileSystemWorkerClientService.cancelUfsFile_result
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(FileSystemWorkerClientService.closeUfsFile_args._Fields) - Method in class alluxio.thrift.FileSystemWorkerClientService.closeUfsFile_args
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(FileSystemWorkerClientService.closeUfsFile_result._Fields) - Method in class alluxio.thrift.FileSystemWorkerClientService.closeUfsFile_result
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(FileSystemWorkerClientService.completeUfsFile_args._Fields) - Method in class alluxio.thrift.FileSystemWorkerClientService.completeUfsFile_args
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(FileSystemWorkerClientService.completeUfsFile_result._Fields) - Method in class alluxio.thrift.FileSystemWorkerClientService.completeUfsFile_result
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(FileSystemWorkerClientService.createUfsFile_args._Fields) - Method in class alluxio.thrift.FileSystemWorkerClientService.createUfsFile_args
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(FileSystemWorkerClientService.createUfsFile_result._Fields) - Method in class alluxio.thrift.FileSystemWorkerClientService.createUfsFile_result
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(FileSystemWorkerClientService.openUfsFile_args._Fields) - Method in class alluxio.thrift.FileSystemWorkerClientService.openUfsFile_args
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(FileSystemWorkerClientService.openUfsFile_result._Fields) - Method in class alluxio.thrift.FileSystemWorkerClientService.openUfsFile_result
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(FileSystemWorkerClientService.sessionFileSystemHeartbeat_args._Fields) - Method in class alluxio.thrift.FileSystemWorkerClientService.sessionFileSystemHeartbeat_args
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(FileSystemWorkerClientService.sessionFileSystemHeartbeat_result._Fields) - Method in class alluxio.thrift.FileSystemWorkerClientService.sessionFileSystemHeartbeat_result
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(FreeTOptions._Fields) - Method in class alluxio.thrift.FreeTOptions
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(FreeTResponse._Fields) - Method in class alluxio.thrift.FreeTResponse
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(GetBlockInfoTOptions._Fields) - Method in class alluxio.thrift.GetBlockInfoTOptions
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(GetBlockInfoTResponse._Fields) - Method in class alluxio.thrift.GetBlockInfoTResponse
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(GetBlockMasterInfoTOptions._Fields) - Method in class alluxio.thrift.GetBlockMasterInfoTOptions
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(GetBlockMasterInfoTResponse._Fields) - Method in class alluxio.thrift.GetBlockMasterInfoTResponse
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(GetCapacityBytesTOptions._Fields) - Method in class alluxio.thrift.GetCapacityBytesTOptions
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(GetCapacityBytesTResponse._Fields) - Method in class alluxio.thrift.GetCapacityBytesTResponse
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(GetConfigReportTOptions._Fields) - Method in class alluxio.thrift.GetConfigReportTOptions
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(GetConfigReportTResponse._Fields) - Method in class alluxio.thrift.GetConfigReportTResponse
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(GetConfigurationTOptions._Fields) - Method in class alluxio.thrift.GetConfigurationTOptions
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(GetConfigurationTResponse._Fields) - Method in class alluxio.thrift.GetConfigurationTResponse
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(GetFileInfoTOptions._Fields) - Method in class alluxio.thrift.GetFileInfoTOptions
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(GetFileInfoTResponse._Fields) - Method in class alluxio.thrift.GetFileInfoTResponse
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(GetFilePathTOptions._Fields) - Method in class alluxio.thrift.GetFilePathTOptions
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(GetFilePathTResponse._Fields) - Method in class alluxio.thrift.GetFilePathTResponse
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(GetLineageInfoListTOptions._Fields) - Method in class alluxio.thrift.GetLineageInfoListTOptions
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(GetLineageInfoListTResponse._Fields) - Method in class alluxio.thrift.GetLineageInfoListTResponse
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(GetMasterIdTOptions._Fields) - Method in class alluxio.thrift.GetMasterIdTOptions
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(GetMasterIdTResponse._Fields) - Method in class alluxio.thrift.GetMasterIdTResponse
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(GetMasterInfoTOptions._Fields) - Method in class alluxio.thrift.GetMasterInfoTOptions
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(GetMasterInfoTResponse._Fields) - Method in class alluxio.thrift.GetMasterInfoTResponse
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(GetMetricsTOptions._Fields) - Method in class alluxio.thrift.GetMetricsTOptions
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(GetMetricsTResponse._Fields) - Method in class alluxio.thrift.GetMetricsTResponse
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(GetMountTableTResponse._Fields) - Method in class alluxio.thrift.GetMountTableTResponse
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(GetNewBlockIdForFileTOptions._Fields) - Method in class alluxio.thrift.GetNewBlockIdForFileTOptions
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(GetNewBlockIdForFileTResponse._Fields) - Method in class alluxio.thrift.GetNewBlockIdForFileTResponse
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(GetNextKeysTOptions._Fields) - Method in class alluxio.thrift.GetNextKeysTOptions
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(GetNextKeysTResponse._Fields) - Method in class alluxio.thrift.GetNextKeysTResponse
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(GetPartitionInfoTOptions._Fields) - Method in class alluxio.thrift.GetPartitionInfoTOptions
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(GetPartitionInfoTResponse._Fields) - Method in class alluxio.thrift.GetPartitionInfoTResponse
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(GetPinnedFileIdsTOptions._Fields) - Method in class alluxio.thrift.GetPinnedFileIdsTOptions
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(GetPinnedFileIdsTResponse._Fields) - Method in class alluxio.thrift.GetPinnedFileIdsTResponse
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(GetServiceVersionTOptions._Fields) - Method in class alluxio.thrift.GetServiceVersionTOptions
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(GetServiceVersionTResponse._Fields) - Method in class alluxio.thrift.GetServiceVersionTResponse
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(GetSizeTOptions._Fields) - Method in class alluxio.thrift.GetSizeTOptions
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(GetSizeTResponse._Fields) - Method in class alluxio.thrift.GetSizeTResponse
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(GetStatusTOptions._Fields) - Method in class alluxio.thrift.GetStatusTOptions
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(GetStatusTResponse._Fields) - Method in class alluxio.thrift.GetStatusTResponse
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(GetTOptions._Fields) - Method in class alluxio.thrift.GetTOptions
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(GetTResponse._Fields) - Method in class alluxio.thrift.GetTResponse
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(GetUfsInfoTOptions._Fields) - Method in class alluxio.thrift.GetUfsInfoTOptions
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(GetUfsInfoTResponse._Fields) - Method in class alluxio.thrift.GetUfsInfoTResponse
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(GetUsedBytesTOptions._Fields) - Method in class alluxio.thrift.GetUsedBytesTOptions
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(GetUsedBytesTResponse._Fields) - Method in class alluxio.thrift.GetUsedBytesTResponse
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(GetWorkerIdTOptions._Fields) - Method in class alluxio.thrift.GetWorkerIdTOptions
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(GetWorkerIdTResponse._Fields) - Method in class alluxio.thrift.GetWorkerIdTResponse
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(GetWorkerInfoListTOptions._Fields) - Method in class alluxio.thrift.GetWorkerInfoListTOptions
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(GetWorkerInfoListTResponse._Fields) - Method in class alluxio.thrift.GetWorkerInfoListTResponse
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(GetWorkerReportTOptions._Fields) - Method in class alluxio.thrift.GetWorkerReportTOptions
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(InconsistentProperty._Fields) - Method in class alluxio.thrift.InconsistentProperty
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(JobConfInfo._Fields) - Method in class alluxio.thrift.JobConfInfo
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(KeyValueMasterClientService.completePartition_args._Fields) - Method in class alluxio.thrift.KeyValueMasterClientService.completePartition_args
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(KeyValueMasterClientService.completePartition_result._Fields) - Method in class alluxio.thrift.KeyValueMasterClientService.completePartition_result
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(KeyValueMasterClientService.completeStore_args._Fields) - Method in class alluxio.thrift.KeyValueMasterClientService.completeStore_args
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(KeyValueMasterClientService.completeStore_result._Fields) - Method in class alluxio.thrift.KeyValueMasterClientService.completeStore_result
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(KeyValueMasterClientService.createStore_args._Fields) - Method in class alluxio.thrift.KeyValueMasterClientService.createStore_args
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(KeyValueMasterClientService.createStore_result._Fields) - Method in class alluxio.thrift.KeyValueMasterClientService.createStore_result
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(KeyValueMasterClientService.deleteStore_args._Fields) - Method in class alluxio.thrift.KeyValueMasterClientService.deleteStore_args
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(KeyValueMasterClientService.deleteStore_result._Fields) - Method in class alluxio.thrift.KeyValueMasterClientService.deleteStore_result
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(KeyValueMasterClientService.getPartitionInfo_args._Fields) - Method in class alluxio.thrift.KeyValueMasterClientService.getPartitionInfo_args
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(KeyValueMasterClientService.getPartitionInfo_result._Fields) - Method in class alluxio.thrift.KeyValueMasterClientService.getPartitionInfo_result
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(KeyValueMasterClientService.mergeStore_args._Fields) - Method in class alluxio.thrift.KeyValueMasterClientService.mergeStore_args
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(KeyValueMasterClientService.mergeStore_result._Fields) - Method in class alluxio.thrift.KeyValueMasterClientService.mergeStore_result
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(KeyValueMasterClientService.renameStore_args._Fields) - Method in class alluxio.thrift.KeyValueMasterClientService.renameStore_args
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(KeyValueMasterClientService.renameStore_result._Fields) - Method in class alluxio.thrift.KeyValueMasterClientService.renameStore_result
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(KeyValueWorkerClientService.get_args._Fields) - Method in class alluxio.thrift.KeyValueWorkerClientService.get_args
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(KeyValueWorkerClientService.get_result._Fields) - Method in class alluxio.thrift.KeyValueWorkerClientService.get_result
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(KeyValueWorkerClientService.getNextKeys_args._Fields) - Method in class alluxio.thrift.KeyValueWorkerClientService.getNextKeys_args
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(KeyValueWorkerClientService.getNextKeys_result._Fields) - Method in class alluxio.thrift.KeyValueWorkerClientService.getNextKeys_result
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(KeyValueWorkerClientService.getSize_args._Fields) - Method in class alluxio.thrift.KeyValueWorkerClientService.getSize_args
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(KeyValueWorkerClientService.getSize_result._Fields) - Method in class alluxio.thrift.KeyValueWorkerClientService.getSize_result
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(LineageInfo._Fields) - Method in class alluxio.thrift.LineageInfo
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(LineageMasterClientService.createLineage_args._Fields) - Method in class alluxio.thrift.LineageMasterClientService.createLineage_args
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(LineageMasterClientService.createLineage_result._Fields) - Method in class alluxio.thrift.LineageMasterClientService.createLineage_result
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(LineageMasterClientService.deleteLineage_args._Fields) - Method in class alluxio.thrift.LineageMasterClientService.deleteLineage_args
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(LineageMasterClientService.deleteLineage_result._Fields) - Method in class alluxio.thrift.LineageMasterClientService.deleteLineage_result
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(LineageMasterClientService.getLineageInfoList_args._Fields) - Method in class alluxio.thrift.LineageMasterClientService.getLineageInfoList_args
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(LineageMasterClientService.getLineageInfoList_result._Fields) - Method in class alluxio.thrift.LineageMasterClientService.getLineageInfoList_result
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(LineageMasterClientService.reinitializeFile_args._Fields) - Method in class alluxio.thrift.LineageMasterClientService.reinitializeFile_args
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(LineageMasterClientService.reinitializeFile_result._Fields) - Method in class alluxio.thrift.LineageMasterClientService.reinitializeFile_result
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(LineageMasterClientService.reportLostFile_args._Fields) - Method in class alluxio.thrift.LineageMasterClientService.reportLostFile_args
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(LineageMasterClientService.reportLostFile_result._Fields) - Method in class alluxio.thrift.LineageMasterClientService.reportLostFile_result
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(ListStatusTOptions._Fields) - Method in class alluxio.thrift.ListStatusTOptions
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(ListStatusTResponse._Fields) - Method in class alluxio.thrift.ListStatusTResponse
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(LoadMetadataTOptions._Fields) - Method in class alluxio.thrift.LoadMetadataTOptions
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(LoadMetadataTResponse._Fields) - Method in class alluxio.thrift.LoadMetadataTResponse
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(LocalityTier._Fields) - Method in class alluxio.thrift.LocalityTier
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(LockBlockTOptions._Fields) - Method in class alluxio.thrift.LockBlockTOptions
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(LockBlockTResponse._Fields) - Method in class alluxio.thrift.LockBlockTResponse
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(MasterHeartbeatTOptions._Fields) - Method in class alluxio.thrift.MasterHeartbeatTOptions
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(MasterHeartbeatTResponse._Fields) - Method in class alluxio.thrift.MasterHeartbeatTResponse
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(MasterInfo._Fields) - Method in class alluxio.thrift.MasterInfo
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(MasterNetAddress._Fields) - Method in class alluxio.thrift.MasterNetAddress
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(MergeStoreTOptions._Fields) - Method in class alluxio.thrift.MergeStoreTOptions
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(MergeStoreTResponse._Fields) - Method in class alluxio.thrift.MergeStoreTResponse
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(MetaMasterClientService.backup_args._Fields) - Method in class alluxio.thrift.MetaMasterClientService.backup_args
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(MetaMasterClientService.backup_result._Fields) - Method in class alluxio.thrift.MetaMasterClientService.backup_result
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(MetaMasterClientService.getConfigReport_args._Fields) - Method in class alluxio.thrift.MetaMasterClientService.getConfigReport_args
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(MetaMasterClientService.getConfigReport_result._Fields) - Method in class alluxio.thrift.MetaMasterClientService.getConfigReport_result
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(MetaMasterClientService.getConfiguration_args._Fields) - Method in class alluxio.thrift.MetaMasterClientService.getConfiguration_args
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(MetaMasterClientService.getConfiguration_result._Fields) - Method in class alluxio.thrift.MetaMasterClientService.getConfiguration_result
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(MetaMasterClientService.getMasterInfo_args._Fields) - Method in class alluxio.thrift.MetaMasterClientService.getMasterInfo_args
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(MetaMasterClientService.getMasterInfo_result._Fields) - Method in class alluxio.thrift.MetaMasterClientService.getMasterInfo_result
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(MetaMasterClientService.getMetrics_args._Fields) - Method in class alluxio.thrift.MetaMasterClientService.getMetrics_args
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(MetaMasterClientService.getMetrics_result._Fields) - Method in class alluxio.thrift.MetaMasterClientService.getMetrics_result
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(MetaMasterMasterService.getMasterId_args._Fields) - Method in class alluxio.thrift.MetaMasterMasterService.getMasterId_args
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(MetaMasterMasterService.getMasterId_result._Fields) - Method in class alluxio.thrift.MetaMasterMasterService.getMasterId_result
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(MetaMasterMasterService.masterHeartbeat_args._Fields) - Method in class alluxio.thrift.MetaMasterMasterService.masterHeartbeat_args
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(MetaMasterMasterService.masterHeartbeat_result._Fields) - Method in class alluxio.thrift.MetaMasterMasterService.masterHeartbeat_result
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(MetaMasterMasterService.registerMaster_args._Fields) - Method in class alluxio.thrift.MetaMasterMasterService.registerMaster_args
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(MetaMasterMasterService.registerMaster_result._Fields) - Method in class alluxio.thrift.MetaMasterMasterService.registerMaster_result
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(Metric._Fields) - Method in class alluxio.thrift.Metric
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(MetricsHeartbeatTOptions._Fields) - Method in class alluxio.thrift.MetricsHeartbeatTOptions
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(MetricsHeartbeatTResponse._Fields) - Method in class alluxio.thrift.MetricsHeartbeatTResponse
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(MetricsMasterClientService.metricsHeartbeat_args._Fields) - Method in class alluxio.thrift.MetricsMasterClientService.metricsHeartbeat_args
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(MetricsMasterClientService.metricsHeartbeat_result._Fields) - Method in class alluxio.thrift.MetricsMasterClientService.metricsHeartbeat_result
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(MetricValue._Fields) - Method in class alluxio.thrift.MetricValue
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(MountPointInfo._Fields) - Method in class alluxio.thrift.MountPointInfo
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(MountTOptions._Fields) - Method in class alluxio.thrift.MountTOptions
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(MountTResponse._Fields) - Method in class alluxio.thrift.MountTResponse
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(OpenUfsFileTOptions._Fields) - Method in class alluxio.thrift.OpenUfsFileTOptions
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(OpenUfsFileTResponse._Fields) - Method in class alluxio.thrift.OpenUfsFileTResponse
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(OptionalString._Fields) - Method in class alluxio.thrift.OptionalString
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(PartitionInfo._Fields) - Method in class alluxio.thrift.PartitionInfo
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(PersistCommandOptions._Fields) - Method in class alluxio.thrift.PersistCommandOptions
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(PersistFile._Fields) - Method in class alluxio.thrift.PersistFile
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(PromoteBlockTOptions._Fields) - Method in class alluxio.thrift.PromoteBlockTOptions
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(PromoteBlockTResponse._Fields) - Method in class alluxio.thrift.PromoteBlockTResponse
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(RegisterMasterTOptions._Fields) - Method in class alluxio.thrift.RegisterMasterTOptions
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(RegisterMasterTResponse._Fields) - Method in class alluxio.thrift.RegisterMasterTResponse
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(RegisterWorkerTOptions._Fields) - Method in class alluxio.thrift.RegisterWorkerTOptions
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(RegisterWorkerTResponse._Fields) - Method in class alluxio.thrift.RegisterWorkerTResponse
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(ReinitializeFileTOptions._Fields) - Method in class alluxio.thrift.ReinitializeFileTOptions
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(ReinitializeFileTResponse._Fields) - Method in class alluxio.thrift.ReinitializeFileTResponse
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(RemoveBlockTOptions._Fields) - Method in class alluxio.thrift.RemoveBlockTOptions
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(RemoveBlockTResponse._Fields) - Method in class alluxio.thrift.RemoveBlockTResponse
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(RenameStoreTOptions._Fields) - Method in class alluxio.thrift.RenameStoreTOptions
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(RenameStoreTResponse._Fields) - Method in class alluxio.thrift.RenameStoreTResponse
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(RenameTOptions._Fields) - Method in class alluxio.thrift.RenameTOptions
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(RenameTResponse._Fields) - Method in class alluxio.thrift.RenameTResponse
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(ReportLostFileTOptions._Fields) - Method in class alluxio.thrift.ReportLostFileTOptions
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(ReportLostFileTResponse._Fields) - Method in class alluxio.thrift.ReportLostFileTResponse
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(RequestBlockLocationTOptions._Fields) - Method in class alluxio.thrift.RequestBlockLocationTOptions
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(RequestBlockLocationTResponse._Fields) - Method in class alluxio.thrift.RequestBlockLocationTResponse
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(RequestSpaceTOptions._Fields) - Method in class alluxio.thrift.RequestSpaceTOptions
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(RequestSpaceTResponse._Fields) - Method in class alluxio.thrift.RequestSpaceTResponse
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(ScheduleAsyncPersistenceTOptions._Fields) - Method in class alluxio.thrift.ScheduleAsyncPersistenceTOptions
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(ScheduleAsyncPersistenceTResponse._Fields) - Method in class alluxio.thrift.ScheduleAsyncPersistenceTResponse
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(SessionBlockHeartbeatTOptions._Fields) - Method in class alluxio.thrift.SessionBlockHeartbeatTOptions
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(SessionBlockHeartbeatTResponse._Fields) - Method in class alluxio.thrift.SessionBlockHeartbeatTResponse
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(SessionFileSystemHeartbeatTOptions._Fields) - Method in class alluxio.thrift.SessionFileSystemHeartbeatTOptions
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(SessionFileSystemHeartbeatTResponse._Fields) - Method in class alluxio.thrift.SessionFileSystemHeartbeatTResponse
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(SetAttributeTOptions._Fields) - Method in class alluxio.thrift.SetAttributeTOptions
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(SetAttributeTResponse._Fields) - Method in class alluxio.thrift.SetAttributeTResponse
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(SyncMetadataTOptions._Fields) - Method in class alluxio.thrift.SyncMetadataTOptions
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(SyncMetadataTResponse._Fields) - Method in class alluxio.thrift.SyncMetadataTResponse
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(TieredIdentity._Fields) - Method in class alluxio.thrift.TieredIdentity
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(UfsInfo._Fields) - Method in class alluxio.thrift.UfsInfo
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(UnlockBlockTOptions._Fields) - Method in class alluxio.thrift.UnlockBlockTOptions
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(UnlockBlockTResponse._Fields) - Method in class alluxio.thrift.UnlockBlockTResponse
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(UnmountTOptions._Fields) - Method in class alluxio.thrift.UnmountTOptions
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(UnmountTResponse._Fields) - Method in class alluxio.thrift.UnmountTResponse
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(UpdateUfsModeTOptions._Fields) - Method in class alluxio.thrift.UpdateUfsModeTOptions
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(UpdateUfsModeTResponse._Fields) - Method in class alluxio.thrift.UpdateUfsModeTResponse
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(WorkerInfo._Fields) - Method in class alluxio.thrift.WorkerInfo
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(WorkerNetAddress._Fields) - Method in class alluxio.thrift.WorkerNetAddress
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSetAddedBlocksOnTiers() - Method in class alluxio.thrift.BlockMasterWorkerService.blockHeartbeat_args
Returns true if field addedBlocksOnTiers is set (has been assigned a value) and false otherwise
isSetAddress() - Method in class alluxio.thrift.WorkerInfo
Returns true if field address is set (has been assigned a value) and false otherwise
isSetAddresses() - Method in class alluxio.thrift.GetWorkerReportTOptions
Returns true if field addresses is set (has been assigned a value) and false otherwise
isSetAllowExists() - Method in class alluxio.thrift.CreateDirectoryTOptions
Returns true if field allowExists is set (has been assigned a value) and false otherwise
isSetAlluxioOnly() - Method in class alluxio.thrift.DeleteTOptions
Returns true if field alluxioOnly is set (has been assigned a value) and false otherwise
isSetAlluxioPath() - Method in class alluxio.thrift.FileSystemMasterClientService.mount_args
Returns true if field alluxioPath is set (has been assigned a value) and false otherwise
isSetAlluxioPath() - Method in class alluxio.thrift.FileSystemMasterClientService.unmount_args
Returns true if field alluxioPath is set (has been assigned a value) and false otherwise
isSetBackupUri() - Method in class alluxio.thrift.BackupTResponse
Returns true if field backupUri is set (has been assigned a value) and false otherwise
isSetBlockId() - Method in class alluxio.thrift.BlockInfo
Returns true if field blockId is set (has been assigned a value) and false otherwise
isSetBlockId() - Method in class alluxio.thrift.BlockMasterClientService.getBlockInfo_args
Returns true if field blockId is set (has been assigned a value) and false otherwise
isSetBlockId() - Method in class alluxio.thrift.BlockMasterWorkerService.commitBlock_args
Returns true if field blockId is set (has been assigned a value) and false otherwise
isSetBlockId() - Method in class alluxio.thrift.BlockWorkerClientService.accessBlock_args
Returns true if field blockId is set (has been assigned a value) and false otherwise
isSetBlockId() - Method in class alluxio.thrift.BlockWorkerClientService.cacheBlock_args
Returns true if field blockId is set (has been assigned a value) and false otherwise
isSetBlockId() - Method in class alluxio.thrift.BlockWorkerClientService.cancelBlock_args
Returns true if field blockId is set (has been assigned a value) and false otherwise
isSetBlockId() - Method in class alluxio.thrift.BlockWorkerClientService.lockBlock_args
Returns true if field blockId is set (has been assigned a value) and false otherwise
isSetBlockId() - Method in class alluxio.thrift.BlockWorkerClientService.promoteBlock_args
Returns true if field blockId is set (has been assigned a value) and false otherwise
isSetBlockId() - Method in class alluxio.thrift.BlockWorkerClientService.removeBlock_args
Returns true if field blockId is set (has been assigned a value) and false otherwise
isSetBlockId() - Method in class alluxio.thrift.BlockWorkerClientService.requestBlockLocation_args
Returns true if field blockId is set (has been assigned a value) and false otherwise
isSetBlockId() - Method in class alluxio.thrift.BlockWorkerClientService.requestSpace_args
Returns true if field blockId is set (has been assigned a value) and false otherwise
isSetBlockId() - Method in class alluxio.thrift.BlockWorkerClientService.unlockBlock_args
Returns true if field blockId is set (has been assigned a value) and false otherwise
isSetBlockId() - Method in class alluxio.thrift.KeyValueWorkerClientService.get_args
Returns true if field blockId is set (has been assigned a value) and false otherwise
isSetBlockId() - Method in class alluxio.thrift.KeyValueWorkerClientService.getNextKeys_args
Returns true if field blockId is set (has been assigned a value) and false otherwise
isSetBlockId() - Method in class alluxio.thrift.KeyValueWorkerClientService.getSize_args
Returns true if field blockId is set (has been assigned a value) and false otherwise
isSetBlockId() - Method in class alluxio.thrift.PartitionInfo
Returns true if field blockId is set (has been assigned a value) and false otherwise
isSetBlockIds() - Method in class alluxio.thrift.FileInfo
Returns true if field blockIds is set (has been assigned a value) and false otherwise
isSetBlockIds() - Method in class alluxio.thrift.PersistFile
Returns true if field blockIds is set (has been assigned a value) and false otherwise
isSetBlockInfo() - Method in class alluxio.thrift.FileBlockInfo
Returns true if field blockInfo is set (has been assigned a value) and false otherwise
isSetBlockInfo() - Method in class alluxio.thrift.GetBlockInfoTResponse
Returns true if field blockInfo is set (has been assigned a value) and false otherwise
isSetBlockMasterInfo() - Method in class alluxio.thrift.GetBlockMasterInfoTResponse
Returns true if field blockMasterInfo is set (has been assigned a value) and false otherwise
isSetBlockPath() - Method in class alluxio.thrift.LockBlockTResponse
Returns true if field blockPath is set (has been assigned a value) and false otherwise
isSetBlockSize() - Method in class alluxio.thrift.LockBlockTOptions
Returns true if field blockSize is set (has been assigned a value) and false otherwise
isSetBlockSizeBytes() - Method in class alluxio.thrift.CreateFileTOptions
Returns true if field blockSizeBytes is set (has been assigned a value) and false otherwise
isSetBlockSizeBytes() - Method in class alluxio.thrift.FileInfo
Returns true if field blockSizeBytes is set (has been assigned a value) and false otherwise
isSetBlockSizeBytes() - Method in class alluxio.thrift.LineageMasterClientService.reinitializeFile_args
Returns true if field blockSizeBytes is set (has been assigned a value) and false otherwise
isSetBytes() - Method in class alluxio.thrift.GetCapacityBytesTResponse
Returns true if field bytes is set (has been assigned a value) and false otherwise
isSetBytes() - Method in class alluxio.thrift.GetUsedBytesTResponse
Returns true if field bytes is set (has been assigned a value) and false otherwise
isSetCacheable() - Method in class alluxio.thrift.FileInfo
Returns true if field cacheable is set (has been assigned a value) and false otherwise
isSetCapacityBytes() - Method in class alluxio.thrift.BlockMasterInfo
Returns true if field capacityBytes is set (has been assigned a value) and false otherwise
isSetCapacityBytes() - Method in class alluxio.thrift.WorkerInfo
Returns true if field capacityBytes is set (has been assigned a value) and false otherwise
isSetCapacityBytesOnTiers() - Method in class alluxio.thrift.BlockMasterInfo
Returns true if field capacityBytesOnTiers is set (has been assigned a value) and false otherwise
isSetCapacityBytesOnTiers() - Method in class alluxio.thrift.WorkerInfo
Returns true if field capacityBytesOnTiers is set (has been assigned a value) and false otherwise
isSetCascade() - Method in class alluxio.thrift.LineageMasterClientService.deleteLineage_args
Returns true if field cascade is set (has been assigned a value) and false otherwise
isSetChildren() - Method in class alluxio.thrift.LineageInfo
Returns true if field children is set (has been assigned a value) and false otherwise
isSetClientId() - Method in class alluxio.thrift.MetricsMasterClientService.metricsHeartbeat_args
Returns true if field clientId is set (has been assigned a value) and false otherwise
isSetCommand() - Method in class alluxio.thrift.BlockHeartbeatTResponse
Returns true if field command is set (has been assigned a value) and false otherwise
isSetCommand() - Method in class alluxio.thrift.CommandLineJobInfo
Returns true if field command is set (has been assigned a value) and false otherwise
isSetCommand() - Method in class alluxio.thrift.FileSystemHeartbeatTResponse
Returns true if field command is set (has been assigned a value) and false otherwise
isSetCommand() - Method in class alluxio.thrift.MasterHeartbeatTResponse
Returns true if field command is set (has been assigned a value) and false otherwise
isSetCommandOptions() - Method in class alluxio.thrift.FileSystemCommand
Returns true if field commandOptions is set (has been assigned a value) and false otherwise
isSetCommandType() - Method in class alluxio.thrift.Command
Returns true if field commandType is set (has been assigned a value) and false otherwise
isSetCommandType() - Method in class alluxio.thrift.FileSystemCommand
Returns true if field commandType is set (has been assigned a value) and false otherwise
isSetCommonOptions() - Method in class alluxio.thrift.CheckConsistencyTOptions
Returns true if field commonOptions is set (has been assigned a value) and false otherwise
isSetCommonOptions() - Method in class alluxio.thrift.CompleteFileTOptions
Returns true if field commonOptions is set (has been assigned a value) and false otherwise
isSetCommonOptions() - Method in class alluxio.thrift.CreateDirectoryTOptions
Returns true if field commonOptions is set (has been assigned a value) and false otherwise
isSetCommonOptions() - Method in class alluxio.thrift.CreateFileTOptions
Returns true if field commonOptions is set (has been assigned a value) and false otherwise
isSetCommonOptions() - Method in class alluxio.thrift.DeleteTOptions
Returns true if field commonOptions is set (has been assigned a value) and false otherwise
isSetCommonOptions() - Method in class alluxio.thrift.FreeTOptions
Returns true if field commonOptions is set (has been assigned a value) and false otherwise
isSetCommonOptions() - Method in class alluxio.thrift.GetNewBlockIdForFileTOptions
Returns true if field commonOptions is set (has been assigned a value) and false otherwise
isSetCommonOptions() - Method in class alluxio.thrift.GetStatusTOptions
Returns true if field commonOptions is set (has been assigned a value) and false otherwise
isSetCommonOptions() - Method in class alluxio.thrift.ListStatusTOptions
Returns true if field commonOptions is set (has been assigned a value) and false otherwise
isSetCommonOptions() - Method in class alluxio.thrift.LoadMetadataTOptions
Returns true if field commonOptions is set (has been assigned a value) and false otherwise
isSetCommonOptions() - Method in class alluxio.thrift.MountTOptions
Returns true if field commonOptions is set (has been assigned a value) and false otherwise
isSetCommonOptions() - Method in class alluxio.thrift.RenameTOptions
Returns true if field commonOptions is set (has been assigned a value) and false otherwise
isSetCommonOptions() - Method in class alluxio.thrift.ScheduleAsyncPersistenceTOptions
Returns true if field commonOptions is set (has been assigned a value) and false otherwise
isSetCommonOptions() - Method in class alluxio.thrift.SetAttributeTOptions
Returns true if field commonOptions is set (has been assigned a value) and false otherwise
isSetCommonOptions() - Method in class alluxio.thrift.SyncMetadataTOptions
Returns true if field commonOptions is set (has been assigned a value) and false otherwise
isSetCommonOptions() - Method in class alluxio.thrift.UnmountTOptions
Returns true if field commonOptions is set (has been assigned a value) and false otherwise
isSetCompleted() - Method in class alluxio.thrift.FileInfo
Returns true if field completed is set (has been assigned a value) and false otherwise
isSetConf() - Method in class alluxio.thrift.CommandLineJobInfo
Returns true if field conf is set (has been assigned a value) and false otherwise
isSetConfigList() - Method in class alluxio.thrift.GetConfigurationTResponse
Returns true if field configList is set (has been assigned a value) and false otherwise
isSetConfigList() - Method in class alluxio.thrift.RegisterMasterTOptions
Returns true if field configList is set (has been assigned a value) and false otherwise
isSetConfigList() - Method in class alluxio.thrift.RegisterWorkerTOptions
Returns true if field configList is set (has been assigned a value) and false otherwise
isSetCreationTimeMs() - Method in class alluxio.thrift.FileInfo
Returns true if field creationTimeMs is set (has been assigned a value) and false otherwise
isSetCreationTimeMs() - Method in class alluxio.thrift.LineageInfo
Returns true if field creationTimeMs is set (has been assigned a value) and false otherwise
isSetCurrentBlocksOnTiers() - Method in class alluxio.thrift.BlockMasterWorkerService.registerWorker_args
Returns true if field currentBlocksOnTiers is set (has been assigned a value) and false otherwise
isSetData() - Method in class alluxio.thrift.Command
Returns true if field data is set (has been assigned a value) and false otherwise
isSetData() - Method in class alluxio.thrift.GetTResponse
Returns true if field data is set (has been assigned a value) and false otherwise
isSetDataPort() - Method in class alluxio.thrift.WorkerNetAddress
Returns true if field dataPort is set (has been assigned a value) and false otherwise
isSetDomainSocketPath() - Method in class alluxio.thrift.WorkerNetAddress
Returns true if field domainSocketPath is set (has been assigned a value) and false otherwise
isSetDoubleValue() - Method in class alluxio.thrift.MetricValue
Returns true if field doubleValue is set (has been assigned a value) and false otherwise
isSetDstPath() - Method in class alluxio.thrift.FileSystemMasterClientService.rename_args
Returns true if field dstPath is set (has been assigned a value) and false otherwise
isSetE() - Method in class alluxio.thrift.AlluxioService.getServiceVersion_result
Returns true if field e is set (has been assigned a value) and false otherwise
isSetE() - Method in class alluxio.thrift.BlockMasterClientService.getBlockInfo_result
Returns true if field e is set (has been assigned a value) and false otherwise
isSetE() - Method in class alluxio.thrift.BlockMasterClientService.getBlockMasterInfo_result
Returns true if field e is set (has been assigned a value) and false otherwise
isSetE() - Method in class alluxio.thrift.BlockMasterClientService.getCapacityBytes_result
Returns true if field e is set (has been assigned a value) and false otherwise
isSetE() - Method in class alluxio.thrift.BlockMasterClientService.getUsedBytes_result
Returns true if field e is set (has been assigned a value) and false otherwise
isSetE() - Method in class alluxio.thrift.BlockMasterClientService.getWorkerInfoList_result
Returns true if field e is set (has been assigned a value) and false otherwise
isSetE() - Method in class alluxio.thrift.BlockMasterClientService.getWorkerReport_result
Returns true if field e is set (has been assigned a value) and false otherwise
isSetE() - Method in class alluxio.thrift.BlockMasterWorkerService.blockHeartbeat_result
Returns true if field e is set (has been assigned a value) and false otherwise
isSetE() - Method in class alluxio.thrift.BlockMasterWorkerService.commitBlock_result
Returns true if field e is set (has been assigned a value) and false otherwise
isSetE() - Method in class alluxio.thrift.BlockMasterWorkerService.getWorkerId_result
Returns true if field e is set (has been assigned a value) and false otherwise
isSetE() - Method in class alluxio.thrift.BlockMasterWorkerService.registerWorker_result
Returns true if field e is set (has been assigned a value) and false otherwise
isSetE() - Method in class alluxio.thrift.BlockWorkerClientService.accessBlock_result
Returns true if field e is set (has been assigned a value) and false otherwise
isSetE() - Method in class alluxio.thrift.BlockWorkerClientService.cacheBlock_result
Returns true if field e is set (has been assigned a value) and false otherwise
isSetE() - Method in class alluxio.thrift.BlockWorkerClientService.cancelBlock_result
Returns true if field e is set (has been assigned a value) and false otherwise
isSetE() - Method in class alluxio.thrift.BlockWorkerClientService.lockBlock_result
Returns true if field e is set (has been assigned a value) and false otherwise
isSetE() - Method in class alluxio.thrift.BlockWorkerClientService.promoteBlock_result
Returns true if field e is set (has been assigned a value) and false otherwise
isSetE() - Method in class alluxio.thrift.BlockWorkerClientService.removeBlock_result
Returns true if field e is set (has been assigned a value) and false otherwise
isSetE() - Method in class alluxio.thrift.BlockWorkerClientService.requestBlockLocation_result
Returns true if field e is set (has been assigned a value) and false otherwise
isSetE() - Method in class alluxio.thrift.BlockWorkerClientService.requestSpace_result
Returns true if field e is set (has been assigned a value) and false otherwise
isSetE() - Method in class alluxio.thrift.BlockWorkerClientService.sessionBlockHeartbeat_result
Returns true if field e is set (has been assigned a value) and false otherwise
isSetE() - Method in class alluxio.thrift.BlockWorkerClientService.unlockBlock_result
Returns true if field e is set (has been assigned a value) and false otherwise
isSetE() - Method in class alluxio.thrift.FileSystemMasterClientService.checkConsistency_result
Returns true if field e is set (has been assigned a value) and false otherwise
isSetE() - Method in class alluxio.thrift.FileSystemMasterClientService.completeFile_result
Returns true if field e is set (has been assigned a value) and false otherwise
isSetE() - Method in class alluxio.thrift.FileSystemMasterClientService.createDirectory_result
Returns true if field e is set (has been assigned a value) and false otherwise
isSetE() - Method in class alluxio.thrift.FileSystemMasterClientService.createFile_result
Returns true if field e is set (has been assigned a value) and false otherwise
isSetE() - Method in class alluxio.thrift.FileSystemMasterClientService.free_result
Returns true if field e is set (has been assigned a value) and false otherwise
isSetE() - Method in class alluxio.thrift.FileSystemMasterClientService.getFilePath_result
Returns true if field e is set (has been assigned a value) and false otherwise
isSetE() - Method in class alluxio.thrift.FileSystemMasterClientService.getMountTable_result
Returns true if field e is set (has been assigned a value) and false otherwise
isSetE() - Method in class alluxio.thrift.FileSystemMasterClientService.getNewBlockIdForFile_result
Returns true if field e is set (has been assigned a value) and false otherwise
isSetE() - Method in class alluxio.thrift.FileSystemMasterClientService.getStatus_result
Returns true if field e is set (has been assigned a value) and false otherwise
isSetE() - Method in class alluxio.thrift.FileSystemMasterClientService.listStatus_result
Returns true if field e is set (has been assigned a value) and false otherwise
isSetE() - Method in class alluxio.thrift.FileSystemMasterClientService.loadMetadata_result
Returns true if field e is set (has been assigned a value) and false otherwise
isSetE() - Method in class alluxio.thrift.FileSystemMasterClientService.mount_result
Returns true if field e is set (has been assigned a value) and false otherwise
isSetE() - Method in class alluxio.thrift.FileSystemMasterClientService.remove_result
Returns true if field e is set (has been assigned a value) and false otherwise
isSetE() - Method in class alluxio.thrift.FileSystemMasterClientService.rename_result
Returns true if field e is set (has been assigned a value) and false otherwise
isSetE() - Method in class alluxio.thrift.FileSystemMasterClientService.scheduleAsyncPersistence_result
Returns true if field e is set (has been assigned a value) and false otherwise
isSetE() - Method in class alluxio.thrift.FileSystemMasterClientService.setAttribute_result
Returns true if field e is set (has been assigned a value) and false otherwise
isSetE() - Method in class alluxio.thrift.FileSystemMasterClientService.unmount_result
Returns true if field e is set (has been assigned a value) and false otherwise
isSetE() - Method in class alluxio.thrift.FileSystemMasterClientService.updateUfsMode_result
Returns true if field e is set (has been assigned a value) and false otherwise
isSetE() - Method in class alluxio.thrift.FileSystemMasterWorkerService.fileSystemHeartbeat_result
Returns true if field e is set (has been assigned a value) and false otherwise
isSetE() - Method in class alluxio.thrift.FileSystemMasterWorkerService.getFileInfo_result
Returns true if field e is set (has been assigned a value) and false otherwise
isSetE() - Method in class alluxio.thrift.FileSystemMasterWorkerService.getPinnedFileIds_result
Returns true if field e is set (has been assigned a value) and false otherwise
isSetE() - Method in class alluxio.thrift.FileSystemMasterWorkerService.getUfsInfo_result
Returns true if field e is set (has been assigned a value) and false otherwise
isSetE() - Method in class alluxio.thrift.FileSystemWorkerClientService.cancelUfsFile_result
Returns true if field e is set (has been assigned a value) and false otherwise
isSetE() - Method in class alluxio.thrift.FileSystemWorkerClientService.closeUfsFile_result
Returns true if field e is set (has been assigned a value) and false otherwise
isSetE() - Method in class alluxio.thrift.FileSystemWorkerClientService.completeUfsFile_result
Returns true if field e is set (has been assigned a value) and false otherwise
isSetE() - Method in class alluxio.thrift.FileSystemWorkerClientService.createUfsFile_result
Returns true if field e is set (has been assigned a value) and false otherwise
isSetE() - Method in class alluxio.thrift.FileSystemWorkerClientService.openUfsFile_result
Returns true if field e is set (has been assigned a value) and false otherwise
isSetE() - Method in class alluxio.thrift.FileSystemWorkerClientService.sessionFileSystemHeartbeat_result
Returns true if field e is set (has been assigned a value) and false otherwise
isSetE() - Method in class alluxio.thrift.KeyValueMasterClientService.completePartition_result
Returns true if field e is set (has been assigned a value) and false otherwise
isSetE() - Method in class alluxio.thrift.KeyValueMasterClientService.completeStore_result
Returns true if field e is set (has been assigned a value) and false otherwise
isSetE() - Method in class alluxio.thrift.KeyValueMasterClientService.createStore_result
Returns true if field e is set (has been assigned a value) and false otherwise
isSetE() - Method in class alluxio.thrift.KeyValueMasterClientService.deleteStore_result
Returns true if field e is set (has been assigned a value) and false otherwise
isSetE() - Method in class alluxio.thrift.KeyValueMasterClientService.getPartitionInfo_result
Returns true if field e is set (has been assigned a value) and false otherwise
isSetE() - Method in class alluxio.thrift.KeyValueMasterClientService.mergeStore_result
Returns true if field e is set (has been assigned a value) and false otherwise
isSetE() - Method in class alluxio.thrift.KeyValueMasterClientService.renameStore_result
Returns true if field e is set (has been assigned a value) and false otherwise
isSetE() - Method in class alluxio.thrift.KeyValueWorkerClientService.get_result
Returns true if field e is set (has been assigned a value) and false otherwise
isSetE() - Method in class alluxio.thrift.KeyValueWorkerClientService.getNextKeys_result
Returns true if field e is set (has been assigned a value) and false otherwise
isSetE() - Method in class alluxio.thrift.KeyValueWorkerClientService.getSize_result
Returns true if field e is set (has been assigned a value) and false otherwise
isSetE() - Method in class alluxio.thrift.LineageMasterClientService.createLineage_result
Returns true if field e is set (has been assigned a value) and false otherwise
isSetE() - Method in class alluxio.thrift.LineageMasterClientService.deleteLineage_result
Returns true if field e is set (has been assigned a value) and false otherwise
isSetE() - Method in class alluxio.thrift.LineageMasterClientService.getLineageInfoList_result
Returns true if field e is set (has been assigned a value) and false otherwise
isSetE() - Method in class alluxio.thrift.LineageMasterClientService.reinitializeFile_result
Returns true if field e is set (has been assigned a value) and false otherwise
isSetE() - Method in class alluxio.thrift.LineageMasterClientService.reportLostFile_result
Returns true if field e is set (has been assigned a value) and false otherwise
isSetE() - Method in class alluxio.thrift.MetaMasterClientService.backup_result
Returns true if field e is set (has been assigned a value) and false otherwise
isSetE() - Method in class alluxio.thrift.MetaMasterClientService.getConfigReport_result
Returns true if field e is set (has been assigned a value) and false otherwise
isSetE() - Method in class alluxio.thrift.MetaMasterClientService.getConfiguration_result
Returns true if field e is set (has been assigned a value) and false otherwise
isSetE() - Method in class alluxio.thrift.MetaMasterClientService.getMasterInfo_result
Returns true if field e is set (has been assigned a value) and false otherwise
isSetE() - Method in class alluxio.thrift.MetaMasterClientService.getMetrics_result
Returns true if field e is set (has been assigned a value) and false otherwise
isSetE() - Method in class alluxio.thrift.MetaMasterMasterService.getMasterId_result
Returns true if field e is set (has been assigned a value) and false otherwise
isSetE() - Method in class alluxio.thrift.MetaMasterMasterService.masterHeartbeat_result
Returns true if field e is set (has been assigned a value) and false otherwise
isSetE() - Method in class alluxio.thrift.MetaMasterMasterService.registerMaster_result
Returns true if field e is set (has been assigned a value) and false otherwise
isSetE() - Method in class alluxio.thrift.MetricsMasterClientService.metricsHeartbeat_result
Returns true if field e is set (has been assigned a value) and false otherwise
isSetEntryCount() - Method in class alluxio.thrift.BackupTResponse
Returns true if field entryCount is set (has been assigned a value) and false otherwise
isSetErrors() - Method in class alluxio.thrift.ConfigCheckReport
Returns true if field errors is set (has been assigned a value) and false otherwise
isSetFieldRange() - Method in class alluxio.thrift.GetWorkerReportTOptions
Returns true if field fieldRange is set (has been assigned a value) and false otherwise
isSetFileBlockInfos() - Method in class alluxio.thrift.FileInfo
Returns true if field fileBlockInfos is set (has been assigned a value) and false otherwise
isSetFileId() - Method in class alluxio.thrift.FileInfo
Returns true if field fileId is set (has been assigned a value) and false otherwise
isSetFileId() - Method in class alluxio.thrift.FileSystemMasterWorkerService.getFileInfo_args
Returns true if field fileId is set (has been assigned a value) and false otherwise
isSetFileId() - Method in class alluxio.thrift.GetFilePathTOptions
Returns true if field fileId is set (has been assigned a value) and false otherwise
isSetFileId() - Method in class alluxio.thrift.PersistFile
Returns true if field fileId is set (has been assigned a value) and false otherwise
isSetFileInfo() - Method in class alluxio.thrift.GetFileInfoTResponse
Returns true if field fileInfo is set (has been assigned a value) and false otherwise
isSetFileInfo() - Method in class alluxio.thrift.GetStatusTResponse
Returns true if field fileInfo is set (has been assigned a value) and false otherwise
isSetFileInfoList() - Method in class alluxio.thrift.ListStatusTResponse
Returns true if field fileInfoList is set (has been assigned a value) and false otherwise
isSetFilter() - Method in class alluxio.thrift.GetBlockMasterInfoTOptions
Returns true if field filter is set (has been assigned a value) and false otherwise
isSetFilter() - Method in class alluxio.thrift.GetMasterInfoTOptions
Returns true if field filter is set (has been assigned a value) and false otherwise
isSetFolder() - Method in class alluxio.thrift.FileInfo
Returns true if field folder is set (has been assigned a value) and false otherwise
isSetForced() - Method in class alluxio.thrift.FreeTOptions
Returns true if field forced is set (has been assigned a value) and false otherwise
isSetFreeBytes() - Method in class alluxio.thrift.BlockMasterInfo
Returns true if field freeBytes is set (has been assigned a value) and false otherwise
isSetFromPath() - Method in class alluxio.thrift.KeyValueMasterClientService.mergeStore_args
Returns true if field fromPath is set (has been assigned a value) and false otherwise
isSetGroup() - Method in class alluxio.thrift.CompleteUfsFileTOptions
Returns true if field group is set (has been assigned a value) and false otherwise
isSetGroup() - Method in class alluxio.thrift.CreateUfsFileTOptions
Returns true if field group is set (has been assigned a value) and false otherwise
isSetGroup() - Method in class alluxio.thrift.FileInfo
Returns true if field group is set (has been assigned a value) and false otherwise
isSetGroup() - Method in class alluxio.thrift.SetAttributeTOptions
Returns true if field group is set (has been assigned a value) and false otherwise
isSetHost() - Method in class alluxio.thrift.MasterNetAddress
Returns true if field host is set (has been assigned a value) and false otherwise
isSetHost() - Method in class alluxio.thrift.WorkerNetAddress
Returns true if field host is set (has been assigned a value) and false otherwise
isSetHostname() - Method in class alluxio.thrift.BackupTResponse
Returns true if field hostname is set (has been assigned a value) and false otherwise
isSetHostname() - Method in class alluxio.thrift.Metric
Returns true if field hostname is set (has been assigned a value) and false otherwise
isSetHostname() - Method in class alluxio.thrift.MetricsMasterClientService.metricsHeartbeat_args
Returns true if field hostname is set (has been assigned a value) and false otherwise
isSetId() - Method in class alluxio.thrift.CompleteUfsFileTReponse
Returns true if field id is set (has been assigned a value) and false otherwise
isSetId() - Method in class alluxio.thrift.CreateLineageTResponse
Returns true if field id is set (has been assigned a value) and false otherwise
isSetId() - Method in class alluxio.thrift.CreateUfsFileTResponse
Returns true if field id is set (has been assigned a value) and false otherwise
isSetId() - Method in class alluxio.thrift.GetNewBlockIdForFileTResponse
Returns true if field id is set (has been assigned a value) and false otherwise
isSetId() - Method in class alluxio.thrift.LineageInfo
Returns true if field id is set (has been assigned a value) and false otherwise
isSetId() - Method in class alluxio.thrift.LoadMetadataTResponse
Returns true if field id is set (has been assigned a value) and false otherwise
isSetId() - Method in class alluxio.thrift.OpenUfsFileTResponse
Returns true if field id is set (has been assigned a value) and false otherwise
isSetId() - Method in class alluxio.thrift.ReinitializeFileTResponse
Returns true if field id is set (has been assigned a value) and false otherwise
isSetId() - Method in class alluxio.thrift.WorkerInfo
Returns true if field id is set (has been assigned a value) and false otherwise
isSetInAlluxioPercentage() - Method in class alluxio.thrift.FileInfo
Returns true if field inAlluxioPercentage is set (has been assigned a value) and false otherwise
isSetInconsistentPaths() - Method in class alluxio.thrift.CheckConsistencyTResponse
Returns true if field inconsistentPaths is set (has been assigned a value) and false otherwise
isSetInfo() - Method in class alluxio.thrift.KeyValueMasterClientService.completePartition_args
Returns true if field info is set (has been assigned a value) and false otherwise
isSetInitialBytes() - Method in class alluxio.thrift.BlockWorkerClientService.requestBlockLocation_args
Returns true if field initialBytes is set (has been assigned a value) and false otherwise
isSetInMemoryPercentage() - Method in class alluxio.thrift.FileInfo
Returns true if field inMemoryPercentage is set (has been assigned a value) and false otherwise
isSetInputFiles() - Method in class alluxio.thrift.LineageInfo
Returns true if field inputFiles is set (has been assigned a value) and false otherwise
isSetInputFiles() - Method in class alluxio.thrift.LineageMasterClientService.createLineage_args
Returns true if field inputFiles is set (has been assigned a value) and false otherwise
isSetInstance() - Method in class alluxio.thrift.Metric
Returns true if field instance is set (has been assigned a value) and false otherwise
isSetInstanceId() - Method in class alluxio.thrift.Metric
Returns true if field instanceId is set (has been assigned a value) and false otherwise
isSetJob() - Method in class alluxio.thrift.LineageInfo
Returns true if field job is set (has been assigned a value) and false otherwise
isSetJob() - Method in class alluxio.thrift.LineageMasterClientService.createLineage_args
Returns true if field job is set (has been assigned a value) and false otherwise
isSetKey() - Method in class alluxio.thrift.KeyValueWorkerClientService.get_args
Returns true if field key is set (has been assigned a value) and false otherwise
isSetKey() - Method in class alluxio.thrift.KeyValueWorkerClientService.getNextKeys_args
Returns true if field key is set (has been assigned a value) and false otherwise
isSetKeyCount() - Method in class alluxio.thrift.PartitionInfo
Returns true if field keyCount is set (has been assigned a value) and false otherwise
isSetKeyLimit() - Method in class alluxio.thrift.PartitionInfo
Returns true if field keyLimit is set (has been assigned a value) and false otherwise
isSetKeys() - Method in class alluxio.thrift.GetNextKeysTResponse
Returns true if field keys is set (has been assigned a value) and false otherwise
isSetKeyStart() - Method in class alluxio.thrift.PartitionInfo
Returns true if field keyStart is set (has been assigned a value) and false otherwise
isSetLastContactSec() - Method in class alluxio.thrift.WorkerInfo
Returns true if field lastContactSec is set (has been assigned a value) and false otherwise
isSetLastModificationTimeMs() - Method in class alluxio.thrift.FileInfo
Returns true if field lastModificationTimeMs is set (has been assigned a value) and false otherwise
isSetLeaderMasterAddress() - Method in class alluxio.thrift.MasterInfo
Returns true if field leaderMasterAddress is set (has been assigned a value) and false otherwise
isSetLength() - Method in class alluxio.thrift.BlockInfo
Returns true if field length is set (has been assigned a value) and false otherwise
isSetLength() - Method in class alluxio.thrift.BlockMasterWorkerService.commitBlock_args
Returns true if field length is set (has been assigned a value) and false otherwise
isSetLength() - Method in class alluxio.thrift.FileInfo
Returns true if field length is set (has been assigned a value) and false otherwise
isSetLineageId() - Method in class alluxio.thrift.LineageMasterClientService.deleteLineage_args
Returns true if field lineageId is set (has been assigned a value) and false otherwise
isSetLineageInfoList() - Method in class alluxio.thrift.GetLineageInfoListTResponse
Returns true if field lineageInfoList is set (has been assigned a value) and false otherwise
isSetLiveWorkerNum() - Method in class alluxio.thrift.BlockMasterInfo
Returns true if field liveWorkerNum is set (has been assigned a value) and false otherwise
isSetLoadDirectChildren() - Method in class alluxio.thrift.ListStatusTOptions
Returns true if field loadDirectChildren is set (has been assigned a value) and false otherwise
isSetLoadMetadataType() - Method in class alluxio.thrift.GetStatusTOptions
Returns true if field loadMetadataType is set (has been assigned a value) and false otherwise
isSetLoadMetadataType() - Method in class alluxio.thrift.ListStatusTOptions
Returns true if field loadMetadataType is set (has been assigned a value) and false otherwise
isSetLocalFileSystem() - Method in class alluxio.thrift.BackupTOptions
Returns true if field localFileSystem is set (has been assigned a value) and false otherwise
isSetLocation() - Method in class alluxio.thrift.RequestBlockLocationTResponse
Returns true if field location is set (has been assigned a value) and false otherwise
isSetLocations() - Method in class alluxio.thrift.BlockInfo
Returns true if field locations is set (has been assigned a value) and false otherwise
isSetLockBlockStatus() - Method in class alluxio.thrift.LockBlockTResponse
Returns true if field lockBlockStatus is set (has been assigned a value) and false otherwise
isSetLockId() - Method in class alluxio.thrift.LockBlockTResponse
Returns true if field lockId is set (has been assigned a value) and false otherwise
isSetLongValue() - Method in class alluxio.thrift.MetricValue
Returns true if field longValue is set (has been assigned a value) and false otherwise
isSetLostWorkerNum() - Method in class alluxio.thrift.BlockMasterInfo
Returns true if field lostWorkerNum is set (has been assigned a value) and false otherwise
isSetMasterAddress() - Method in class alluxio.thrift.MetaMasterMasterService.getMasterId_args
Returns true if field masterAddress is set (has been assigned a value) and false otherwise
isSetMasterAddresses() - Method in class alluxio.thrift.MasterInfo
Returns true if field masterAddresses is set (has been assigned a value) and false otherwise
isSetMasterId() - Method in class alluxio.thrift.GetMasterIdTResponse
Returns true if field masterId is set (has been assigned a value) and false otherwise
isSetMasterId() - Method in class alluxio.thrift.MetaMasterMasterService.masterHeartbeat_args
Returns true if field masterId is set (has been assigned a value) and false otherwise
isSetMasterId() - Method in class alluxio.thrift.MetaMasterMasterService.registerMaster_args
Returns true if field masterId is set (has been assigned a value) and false otherwise
isSetMasterInfo() - Method in class alluxio.thrift.GetMasterInfoTResponse
Returns true if field masterInfo is set (has been assigned a value) and false otherwise
isSetMaxUfsReadConcurrency() - Method in class alluxio.thrift.LockBlockTOptions
Returns true if field maxUfsReadConcurrency is set (has been assigned a value) and false otherwise
isSetMessage() - Method in exception alluxio.thrift.AlluxioTException
Returns true if field message is set (has been assigned a value) and false otherwise
isSetMetrics() - Method in class alluxio.thrift.BlockHeartbeatTOptions
Returns true if field metrics is set (has been assigned a value) and false otherwise
isSetMetrics() - Method in class alluxio.thrift.BlockWorkerClientService.sessionBlockHeartbeat_args
Returns true if field metrics is set (has been assigned a value) and false otherwise
isSetMetrics() - Method in class alluxio.thrift.FileSystemWorkerClientService.sessionFileSystemHeartbeat_args
Returns true if field metrics is set (has been assigned a value) and false otherwise
isSetMetrics() - Method in class alluxio.thrift.MetricsHeartbeatTOptions
Returns true if field metrics is set (has been assigned a value) and false otherwise
isSetMetricsMap() - Method in class alluxio.thrift.GetMetricsTResponse
Returns true if field metricsMap is set (has been assigned a value) and false otherwise
isSetMode() - Method in class alluxio.thrift.CompleteUfsFileTOptions
Returns true if field mode is set (has been assigned a value) and false otherwise
isSetMode() - Method in class alluxio.thrift.CreateDirectoryTOptions
Returns true if field mode is set (has been assigned a value) and false otherwise
isSetMode() - Method in class alluxio.thrift.CreateFileTOptions
Returns true if field mode is set (has been assigned a value) and false otherwise
isSetMode() - Method in class alluxio.thrift.CreateUfsFileTOptions
Returns true if field mode is set (has been assigned a value) and false otherwise
isSetMode() - Method in class alluxio.thrift.FileInfo
Returns true if field mode is set (has been assigned a value) and false otherwise
isSetMode() - Method in class alluxio.thrift.SetAttributeTOptions
Returns true if field mode is set (has been assigned a value) and false otherwise
isSetMountId() - Method in class alluxio.thrift.FileInfo
Returns true if field mountId is set (has been assigned a value) and false otherwise
isSetMountId() - Method in class alluxio.thrift.FileSystemMasterWorkerService.getUfsInfo_args
Returns true if field mountId is set (has been assigned a value) and false otherwise
isSetMountId() - Method in class alluxio.thrift.LockBlockTOptions
Returns true if field mountId is set (has been assigned a value) and false otherwise
isSetMountPoint() - Method in class alluxio.thrift.FileInfo
Returns true if field mountPoint is set (has been assigned a value) and false otherwise
isSetMountTable() - Method in class alluxio.thrift.GetMountTableTResponse
Returns true if field mountTable is set (has been assigned a value) and false otherwise
isSetName() - Method in class alluxio.thrift.ConfigProperty
Returns true if field name is set (has been assigned a value) and false otherwise
isSetName() - Method in class alluxio.thrift.FileInfo
Returns true if field name is set (has been assigned a value) and false otherwise
isSetName() - Method in class alluxio.thrift.InconsistentProperty
Returns true if field name is set (has been assigned a value) and false otherwise
isSetName() - Method in class alluxio.thrift.Metric
Returns true if field name is set (has been assigned a value) and false otherwise
isSetNewPath() - Method in class alluxio.thrift.KeyValueMasterClientService.renameStore_args
Returns true if field newPath is set (has been assigned a value) and false otherwise
isSetNumKeys() - Method in class alluxio.thrift.KeyValueWorkerClientService.getNextKeys_args
Returns true if field numKeys is set (has been assigned a value) and false otherwise
isSetOffset() - Method in class alluxio.thrift.FileBlockInfo
Returns true if field offset is set (has been assigned a value) and false otherwise
isSetOffset() - Method in class alluxio.thrift.LockBlockTOptions
Returns true if field offset is set (has been assigned a value) and false otherwise
isSetOldPath() - Method in class alluxio.thrift.KeyValueMasterClientService.renameStore_args
Returns true if field oldPath is set (has been assigned a value) and false otherwise
isSetOptions() - Method in class alluxio.thrift.AlluxioService.getServiceVersion_args
Returns true if field options is set (has been assigned a value) and false otherwise
isSetOptions() - Method in class alluxio.thrift.BlockMasterClientService.getBlockInfo_args
Returns true if field options is set (has been assigned a value) and false otherwise
isSetOptions() - Method in class alluxio.thrift.BlockMasterClientService.getBlockMasterInfo_args
Returns true if field options is set (has been assigned a value) and false otherwise
isSetOptions() - Method in class alluxio.thrift.BlockMasterClientService.getCapacityBytes_args
Returns true if field options is set (has been assigned a value) and false otherwise
isSetOptions() - Method in class alluxio.thrift.BlockMasterClientService.getUsedBytes_args
Returns true if field options is set (has been assigned a value) and false otherwise
isSetOptions() - Method in class alluxio.thrift.BlockMasterClientService.getWorkerInfoList_args
Returns true if field options is set (has been assigned a value) and false otherwise
isSetOptions() - Method in class alluxio.thrift.BlockMasterClientService.getWorkerReport_args
Returns true if field options is set (has been assigned a value) and false otherwise
isSetOptions() - Method in class alluxio.thrift.BlockMasterWorkerService.blockHeartbeat_args
Returns true if field options is set (has been assigned a value) and false otherwise
isSetOptions() - Method in class alluxio.thrift.BlockMasterWorkerService.commitBlock_args
Returns true if field options is set (has been assigned a value) and false otherwise
isSetOptions() - Method in class alluxio.thrift.BlockMasterWorkerService.getWorkerId_args
Returns true if field options is set (has been assigned a value) and false otherwise
isSetOptions() - Method in class alluxio.thrift.BlockMasterWorkerService.registerWorker_args
Returns true if field options is set (has been assigned a value) and false otherwise
isSetOptions() - Method in class alluxio.thrift.BlockWorkerClientService.accessBlock_args
Returns true if field options is set (has been assigned a value) and false otherwise
isSetOptions() - Method in class alluxio.thrift.BlockWorkerClientService.cacheBlock_args
Returns true if field options is set (has been assigned a value) and false otherwise
isSetOptions() - Method in class alluxio.thrift.BlockWorkerClientService.cancelBlock_args
Returns true if field options is set (has been assigned a value) and false otherwise
isSetOptions() - Method in class alluxio.thrift.BlockWorkerClientService.lockBlock_args
Returns true if field options is set (has been assigned a value) and false otherwise
isSetOptions() - Method in class alluxio.thrift.BlockWorkerClientService.promoteBlock_args
Returns true if field options is set (has been assigned a value) and false otherwise
isSetOptions() - Method in class alluxio.thrift.BlockWorkerClientService.removeBlock_args
Returns true if field options is set (has been assigned a value) and false otherwise
isSetOptions() - Method in class alluxio.thrift.BlockWorkerClientService.requestBlockLocation_args
Returns true if field options is set (has been assigned a value) and false otherwise
isSetOptions() - Method in class alluxio.thrift.BlockWorkerClientService.requestSpace_args
Returns true if field options is set (has been assigned a value) and false otherwise
isSetOptions() - Method in class alluxio.thrift.BlockWorkerClientService.sessionBlockHeartbeat_args
Returns true if field options is set (has been assigned a value) and false otherwise
isSetOptions() - Method in class alluxio.thrift.BlockWorkerClientService.unlockBlock_args
Returns true if field options is set (has been assigned a value) and false otherwise
isSetOptions() - Method in class alluxio.thrift.FileSystemMasterClientService.checkConsistency_args
Returns true if field options is set (has been assigned a value) and false otherwise
isSetOptions() - Method in class alluxio.thrift.FileSystemMasterClientService.completeFile_args
Returns true if field options is set (has been assigned a value) and false otherwise
isSetOptions() - Method in class alluxio.thrift.FileSystemMasterClientService.createDirectory_args
Returns true if field options is set (has been assigned a value) and false otherwise
isSetOptions() - Method in class alluxio.thrift.FileSystemMasterClientService.createFile_args
Returns true if field options is set (has been assigned a value) and false otherwise
isSetOptions() - Method in class alluxio.thrift.FileSystemMasterClientService.free_args
Returns true if field options is set (has been assigned a value) and false otherwise
isSetOptions() - Method in class alluxio.thrift.FileSystemMasterClientService.getFilePath_args
Returns true if field options is set (has been assigned a value) and false otherwise
isSetOptions() - Method in class alluxio.thrift.FileSystemMasterClientService.getNewBlockIdForFile_args
Returns true if field options is set (has been assigned a value) and false otherwise
isSetOptions() - Method in class alluxio.thrift.FileSystemMasterClientService.getStatus_args
Returns true if field options is set (has been assigned a value) and false otherwise
isSetOptions() - Method in class alluxio.thrift.FileSystemMasterClientService.listStatus_args
Returns true if field options is set (has been assigned a value) and false otherwise
isSetOptions() - Method in class alluxio.thrift.FileSystemMasterClientService.loadMetadata_args
Returns true if field options is set (has been assigned a value) and false otherwise
isSetOptions() - Method in class alluxio.thrift.FileSystemMasterClientService.mount_args
Returns true if field options is set (has been assigned a value) and false otherwise
isSetOptions() - Method in class alluxio.thrift.FileSystemMasterClientService.remove_args
Returns true if field options is set (has been assigned a value) and false otherwise
isSetOptions() - Method in class alluxio.thrift.FileSystemMasterClientService.rename_args
Returns true if field options is set (has been assigned a value) and false otherwise
isSetOptions() - Method in class alluxio.thrift.FileSystemMasterClientService.scheduleAsyncPersistence_args
Returns true if field options is set (has been assigned a value) and false otherwise
isSetOptions() - Method in class alluxio.thrift.FileSystemMasterClientService.setAttribute_args
Returns true if field options is set (has been assigned a value) and false otherwise
isSetOptions() - Method in class alluxio.thrift.FileSystemMasterClientService.unmount_args
Returns true if field options is set (has been assigned a value) and false otherwise
isSetOptions() - Method in class alluxio.thrift.FileSystemMasterClientService.updateUfsMode_args
Returns true if field options is set (has been assigned a value) and false otherwise
isSetOptions() - Method in class alluxio.thrift.FileSystemMasterWorkerService.fileSystemHeartbeat_args
Returns true if field options is set (has been assigned a value) and false otherwise
isSetOptions() - Method in class alluxio.thrift.FileSystemMasterWorkerService.getFileInfo_args
Returns true if field options is set (has been assigned a value) and false otherwise
isSetOptions() - Method in class alluxio.thrift.FileSystemMasterWorkerService.getPinnedFileIds_args
Returns true if field options is set (has been assigned a value) and false otherwise
isSetOptions() - Method in class alluxio.thrift.FileSystemMasterWorkerService.getUfsInfo_args
Returns true if field options is set (has been assigned a value) and false otherwise
isSetOptions() - Method in class alluxio.thrift.FileSystemWorkerClientService.cancelUfsFile_args
Returns true if field options is set (has been assigned a value) and false otherwise
isSetOptions() - Method in class alluxio.thrift.FileSystemWorkerClientService.closeUfsFile_args
Returns true if field options is set (has been assigned a value) and false otherwise
isSetOptions() - Method in class alluxio.thrift.FileSystemWorkerClientService.completeUfsFile_args
Returns true if field options is set (has been assigned a value) and false otherwise
isSetOptions() - Method in class alluxio.thrift.FileSystemWorkerClientService.createUfsFile_args
Returns true if field options is set (has been assigned a value) and false otherwise
isSetOptions() - Method in class alluxio.thrift.FileSystemWorkerClientService.openUfsFile_args
Returns true if field options is set (has been assigned a value) and false otherwise
isSetOptions() - Method in class alluxio.thrift.FileSystemWorkerClientService.sessionFileSystemHeartbeat_args
Returns true if field options is set (has been assigned a value) and false otherwise
isSetOptions() - Method in class alluxio.thrift.KeyValueMasterClientService.completePartition_args
Returns true if field options is set (has been assigned a value) and false otherwise
isSetOptions() - Method in class alluxio.thrift.KeyValueMasterClientService.completeStore_args
Returns true if field options is set (has been assigned a value) and false otherwise
isSetOptions() - Method in class alluxio.thrift.KeyValueMasterClientService.createStore_args
Returns true if field options is set (has been assigned a value) and false otherwise
isSetOptions() - Method in class alluxio.thrift.KeyValueMasterClientService.deleteStore_args
Returns true if field options is set (has been assigned a value) and false otherwise
isSetOptions() - Method in class alluxio.thrift.KeyValueMasterClientService.getPartitionInfo_args
Returns true if field options is set (has been assigned a value) and false otherwise
isSetOptions() - Method in class alluxio.thrift.KeyValueMasterClientService.mergeStore_args
Returns true if field options is set (has been assigned a value) and false otherwise
isSetOptions() - Method in class alluxio.thrift.KeyValueMasterClientService.renameStore_args
Returns true if field options is set (has been assigned a value) and false otherwise
isSetOptions() - Method in class alluxio.thrift.KeyValueWorkerClientService.get_args
Returns true if field options is set (has been assigned a value) and false otherwise
isSetOptions() - Method in class alluxio.thrift.KeyValueWorkerClientService.getNextKeys_args
Returns true if field options is set (has been assigned a value) and false otherwise
isSetOptions() - Method in class alluxio.thrift.KeyValueWorkerClientService.getSize_args
Returns true if field options is set (has been assigned a value) and false otherwise
isSetOptions() - Method in class alluxio.thrift.LineageMasterClientService.createLineage_args
Returns true if field options is set (has been assigned a value) and false otherwise
isSetOptions() - Method in class alluxio.thrift.LineageMasterClientService.deleteLineage_args
Returns true if field options is set (has been assigned a value) and false otherwise
isSetOptions() - Method in class alluxio.thrift.LineageMasterClientService.getLineageInfoList_args
Returns true if field options is set (has been assigned a value) and false otherwise
isSetOptions() - Method in class alluxio.thrift.LineageMasterClientService.reinitializeFile_args
Returns true if field options is set (has been assigned a value) and false otherwise
isSetOptions() - Method in class alluxio.thrift.LineageMasterClientService.reportLostFile_args
Returns true if field options is set (has been assigned a value) and false otherwise
isSetOptions() - Method in class alluxio.thrift.MetaMasterClientService.backup_args
Returns true if field options is set (has been assigned a value) and false otherwise
isSetOptions() - Method in class alluxio.thrift.MetaMasterClientService.getConfigReport_args
Returns true if field options is set (has been assigned a value) and false otherwise
isSetOptions() - Method in class alluxio.thrift.MetaMasterClientService.getConfiguration_args
Returns true if field options is set (has been assigned a value) and false otherwise
isSetOptions() - Method in class alluxio.thrift.MetaMasterClientService.getMasterInfo_args
Returns true if field options is set (has been assigned a value) and false otherwise
isSetOptions() - Method in class alluxio.thrift.MetaMasterClientService.getMetrics_args
Returns true if field options is set (has been assigned a value) and false otherwise
isSetOptions() - Method in class alluxio.thrift.MetaMasterMasterService.getMasterId_args
Returns true if field options is set (has been assigned a value) and false otherwise
isSetOptions() - Method in class alluxio.thrift.MetaMasterMasterService.masterHeartbeat_args
Returns true if field options is set (has been assigned a value) and false otherwise
isSetOptions() - Method in class alluxio.thrift.MetaMasterMasterService.registerMaster_args
Returns true if field options is set (has been assigned a value) and false otherwise
isSetOptions() - Method in class alluxio.thrift.MetricsMasterClientService.metricsHeartbeat_args
Returns true if field options is set (has been assigned a value) and false otherwise
isSetOutputFile() - Method in class alluxio.thrift.JobConfInfo
Returns true if field outputFile is set (has been assigned a value) and false otherwise
isSetOutputFiles() - Method in class alluxio.thrift.LineageInfo
Returns true if field outputFiles is set (has been assigned a value) and false otherwise
isSetOutputFiles() - Method in class alluxio.thrift.LineageMasterClientService.createLineage_args
Returns true if field outputFiles is set (has been assigned a value) and false otherwise
isSetOwner() - Method in class alluxio.thrift.CompleteUfsFileTOptions
Returns true if field owner is set (has been assigned a value) and false otherwise
isSetOwner() - Method in class alluxio.thrift.CreateUfsFileTOptions
Returns true if field owner is set (has been assigned a value) and false otherwise
isSetOwner() - Method in class alluxio.thrift.FileInfo
Returns true if field owner is set (has been assigned a value) and false otherwise
isSetOwner() - Method in class alluxio.thrift.SetAttributeTOptions
Returns true if field owner is set (has been assigned a value) and false otherwise
isSetParents() - Method in class alluxio.thrift.LineageInfo
Returns true if field parents is set (has been assigned a value) and false otherwise
isSetPartitionInfo() - Method in class alluxio.thrift.GetPartitionInfoTResponse
Returns true if field partitionInfo is set (has been assigned a value) and false otherwise
isSetPath() - Method in class alluxio.thrift.FileInfo
Returns true if field path is set (has been assigned a value) and false otherwise
isSetPath() - Method in class alluxio.thrift.FileSystemMasterClientService.checkConsistency_args
Returns true if field path is set (has been assigned a value) and false otherwise
isSetPath() - Method in class alluxio.thrift.FileSystemMasterClientService.completeFile_args
Returns true if field path is set (has been assigned a value) and false otherwise
isSetPath() - Method in class alluxio.thrift.FileSystemMasterClientService.createDirectory_args
Returns true if field path is set (has been assigned a value) and false otherwise
isSetPath() - Method in class alluxio.thrift.FileSystemMasterClientService.createFile_args
Returns true if field path is set (has been assigned a value) and false otherwise
isSetPath() - Method in class alluxio.thrift.FileSystemMasterClientService.free_args
Returns true if field path is set (has been assigned a value) and false otherwise
isSetPath() - Method in class alluxio.thrift.FileSystemMasterClientService.getNewBlockIdForFile_args
Returns true if field path is set (has been assigned a value) and false otherwise
isSetPath() - Method in class alluxio.thrift.FileSystemMasterClientService.getStatus_args
Returns true if field path is set (has been assigned a value) and false otherwise
isSetPath() - Method in class alluxio.thrift.FileSystemMasterClientService.listStatus_args
Returns true if field path is set (has been assigned a value) and false otherwise
isSetPath() - Method in class alluxio.thrift.FileSystemMasterClientService.remove_args
Returns true if field path is set (has been assigned a value) and false otherwise
isSetPath() - Method in class alluxio.thrift.FileSystemMasterClientService.rename_args
Returns true if field path is set (has been assigned a value) and false otherwise
isSetPath() - Method in class alluxio.thrift.FileSystemMasterClientService.scheduleAsyncPersistence_args
Returns true if field path is set (has been assigned a value) and false otherwise
isSetPath() - Method in class alluxio.thrift.FileSystemMasterClientService.setAttribute_args
Returns true if field path is set (has been assigned a value) and false otherwise
isSetPath() - Method in class alluxio.thrift.GetFilePathTResponse
Returns true if field path is set (has been assigned a value) and false otherwise
isSetPath() - Method in class alluxio.thrift.KeyValueMasterClientService.completePartition_args
Returns true if field path is set (has been assigned a value) and false otherwise
isSetPath() - Method in class alluxio.thrift.KeyValueMasterClientService.completeStore_args
Returns true if field path is set (has been assigned a value) and false otherwise
isSetPath() - Method in class alluxio.thrift.KeyValueMasterClientService.createStore_args
Returns true if field path is set (has been assigned a value) and false otherwise
isSetPath() - Method in class alluxio.thrift.KeyValueMasterClientService.deleteStore_args
Returns true if field path is set (has been assigned a value) and false otherwise
isSetPath() - Method in class alluxio.thrift.KeyValueMasterClientService.getPartitionInfo_args
Returns true if field path is set (has been assigned a value) and false otherwise
isSetPath() - Method in class alluxio.thrift.LineageMasterClientService.reinitializeFile_args
Returns true if field path is set (has been assigned a value) and false otherwise
isSetPath() - Method in class alluxio.thrift.LineageMasterClientService.reportLostFile_args
Returns true if field path is set (has been assigned a value) and false otherwise
isSetPersisted() - Method in class alluxio.thrift.CreateDirectoryTOptions
Returns true if field persisted is set (has been assigned a value) and false otherwise
isSetPersisted() - Method in class alluxio.thrift.CreateFileTOptions
Returns true if field persisted is set (has been assigned a value) and false otherwise
isSetPersisted() - Method in class alluxio.thrift.FileInfo
Returns true if field persisted is set (has been assigned a value) and false otherwise
isSetPersisted() - Method in class alluxio.thrift.SetAttributeTOptions
Returns true if field persisted is set (has been assigned a value) and false otherwise
isSetPersistedFileFingerprints() - Method in class alluxio.thrift.FileSystemHeartbeatTOptions
Returns true if field persistedFileFingerprints is set (has been assigned a value) and false otherwise
isSetPersistedFiles() - Method in class alluxio.thrift.FileSystemMasterWorkerService.fileSystemHeartbeat_args
Returns true if field persistedFiles is set (has been assigned a value) and false otherwise
isSetPersistenceState() - Method in class alluxio.thrift.FileInfo
Returns true if field persistenceState is set (has been assigned a value) and false otherwise
isSetPersistFiles() - Method in class alluxio.thrift.PersistCommandOptions
Returns true if field persistFiles is set (has been assigned a value) and false otherwise
isSetPersistOptions() - Method in class alluxio.thrift.FileSystemCommandOptions
 
isSetPinned() - Method in class alluxio.thrift.FileInfo
Returns true if field pinned is set (has been assigned a value) and false otherwise
isSetPinned() - Method in class alluxio.thrift.SetAttributeTOptions
Returns true if field pinned is set (has been assigned a value) and false otherwise
isSetPinnedFileIds() - Method in class alluxio.thrift.GetPinnedFileIdsTResponse
Returns true if field pinnedFileIds is set (has been assigned a value) and false otherwise
isSetPromoted() - Method in class alluxio.thrift.PromoteBlockTResponse
Returns true if field promoted is set (has been assigned a value) and false otherwise
isSetProperties() - Method in class alluxio.thrift.MountPointInfo
Returns true if field properties is set (has been assigned a value) and false otherwise
isSetProperties() - Method in class alluxio.thrift.MountTOptions
Returns true if field properties is set (has been assigned a value) and false otherwise
isSetProperties() - Method in class alluxio.thrift.UfsInfo
Returns true if field properties is set (has been assigned a value) and false otherwise
isSetRawValue() - Method in class alluxio.thrift.GetConfigurationTOptions
Returns true if field rawValue is set (has been assigned a value) and false otherwise
isSetReadOnly() - Method in class alluxio.thrift.MountPointInfo
Returns true if field readOnly is set (has been assigned a value) and false otherwise
isSetReadOnly() - Method in class alluxio.thrift.MountTOptions
Returns true if field readOnly is set (has been assigned a value) and false otherwise
isSetRecursive() - Method in class alluxio.thrift.CreateDirectoryTOptions
Returns true if field recursive is set (has been assigned a value) and false otherwise
isSetRecursive() - Method in class alluxio.thrift.CreateFileTOptions
Returns true if field recursive is set (has been assigned a value) and false otherwise
isSetRecursive() - Method in class alluxio.thrift.DeleteTOptions
Returns true if field recursive is set (has been assigned a value) and false otherwise
isSetRecursive() - Method in class alluxio.thrift.FileSystemMasterClientService.free_args
Returns true if field recursive is set (has been assigned a value) and false otherwise
isSetRecursive() - Method in class alluxio.thrift.FileSystemMasterClientService.loadMetadata_args
Returns true if field recursive is set (has been assigned a value) and false otherwise
isSetRecursive() - Method in class alluxio.thrift.FileSystemMasterClientService.remove_args
Returns true if field recursive is set (has been assigned a value) and false otherwise
isSetRecursive() - Method in class alluxio.thrift.FreeTOptions
Returns true if field recursive is set (has been assigned a value) and false otherwise
isSetRecursive() - Method in class alluxio.thrift.ListStatusTOptions
Returns true if field recursive is set (has been assigned a value) and false otherwise
isSetRecursive() - Method in class alluxio.thrift.SetAttributeTOptions
Returns true if field recursive is set (has been assigned a value) and false otherwise
isSetRemovedBlockIds() - Method in class alluxio.thrift.BlockMasterWorkerService.blockHeartbeat_args
Returns true if field removedBlockIds is set (has been assigned a value) and false otherwise
isSetReport() - Method in class alluxio.thrift.GetConfigReportTResponse
Returns true if field report is set (has been assigned a value) and false otherwise
isSetRequestBytes() - Method in class alluxio.thrift.BlockWorkerClientService.requestSpace_args
Returns true if field requestBytes is set (has been assigned a value) and false otherwise
isSetRpcPort() - Method in class alluxio.thrift.MasterInfo
Returns true if field rpcPort is set (has been assigned a value) and false otherwise
isSetRpcPort() - Method in class alluxio.thrift.MasterNetAddress
Returns true if field rpcPort is set (has been assigned a value) and false otherwise
isSetRpcPort() - Method in class alluxio.thrift.WorkerNetAddress
Returns true if field rpcPort is set (has been assigned a value) and false otherwise
isSetSafeMode() - Method in class alluxio.thrift.MasterInfo
Returns true if field safeMode is set (has been assigned a value) and false otherwise
isSetSessionId() - Method in class alluxio.thrift.BlockWorkerClientService.cacheBlock_args
Returns true if field sessionId is set (has been assigned a value) and false otherwise
isSetSessionId() - Method in class alluxio.thrift.BlockWorkerClientService.cancelBlock_args
Returns true if field sessionId is set (has been assigned a value) and false otherwise
isSetSessionId() - Method in class alluxio.thrift.BlockWorkerClientService.lockBlock_args
Returns true if field sessionId is set (has been assigned a value) and false otherwise
isSetSessionId() - Method in class alluxio.thrift.BlockWorkerClientService.requestBlockLocation_args
Returns true if field sessionId is set (has been assigned a value) and false otherwise
isSetSessionId() - Method in class alluxio.thrift.BlockWorkerClientService.requestSpace_args
Returns true if field sessionId is set (has been assigned a value) and false otherwise
isSetSessionId() - Method in class alluxio.thrift.BlockWorkerClientService.sessionBlockHeartbeat_args
Returns true if field sessionId is set (has been assigned a value) and false otherwise
isSetSessionId() - Method in class alluxio.thrift.BlockWorkerClientService.unlockBlock_args
Returns true if field sessionId is set (has been assigned a value) and false otherwise
isSetSessionId() - Method in class alluxio.thrift.FileSystemWorkerClientService.cancelUfsFile_args
Returns true if field sessionId is set (has been assigned a value) and false otherwise
isSetSessionId() - Method in class alluxio.thrift.FileSystemWorkerClientService.closeUfsFile_args
Returns true if field sessionId is set (has been assigned a value) and false otherwise
isSetSessionId() - Method in class alluxio.thrift.FileSystemWorkerClientService.completeUfsFile_args
Returns true if field sessionId is set (has been assigned a value) and false otherwise
isSetSessionId() - Method in class alluxio.thrift.FileSystemWorkerClientService.createUfsFile_args
Returns true if field sessionId is set (has been assigned a value) and false otherwise
isSetSessionId() - Method in class alluxio.thrift.FileSystemWorkerClientService.openUfsFile_args
Returns true if field sessionId is set (has been assigned a value) and false otherwise
isSetSessionId() - Method in class alluxio.thrift.FileSystemWorkerClientService.sessionFileSystemHeartbeat_args
Returns true if field sessionId is set (has been assigned a value) and false otherwise
isSetShared() - Method in class alluxio.thrift.MountPointInfo
Returns true if field shared is set (has been assigned a value) and false otherwise
isSetShared() - Method in class alluxio.thrift.MountTOptions
Returns true if field shared is set (has been assigned a value) and false otherwise
isSetSize() - Method in class alluxio.thrift.GetSizeTResponse
Returns true if field size is set (has been assigned a value) and false otherwise
isSetSource() - Method in class alluxio.thrift.ConfigProperty
Returns true if field source is set (has been assigned a value) and false otherwise
isSetStartTimeMs() - Method in class alluxio.thrift.MasterInfo
Returns true if field startTimeMs is set (has been assigned a value) and false otherwise
isSetStartTimeMs() - Method in class alluxio.thrift.WorkerInfo
Returns true if field startTimeMs is set (has been assigned a value) and false otherwise
isSetState() - Method in class alluxio.thrift.WorkerInfo
Returns true if field state is set (has been assigned a value) and false otherwise
isSetStatus() - Method in exception alluxio.thrift.AlluxioTException
Returns true if field status is set (has been assigned a value) and false otherwise
isSetStatus() - Method in class alluxio.thrift.ConfigCheckReport
Returns true if field status is set (has been assigned a value) and false otherwise
isSetStorageTiers() - Method in class alluxio.thrift.BlockMasterWorkerService.registerWorker_args
Returns true if field storageTiers is set (has been assigned a value) and false otherwise
isSetSuccess() - Method in class alluxio.thrift.AlluxioService.getServiceVersion_result
Returns true if field success is set (has been assigned a value) and false otherwise
isSetSuccess() - Method in class alluxio.thrift.BlockMasterClientService.getBlockInfo_result
Returns true if field success is set (has been assigned a value) and false otherwise
isSetSuccess() - Method in class alluxio.thrift.BlockMasterClientService.getBlockMasterInfo_result
Returns true if field success is set (has been assigned a value) and false otherwise
isSetSuccess() - Method in class alluxio.thrift.BlockMasterClientService.getCapacityBytes_result
Returns true if field success is set (has been assigned a value) and false otherwise
isSetSuccess() - Method in class alluxio.thrift.BlockMasterClientService.getUsedBytes_result
Returns true if field success is set (has been assigned a value) and false otherwise
isSetSuccess() - Method in class alluxio.thrift.BlockMasterClientService.getWorkerInfoList_result
Returns true if field success is set (has been assigned a value) and false otherwise
isSetSuccess() - Method in class alluxio.thrift.BlockMasterClientService.getWorkerReport_result
Returns true if field success is set (has been assigned a value) and false otherwise
isSetSuccess() - Method in class alluxio.thrift.BlockMasterWorkerService.blockHeartbeat_result
Returns true if field success is set (has been assigned a value) and false otherwise
isSetSuccess() - Method in class alluxio.thrift.BlockMasterWorkerService.commitBlock_result
Returns true if field success is set (has been assigned a value) and false otherwise
isSetSuccess() - Method in class alluxio.thrift.BlockMasterWorkerService.getWorkerId_result
Returns true if field success is set (has been assigned a value) and false otherwise
isSetSuccess() - Method in class alluxio.thrift.BlockMasterWorkerService.registerWorker_result
Returns true if field success is set (has been assigned a value) and false otherwise
isSetSuccess() - Method in class alluxio.thrift.BlockWorkerClientService.accessBlock_result
Returns true if field success is set (has been assigned a value) and false otherwise
isSetSuccess() - Method in class alluxio.thrift.BlockWorkerClientService.cacheBlock_result
Returns true if field success is set (has been assigned a value) and false otherwise
isSetSuccess() - Method in class alluxio.thrift.BlockWorkerClientService.cancelBlock_result
Returns true if field success is set (has been assigned a value) and false otherwise
isSetSuccess() - Method in class alluxio.thrift.BlockWorkerClientService.lockBlock_result
Returns true if field success is set (has been assigned a value) and false otherwise
isSetSuccess() - Method in class alluxio.thrift.BlockWorkerClientService.promoteBlock_result
Returns true if field success is set (has been assigned a value) and false otherwise
isSetSuccess() - Method in class alluxio.thrift.BlockWorkerClientService.removeBlock_result
Returns true if field success is set (has been assigned a value) and false otherwise
isSetSuccess() - Method in class alluxio.thrift.BlockWorkerClientService.requestBlockLocation_result
Returns true if field success is set (has been assigned a value) and false otherwise
isSetSuccess() - Method in class alluxio.thrift.BlockWorkerClientService.requestSpace_result
Returns true if field success is set (has been assigned a value) and false otherwise
isSetSuccess() - Method in class alluxio.thrift.BlockWorkerClientService.sessionBlockHeartbeat_result
Returns true if field success is set (has been assigned a value) and false otherwise
isSetSuccess() - Method in class alluxio.thrift.BlockWorkerClientService.unlockBlock_result
Returns true if field success is set (has been assigned a value) and false otherwise
isSetSuccess() - Method in class alluxio.thrift.DeleteLineageTResponse
Returns true if field success is set (has been assigned a value) and false otherwise
isSetSuccess() - Method in class alluxio.thrift.FileSystemMasterClientService.checkConsistency_result
Returns true if field success is set (has been assigned a value) and false otherwise
isSetSuccess() - Method in class alluxio.thrift.FileSystemMasterClientService.completeFile_result
Returns true if field success is set (has been assigned a value) and false otherwise
isSetSuccess() - Method in class alluxio.thrift.FileSystemMasterClientService.createDirectory_result
Returns true if field success is set (has been assigned a value) and false otherwise
isSetSuccess() - Method in class alluxio.thrift.FileSystemMasterClientService.createFile_result
Returns true if field success is set (has been assigned a value) and false otherwise
isSetSuccess() - Method in class alluxio.thrift.FileSystemMasterClientService.free_result
Returns true if field success is set (has been assigned a value) and false otherwise
isSetSuccess() - Method in class alluxio.thrift.FileSystemMasterClientService.getFilePath_result
Returns true if field success is set (has been assigned a value) and false otherwise
isSetSuccess() - Method in class alluxio.thrift.FileSystemMasterClientService.getMountTable_result
Returns true if field success is set (has been assigned a value) and false otherwise
isSetSuccess() - Method in class alluxio.thrift.FileSystemMasterClientService.getNewBlockIdForFile_result
Returns true if field success is set (has been assigned a value) and false otherwise
isSetSuccess() - Method in class alluxio.thrift.FileSystemMasterClientService.getStatus_result
Returns true if field success is set (has been assigned a value) and false otherwise
isSetSuccess() - Method in class alluxio.thrift.FileSystemMasterClientService.listStatus_result
Returns true if field success is set (has been assigned a value) and false otherwise
isSetSuccess() - Method in class alluxio.thrift.FileSystemMasterClientService.loadMetadata_result
Returns true if field success is set (has been assigned a value) and false otherwise
isSetSuccess() - Method in class alluxio.thrift.FileSystemMasterClientService.mount_result
Returns true if field success is set (has been assigned a value) and false otherwise
isSetSuccess() - Method in class alluxio.thrift.FileSystemMasterClientService.remove_result
Returns true if field success is set (has been assigned a value) and false otherwise
isSetSuccess() - Method in class alluxio.thrift.FileSystemMasterClientService.rename_result
Returns true if field success is set (has been assigned a value) and false otherwise
isSetSuccess() - Method in class alluxio.thrift.FileSystemMasterClientService.scheduleAsyncPersistence_result
Returns true if field success is set (has been assigned a value) and false otherwise
isSetSuccess() - Method in class alluxio.thrift.FileSystemMasterClientService.setAttribute_result
Returns true if field success is set (has been assigned a value) and false otherwise
isSetSuccess() - Method in class alluxio.thrift.FileSystemMasterClientService.unmount_result
Returns true if field success is set (has been assigned a value) and false otherwise
isSetSuccess() - Method in class alluxio.thrift.FileSystemMasterClientService.updateUfsMode_result
Returns true if field success is set (has been assigned a value) and false otherwise
isSetSuccess() - Method in class alluxio.thrift.FileSystemMasterWorkerService.fileSystemHeartbeat_result
Returns true if field success is set (has been assigned a value) and false otherwise
isSetSuccess() - Method in class alluxio.thrift.FileSystemMasterWorkerService.getFileInfo_result
Returns true if field success is set (has been assigned a value) and false otherwise
isSetSuccess() - Method in class alluxio.thrift.FileSystemMasterWorkerService.getPinnedFileIds_result
Returns true if field success is set (has been assigned a value) and false otherwise
isSetSuccess() - Method in class alluxio.thrift.FileSystemMasterWorkerService.getUfsInfo_result
Returns true if field success is set (has been assigned a value) and false otherwise
isSetSuccess() - Method in class alluxio.thrift.FileSystemWorkerClientService.cancelUfsFile_result
Returns true if field success is set (has been assigned a value) and false otherwise
isSetSuccess() - Method in class alluxio.thrift.FileSystemWorkerClientService.closeUfsFile_result
Returns true if field success is set (has been assigned a value) and false otherwise
isSetSuccess() - Method in class alluxio.thrift.FileSystemWorkerClientService.completeUfsFile_result
Returns true if field success is set (has been assigned a value) and false otherwise
isSetSuccess() - Method in class alluxio.thrift.FileSystemWorkerClientService.createUfsFile_result
Returns true if field success is set (has been assigned a value) and false otherwise
isSetSuccess() - Method in class alluxio.thrift.FileSystemWorkerClientService.openUfsFile_result
Returns true if field success is set (has been assigned a value) and false otherwise
isSetSuccess() - Method in class alluxio.thrift.FileSystemWorkerClientService.sessionFileSystemHeartbeat_result
Returns true if field success is set (has been assigned a value) and false otherwise
isSetSuccess() - Method in class alluxio.thrift.KeyValueMasterClientService.completePartition_result
Returns true if field success is set (has been assigned a value) and false otherwise
isSetSuccess() - Method in class alluxio.thrift.KeyValueMasterClientService.completeStore_result
Returns true if field success is set (has been assigned a value) and false otherwise
isSetSuccess() - Method in class alluxio.thrift.KeyValueMasterClientService.createStore_result
Returns true if field success is set (has been assigned a value) and false otherwise
isSetSuccess() - Method in class alluxio.thrift.KeyValueMasterClientService.deleteStore_result
Returns true if field success is set (has been assigned a value) and false otherwise
isSetSuccess() - Method in class alluxio.thrift.KeyValueMasterClientService.getPartitionInfo_result
Returns true if field success is set (has been assigned a value) and false otherwise
isSetSuccess() - Method in class alluxio.thrift.KeyValueMasterClientService.mergeStore_result
Returns true if field success is set (has been assigned a value) and false otherwise
isSetSuccess() - Method in class alluxio.thrift.KeyValueMasterClientService.renameStore_result
Returns true if field success is set (has been assigned a value) and false otherwise
isSetSuccess() - Method in class alluxio.thrift.KeyValueWorkerClientService.get_result
Returns true if field success is set (has been assigned a value) and false otherwise
isSetSuccess() - Method in class alluxio.thrift.KeyValueWorkerClientService.getNextKeys_result
Returns true if field success is set (has been assigned a value) and false otherwise
isSetSuccess() - Method in class alluxio.thrift.KeyValueWorkerClientService.getSize_result
Returns true if field success is set (has been assigned a value) and false otherwise
isSetSuccess() - Method in class alluxio.thrift.LineageMasterClientService.createLineage_result
Returns true if field success is set (has been assigned a value) and false otherwise
isSetSuccess() - Method in class alluxio.thrift.LineageMasterClientService.deleteLineage_result
Returns true if field success is set (has been assigned a value) and false otherwise
isSetSuccess() - Method in class alluxio.thrift.LineageMasterClientService.getLineageInfoList_result
Returns true if field success is set (has been assigned a value) and false otherwise
isSetSuccess() - Method in class alluxio.thrift.LineageMasterClientService.reinitializeFile_result
Returns true if field success is set (has been assigned a value) and false otherwise
isSetSuccess() - Method in class alluxio.thrift.LineageMasterClientService.reportLostFile_result
Returns true if field success is set (has been assigned a value) and false otherwise
isSetSuccess() - Method in class alluxio.thrift.MetaMasterClientService.backup_result
Returns true if field success is set (has been assigned a value) and false otherwise
isSetSuccess() - Method in class alluxio.thrift.MetaMasterClientService.getConfigReport_result
Returns true if field success is set (has been assigned a value) and false otherwise
isSetSuccess() - Method in class alluxio.thrift.MetaMasterClientService.getConfiguration_result
Returns true if field success is set (has been assigned a value) and false otherwise
isSetSuccess() - Method in class alluxio.thrift.MetaMasterClientService.getMasterInfo_result
Returns true if field success is set (has been assigned a value) and false otherwise
isSetSuccess() - Method in class alluxio.thrift.MetaMasterClientService.getMetrics_result
Returns true if field success is set (has been assigned a value) and false otherwise
isSetSuccess() - Method in class alluxio.thrift.MetaMasterMasterService.getMasterId_result
Returns true if field success is set (has been assigned a value) and false otherwise
isSetSuccess() - Method in class alluxio.thrift.MetaMasterMasterService.masterHeartbeat_result
Returns true if field success is set (has been assigned a value) and false otherwise
isSetSuccess() - Method in class alluxio.thrift.MetaMasterMasterService.registerMaster_result
Returns true if field success is set (has been assigned a value) and false otherwise
isSetSuccess() - Method in class alluxio.thrift.MetricsMasterClientService.metricsHeartbeat_result
Returns true if field success is set (has been assigned a value) and false otherwise
isSetSuccess() - Method in class alluxio.thrift.RequestSpaceTResponse
Returns true if field success is set (has been assigned a value) and false otherwise
isSetSuccess() - Method in class alluxio.thrift.UnlockBlockTResponse
Returns true if field success is set (has been assigned a value) and false otherwise
isSetSynced() - Method in class alluxio.thrift.SyncMetadataTResponse
Returns true if field synced is set (has been assigned a value) and false otherwise
isSetSyncIntervalMs() - Method in class alluxio.thrift.FileSystemMasterCommonTOptions
Returns true if field syncIntervalMs is set (has been assigned a value) and false otherwise
isSetTags() - Method in class alluxio.thrift.Metric
Returns true if field tags is set (has been assigned a value) and false otherwise
isSetTargetDirectory() - Method in class alluxio.thrift.BackupTOptions
Returns true if field targetDirectory is set (has been assigned a value) and false otherwise
isSetTempUfsFileId() - Method in class alluxio.thrift.FileSystemWorkerClientService.cancelUfsFile_args
Returns true if field tempUfsFileId is set (has been assigned a value) and false otherwise
isSetTempUfsFileId() - Method in class alluxio.thrift.FileSystemWorkerClientService.closeUfsFile_args
Returns true if field tempUfsFileId is set (has been assigned a value) and false otherwise
isSetTempUfsFileId() - Method in class alluxio.thrift.FileSystemWorkerClientService.completeUfsFile_args
Returns true if field tempUfsFileId is set (has been assigned a value) and false otherwise
isSetTierAlias() - Method in class alluxio.thrift.BlockLocation
Returns true if field tierAlias is set (has been assigned a value) and false otherwise
isSetTierAlias() - Method in class alluxio.thrift.BlockMasterWorkerService.commitBlock_args
Returns true if field tierAlias is set (has been assigned a value) and false otherwise
isSetTieredIdentity() - Method in class alluxio.thrift.WorkerNetAddress
Returns true if field tieredIdentity is set (has been assigned a value) and false otherwise
isSetTierName() - Method in class alluxio.thrift.LocalityTier
Returns true if field tierName is set (has been assigned a value) and false otherwise
isSetTiers() - Method in class alluxio.thrift.TieredIdentity
Returns true if field tiers is set (has been assigned a value) and false otherwise
isSetToPath() - Method in class alluxio.thrift.KeyValueMasterClientService.mergeStore_args
Returns true if field toPath is set (has been assigned a value) and false otherwise
isSetTotalBytesOnTiers() - Method in class alluxio.thrift.BlockMasterWorkerService.registerWorker_args
Returns true if field totalBytesOnTiers is set (has been assigned a value) and false otherwise
isSetTtl() - Method in class alluxio.thrift.CreateDirectoryTOptions
Returns true if field ttl is set (has been assigned a value) and false otherwise
isSetTtl() - Method in class alluxio.thrift.CreateFileTOptions
Returns true if field ttl is set (has been assigned a value) and false otherwise
isSetTtl() - Method in class alluxio.thrift.FileInfo
Returns true if field ttl is set (has been assigned a value) and false otherwise
isSetTtl() - Method in class alluxio.thrift.LineageMasterClientService.reinitializeFile_args
Returns true if field ttl is set (has been assigned a value) and false otherwise
isSetTtl() - Method in class alluxio.thrift.SetAttributeTOptions
Returns true if field ttl is set (has been assigned a value) and false otherwise
isSetTtlAction() - Method in class alluxio.thrift.CreateDirectoryTOptions
Returns true if field ttlAction is set (has been assigned a value) and false otherwise
isSetTtlAction() - Method in class alluxio.thrift.CreateFileTOptions
Returns true if field ttlAction is set (has been assigned a value) and false otherwise
isSetTtlAction() - Method in class alluxio.thrift.FileInfo
Returns true if field ttlAction is set (has been assigned a value) and false otherwise
isSetTtlAction() - Method in class alluxio.thrift.LineageMasterClientService.reinitializeFile_args
Returns true if field ttlAction is set (has been assigned a value) and false otherwise
isSetTtlAction() - Method in class alluxio.thrift.SetAttributeTOptions
Returns true if field ttlAction is set (has been assigned a value) and false otherwise
isSetUfsCapacityBytes() - Method in class alluxio.thrift.MountPointInfo
Returns true if field ufsCapacityBytes is set (has been assigned a value) and false otherwise
isSetUfsFingerprint() - Method in class alluxio.thrift.FileInfo
Returns true if field ufsFingerprint is set (has been assigned a value) and false otherwise
isSetUfsInfo() - Method in class alluxio.thrift.GetUfsInfoTResponse
Returns true if field ufsInfo is set (has been assigned a value) and false otherwise
isSetUfsLength() - Method in class alluxio.thrift.CompleteFileTOptions
Returns true if field ufsLength is set (has been assigned a value) and false otherwise
isSetUfsLocations() - Method in class alluxio.thrift.FileBlockInfo
Returns true if field ufsLocations is set (has been assigned a value) and false otherwise
isSetUfsMode() - Method in class alluxio.thrift.UpdateUfsModeTOptions
Returns true if field ufsMode is set (has been assigned a value) and false otherwise
isSetUfsPath() - Method in class alluxio.thrift.FileInfo
Returns true if field ufsPath is set (has been assigned a value) and false otherwise
isSetUfsPath() - Method in class alluxio.thrift.FileSystemMasterClientService.loadMetadata_args
Returns true if field ufsPath is set (has been assigned a value) and false otherwise
isSetUfsPath() - Method in class alluxio.thrift.FileSystemMasterClientService.mount_args
Returns true if field ufsPath is set (has been assigned a value) and false otherwise
isSetUfsPath() - Method in class alluxio.thrift.FileSystemMasterClientService.updateUfsMode_args
Returns true if field ufsPath is set (has been assigned a value) and false otherwise
isSetUfsPath() - Method in class alluxio.thrift.FileSystemWorkerClientService.createUfsFile_args
Returns true if field ufsPath is set (has been assigned a value) and false otherwise
isSetUfsPath() - Method in class alluxio.thrift.FileSystemWorkerClientService.openUfsFile_args
Returns true if field ufsPath is set (has been assigned a value) and false otherwise
isSetUfsPath() - Method in class alluxio.thrift.LockBlockTOptions
Returns true if field ufsPath is set (has been assigned a value) and false otherwise
isSetUfsStringLocations() - Method in class alluxio.thrift.FileBlockInfo
Returns true if field ufsStringLocations is set (has been assigned a value) and false otherwise
isSetUfsType() - Method in class alluxio.thrift.MountPointInfo
Returns true if field ufsType is set (has been assigned a value) and false otherwise
isSetUfsUri() - Method in class alluxio.thrift.MountPointInfo
Returns true if field ufsUri is set (has been assigned a value) and false otherwise
isSetUfsUsedBytes() - Method in class alluxio.thrift.MountPointInfo
Returns true if field ufsUsedBytes is set (has been assigned a value) and false otherwise
isSetUnchecked() - Method in class alluxio.thrift.DeleteTOptions
Returns true if field unchecked is set (has been assigned a value) and false otherwise
isSetUpTimeMs() - Method in class alluxio.thrift.MasterInfo
Returns true if field upTimeMs is set (has been assigned a value) and false otherwise
isSetUri() - Method in class alluxio.thrift.UfsInfo
Returns true if field uri is set (has been assigned a value) and false otherwise
isSetUsedBytes() - Method in class alluxio.thrift.BlockMasterInfo
Returns true if field usedBytes is set (has been assigned a value) and false otherwise
isSetUsedBytes() - Method in class alluxio.thrift.WorkerInfo
Returns true if field usedBytes is set (has been assigned a value) and false otherwise
isSetUsedBytesOnTier() - Method in class alluxio.thrift.BlockMasterWorkerService.commitBlock_args
Returns true if field usedBytesOnTier is set (has been assigned a value) and false otherwise
isSetUsedBytesOnTiers() - Method in class alluxio.thrift.BlockMasterInfo
Returns true if field usedBytesOnTiers is set (has been assigned a value) and false otherwise
isSetUsedBytesOnTiers() - Method in class alluxio.thrift.BlockMasterWorkerService.blockHeartbeat_args
Returns true if field usedBytesOnTiers is set (has been assigned a value) and false otherwise
isSetUsedBytesOnTiers() - Method in class alluxio.thrift.BlockMasterWorkerService.registerWorker_args
Returns true if field usedBytesOnTiers is set (has been assigned a value) and false otherwise
isSetUsedBytesOnTiers() - Method in class alluxio.thrift.WorkerInfo
Returns true if field usedBytesOnTiers is set (has been assigned a value) and false otherwise
isSetValue() - Method in class alluxio.thrift.ConfigProperty
Returns true if field value is set (has been assigned a value) and false otherwise
isSetValue() - Method in class alluxio.thrift.LocalityTier
Returns true if field value is set (has been assigned a value) and false otherwise
isSetValue() - Method in class alluxio.thrift.Metric
Returns true if field value is set (has been assigned a value) and false otherwise
isSetValue() - Method in class alluxio.thrift.OptionalString
Returns true if field value is set (has been assigned a value) and false otherwise
isSetValues() - Method in class alluxio.thrift.InconsistentProperty
Returns true if field values is set (has been assigned a value) and false otherwise
isSetVersion() - Method in class alluxio.thrift.GetServiceVersionTResponse
Returns true if field version is set (has been assigned a value) and false otherwise
isSetVersion() - Method in class alluxio.thrift.MasterInfo
Returns true if field version is set (has been assigned a value) and false otherwise
isSetWarns() - Method in class alluxio.thrift.ConfigCheckReport
Returns true if field warns is set (has been assigned a value) and false otherwise
isSetWebPort() - Method in class alluxio.thrift.MasterInfo
Returns true if field webPort is set (has been assigned a value) and false otherwise
isSetWebPort() - Method in class alluxio.thrift.WorkerNetAddress
Returns true if field webPort is set (has been assigned a value) and false otherwise
isSetWorkerAddress() - Method in class alluxio.thrift.BlockLocation
Returns true if field workerAddress is set (has been assigned a value) and false otherwise
isSetWorkerAddresses() - Method in class alluxio.thrift.MasterInfo
Returns true if field workerAddresses is set (has been assigned a value) and false otherwise
isSetWorkerId() - Method in class alluxio.thrift.BlockLocation
Returns true if field workerId is set (has been assigned a value) and false otherwise
isSetWorkerId() - Method in class alluxio.thrift.BlockMasterWorkerService.blockHeartbeat_args
Returns true if field workerId is set (has been assigned a value) and false otherwise
isSetWorkerId() - Method in class alluxio.thrift.BlockMasterWorkerService.commitBlock_args
Returns true if field workerId is set (has been assigned a value) and false otherwise
isSetWorkerId() - Method in class alluxio.thrift.BlockMasterWorkerService.registerWorker_args
Returns true if field workerId is set (has been assigned a value) and false otherwise
isSetWorkerId() - Method in class alluxio.thrift.FileSystemMasterWorkerService.fileSystemHeartbeat_args
Returns true if field workerId is set (has been assigned a value) and false otherwise
isSetWorkerId() - Method in class alluxio.thrift.GetWorkerIdTResponse
Returns true if field workerId is set (has been assigned a value) and false otherwise
isSetWorkerInfoList() - Method in class alluxio.thrift.GetWorkerInfoListTResponse
Returns true if field workerInfoList is set (has been assigned a value) and false otherwise
isSetWorkerNetAddress() - Method in class alluxio.thrift.BlockMasterWorkerService.getWorkerId_args
Returns true if field workerNetAddress is set (has been assigned a value) and false otherwise
isSetWorkerRange() - Method in class alluxio.thrift.GetWorkerReportTOptions
Returns true if field workerRange is set (has been assigned a value) and false otherwise
isSetWriteTier() - Method in class alluxio.thrift.BlockWorkerClientService.requestBlockLocation_args
Returns true if field writeTier is set (has been assigned a value) and false otherwise
isSetZookeeperAddresses() - Method in class alluxio.thrift.MasterInfo
Returns true if field zookeeperAddresses is set (has been assigned a value) and false otherwise
isShared() - Method in class alluxio.client.file.options.MountOptions
 
isShared() - Method in class alluxio.master.file.options.MountOptions
 
isShared() - Method in class alluxio.thrift.MountPointInfo
 
isShared() - Method in class alluxio.thrift.MountTOptions
 
isShared() - Method in class alluxio.underfs.UnderFileSystemConfiguration
 
isShortCircuit() - Method in class alluxio.client.block.stream.BlockInStream
 
isShortCircuit() - Method in class alluxio.client.block.stream.LocalFilePacketReader.Factory
 
isShortCircuit() - Method in class alluxio.client.block.stream.NettyPacketReader.Factory
 
isShortCircuit() - Method in interface alluxio.client.block.stream.PacketReader.Factory
 
isShutdown() - Method in class alluxio.util.executor.ControllableScheduler
 
isStarted() - Method in class alluxio.util.JvmPauseMonitor
 
isStore() - Method in enum alluxio.client.AlluxioStorageType
 
isSuccess() - Method in class alluxio.thrift.DeleteLineageTResponse
 
isSuccess() - Method in class alluxio.thrift.RequestSpaceTResponse
 
isSuccess() - Method in class alluxio.thrift.UnlockBlockTResponse
 
isSwift(UnderFileSystem) - Static method in class alluxio.util.UnderFileSystemUtils
 
isSynced() - Method in class alluxio.thrift.SyncMetadataTResponse
 
isSyncPersist() - Method in enum alluxio.client.UnderStorageType
 
isTemporaryFileName(String) - Static method in class alluxio.util.io.PathUtils
Determines whether the given path is a temporary file name generated by Alluxio.
isTenantSupplied() - Method in class alluxio.underfs.swift.KeystoneV3Access
 
isTerminated() - Method in class alluxio.util.executor.ControllableScheduler
 
isThrough() - Method in enum alluxio.client.WriteType
 
isThrowOnTimeout() - Method in class alluxio.util.WaitForOptions
 
isTraceEnabled() - Method in class alluxio.util.logging.SamplingLogger
 
isTraceEnabled(Marker) - Method in class alluxio.util.logging.SamplingLogger
 
isTruncated() - Method in class alluxio.proxy.s3.ListBucketResult
 
isTruncated() - Method in class alluxio.proxy.s3.ListPartsResult
 
isTruncatedMessageException(IOException) - Static method in class alluxio.util.proto.ProtoUtils
Checks whether the exception is an InvalidProtocolBufferException thrown because of a truncated message.
isUnchecked() - Method in class alluxio.client.file.options.DeleteOptions
 
isUnchecked() - Method in class alluxio.master.file.options.DeleteOptions
 
isUnchecked() - Method in class alluxio.thrift.DeleteTOptions
 
isUnique() - Method in class alluxio.collections.IndexDefinition
 
isValid() - Method in interface alluxio.master.journalv0.JournalReader
Checks to see if the journal checkpoint has not been updated.
isValid() - Method in class alluxio.master.journalv0.ufs.UfsJournalReader
 
isValid(String) - Static method in class alluxio.PropertyKey
 
isValid() - Method in class alluxio.underfs.Fingerprint
Checks if the fingerprint object was generated from an INVALID_UFS_FINGERPRINT.
isWarnEnabled() - Method in class alluxio.util.logging.SamplingLogger
 
isWarnEnabled(Marker) - Method in class alluxio.util.logging.SamplingLogger
 
isWindows() - Static method in class alluxio.util.OSUtils
 
isWritable() - Method in class alluxio.master.journal.ufs.UfsJournal
 
isWriteLocked() - Method in class alluxio.master.file.meta.Inode
 
isWriteRequest() - Method in class alluxio.util.proto.ProtoMessage
 
isZookeeperMode() - Method in class alluxio.hadoop.FaultTolerantFileSystem
Deprecated.
 
isZookeeperMode() - Method in class alluxio.hadoop.FileSystem
 
iterator() - Method in class alluxio.client.keyvalue.ByteBufferKeyValuePartitionReader
 
iterator() - Method in interface alluxio.client.keyvalue.KeyValueIterable
 
iterator() - Method in class alluxio.collections.ConcurrentHashSet
 
iterator() - Method in interface alluxio.collections.FieldIndex
Returns an iterator over the elements in this index.
iterator() - Method in class alluxio.collections.IndexedSet
Returns an iterator over the elements in this set.
iterator() - Method in class alluxio.collections.NonUniqueFieldIndex
 
iterator() - Method in class alluxio.collections.UniqueFieldIndex
 

J

JAVA_VENDOR_NAME - Static variable in class alluxio.util.OSUtils
The java vendor name used in this platform.
JmxSink - Class in alluxio.metrics.sink
A sink which listens for new metrics and exposes them as namespaces MBeans.
JmxSink(Properties, MetricRegistry) - Constructor for class alluxio.metrics.sink.JmxSink
Creates a new JmxSink with a Properties and MetricRegistry.
Job - Class in alluxio.job
A Job that can run at Alluxio.
Job(JobConf) - Constructor for class alluxio.job.Job
Constructs with job configuration.
JOB_COMMAND_FIELD_NUMBER - Static variable in class alluxio.proto.journal.Lineage.LineageEntry
 
JOB_OUTPUT_PATH_FIELD_NUMBER - Static variable in class alluxio.proto.journal.Lineage.LineageEntry
 
JobConf - Class in alluxio.job
A job configuration.
JobConf(String) - Constructor for class alluxio.job.JobConf
Constructs the job configuration.
JobConfInfo - Class in alluxio.thrift
 
JobConfInfo() - Constructor for class alluxio.thrift.JobConfInfo
 
JobConfInfo(String) - Constructor for class alluxio.thrift.JobConfInfo
 
JobConfInfo(JobConfInfo) - Constructor for class alluxio.thrift.JobConfInfo
Performs a deep copy on other.
JobConfInfo - Class in alluxio.wire
The lineage command-line job configuration.
JobConfInfo() - Constructor for class alluxio.wire.JobConfInfo
Creates a new instance of JobConfInfo.
JobConfInfo._Fields - Enum in alluxio.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
join(String) - Method in class alluxio.AlluxioURI
Append additional path elements to the end of an AlluxioURI.
join(AlluxioURI) - Method in class alluxio.AlluxioURI
Append additional path elements to the end of an AlluxioURI.
journal(Journal.JournalEntry) - Method in class alluxio.master.file.RpcContext
Syntax sugar for getJournalContext().append(entry).
Journal - Interface in alluxio.master.journal
A journal for persisting journal entries.
Journal - Interface in alluxio.master.journalv0
The read-only journal.
Journal - Class in alluxio.proto.journal
 
Journal.Factory - Class in alluxio.master.journalv0
A Journal factory.
Journal.JournalEntry - Class in alluxio.proto.journal
Protobuf type alluxio.proto.journal.JournalEntry
Journal.JournalEntry.Builder - Class in alluxio.proto.journal
Protobuf type alluxio.proto.journal.JournalEntry
Journal.JournalEntryOrBuilder - Interface in alluxio.proto.journal
 
JOURNAL_STOP_MULTI_MASTER - Static variable in class alluxio.multi.process.PortCoordination
 
JOURNAL_STOP_SINGLE_MASTER - Static variable in class alluxio.multi.process.PortCoordination
 
JournalCheckpointStreamable - Interface in alluxio.master.journalv0
This interface enables streaming out to the journal checkpoint.
JournalClosedException - Exception in alluxio.exception
Exception thrown to indicate that an operation failed because the journal has been closed.
JournalClosedException(String) - Constructor for exception alluxio.exception.JournalClosedException
Constructs a JournalClosedException with the specified detail message.
JournalClosedException.IOJournalClosedException - Exception in alluxio.exception
Same as JournalClosedException, but extends IOException for situations where only IOException is allowed.
JournalContext - Interface in alluxio.master.journal
Context for storing journaling information.
JournalCrashTest - Class in alluxio.cli
Class to perform Journal crash test.
JournalEntryAssociation - Class in alluxio.master.journal
Association from journal entry to the master it applies to.
JournalEntryIterable - Interface in alluxio.master.journal
Interface to get an iterator of Journal.JournalEntrys.
JournalEntryRepresentable - Interface in alluxio.master.journal
This interface enables representing a class as a Journal.JournalEntry.
JournalEntryRepresentable - Interface in alluxio.master.journalv0
This interface enables representing a class as a Journal.JournalEntry.
JournalEntryStateMachine - Interface in alluxio.master.journal
Interface for a state machine which operates on Journal.JournalEntrys.
JournalEntryStreamReader - Class in alluxio.master.journal
Class for reading journal entries from an input stream.
JournalEntryStreamReader(InputStream) - Constructor for class alluxio.master.journal.JournalEntryStreamReader
 
JournalFactory - Interface in alluxio.master.journalv0
Factory for creating named journals.
JournalFileParser - Interface in alluxio.master.journal
An interface to parse a journal file.
JournalFileParser.Factory - Class in alluxio.master.journal
Factory to create JournalFileParser.
JournalFormatter - Interface in alluxio.master.journalv0
This describes the interface for serializing and de-serializing entries in the journal.
JournalFormatter.Factory - Class in alluxio.master.journalv0
Factory for JournalFormatter.
JournalInputStream - Interface in alluxio.master.journalv0
This input stream retrieves Journal.JournalEntry from journal checkpoints and journal logs.
JournalOutputStream - Interface in alluxio.master.journalv0
This output stream writes Journal.JournalEntry objects to the journal.
JournalReader - Interface in alluxio.master.journal
This class manages reading from the journal.
JournalReader - Interface in alluxio.master.journalv0
This class manages reading from the journal.
JournalReaderOptions - Class in alluxio.master.journal.options
Options to create a journal reader.
JournalSystem - Interface in alluxio.master.journal
A journal system for storing and applying journal entries.
JournalSystem.Builder - Class in alluxio.master.journal
Builder for constructing a journal system.
JournalSystem.Mode - Enum in alluxio.master.journal
The mode of the journal system.
JournalTool - Class in alluxio.master.journal
Tool for reading the journal entries given a range of sequence numbers.
JournalTool - Class in alluxio.master.journalv0
Tool for reading the journal.
JournalType - Enum in alluxio.master.journal
Enumerates the different types of journals that Alluxio may be configured with.
JournalUpgrader - Class in alluxio.master.journal
Tool to upgrade journal from v0 to v1.
JournalUtils - Class in alluxio.master.journal
Utility methods for working with the Alluxio journal.
JournalWriter - Interface in alluxio.master.journal
Interface for a class that can write and flush journal entries.
JournalWriter - Interface in alluxio.master.journalv0
This class manages all the writes to the journal.
JournalWriterOptions - Class in alluxio.master.journal.options
Options to create a JournalWriter.
jumpAndExecute(long, TimeUnit) - Method in class alluxio.util.executor.ControllableScheduler
Jumps to a future time by a given duration.
JVM_MONITOR_INFO_THRESHOLD_MS - Static variable in class alluxio.PropertyKey
 
JVM_MONITOR_INFO_THRESHOLD_MS - Static variable in class alluxio.PropertyKey.Name
 
JVM_MONITOR_SLEEP_INTERVAL_MS - Static variable in class alluxio.PropertyKey
 
JVM_MONITOR_SLEEP_INTERVAL_MS - Static variable in class alluxio.PropertyKey.Name
 
JVM_MONITOR_WARN_THRESHOLD_MS - Static variable in class alluxio.PropertyKey
 
JVM_MONITOR_WARN_THRESHOLD_MS - Static variable in class alluxio.PropertyKey.Name
 
JvmPauseMonitor - Class in alluxio.util
Class to monitor JVM with a daemon thread, the thread sleep period of time and get the true time the sleep takes.
JvmPauseMonitor() - Constructor for class alluxio.util.JvmPauseMonitor
Constructs JvmPauseMonitor.
JvmSource - Class in alluxio.metrics.source
A Source which collects JVM metrics, including JVM memory usage, GC counts, GC times, etc.
JvmSource() - Constructor for class alluxio.metrics.source.JvmSource
Creates a new JvmSource and register all JVM metrics.

K

KB - Static variable in class alluxio.Constants
 
KEY_COUNT_FIELD_NUMBER - Static variable in class alluxio.proto.journal.KeyValue.CompletePartitionEntry
 
KEY_FIELD_NUMBER - Static variable in class alluxio.proto.journal.File.StringPairEntry
 
KEY_LIMIT_FIELD_NUMBER - Static variable in class alluxio.proto.journal.KeyValue.CompletePartitionEntry
 
KEY_START_FIELD_NUMBER - Static variable in class alluxio.proto.journal.KeyValue.CompletePartitionEntry
 
KEY_VALUE_ENABLED - Static variable in class alluxio.PropertyKey
 
KEY_VALUE_ENABLED - Static variable in class alluxio.PropertyKey.Name
 
KEY_VALUE_MASTER_CLIENT_SERVICE_NAME - Static variable in class alluxio.Constants
 
KEY_VALUE_MASTER_CLIENT_SERVICE_VERSION - Static variable in class alluxio.Constants
 
KEY_VALUE_MASTER_NAME - Static variable in class alluxio.Constants
 
KEY_VALUE_PARTITION_SIZE_BYTES_MAX - Static variable in class alluxio.PropertyKey
 
KEY_VALUE_PARTITION_SIZE_BYTES_MAX - Static variable in class alluxio.PropertyKey.Name
 
KEY_VALUE_WORKER_CLIENT_SERVICE_NAME - Static variable in class alluxio.Constants
 
KEY_VALUE_WORKER_NAME - Static variable in class alluxio.Constants
 
KEY_VALUE_WORKER_SERVICE_VERSION - Static variable in class alluxio.Constants
 
keyCount() - Method in interface alluxio.client.keyvalue.Index
 
keyCount() - Method in interface alluxio.client.keyvalue.KeyValuePartitionWriter
 
keyCount() - Method in class alluxio.client.keyvalue.LinearProbingIndex
 
keyIterator(PayloadReader) - Method in interface alluxio.client.keyvalue.Index
Gets an iterator to iterate over all keys.
keyIterator(PayloadReader) - Method in class alluxio.client.keyvalue.LinearProbingIndex
 
keySet() - Method in interface alluxio.AlluxioConfiguration
 
keySet() - Method in class alluxio.conf.AlluxioProperties
 
keySet() - Method in class alluxio.conf.InstancedConfiguration
 
keySet() - Static method in class alluxio.Configuration
 
KeystoneV3Access - Class in alluxio.underfs.swift
Custom Access for Keystone V3 authentication.
KeystoneV3Access(String, String, String, String) - Constructor for class alluxio.underfs.swift.KeystoneV3Access
Construct a new instance of KeystoneV3Access.
KeystoneV3AccessProvider - Class in alluxio.underfs.swift
Custom AuthenticationMethod.AccessProvider for Keystone V3 authentication.
KeystoneV3AccessProvider(AccountConfig) - Constructor for class alluxio.underfs.swift.KeystoneV3AccessProvider
Create a new instance of KeystoneV3AccessProvider.
KeyValue - Class in alluxio.proto.journal
 
KeyValue.CompletePartitionEntry - Class in alluxio.proto.journal
Protobuf type alluxio.proto.journal.CompletePartitionEntry
KeyValue.CompletePartitionEntry.Builder - Class in alluxio.proto.journal
Protobuf type alluxio.proto.journal.CompletePartitionEntry
KeyValue.CompletePartitionEntryOrBuilder - Interface in alluxio.proto.journal
 
KeyValue.CompleteStoreEntry - Class in alluxio.proto.journal
Protobuf type alluxio.proto.journal.CompleteStoreEntry
KeyValue.CompleteStoreEntry.Builder - Class in alluxio.proto.journal
Protobuf type alluxio.proto.journal.CompleteStoreEntry
KeyValue.CompleteStoreEntryOrBuilder - Interface in alluxio.proto.journal
 
KeyValue.CreateStoreEntry - Class in alluxio.proto.journal
Protobuf type alluxio.proto.journal.CreateStoreEntry
KeyValue.CreateStoreEntry.Builder - Class in alluxio.proto.journal
Protobuf type alluxio.proto.journal.CreateStoreEntry
KeyValue.CreateStoreEntryOrBuilder - Interface in alluxio.proto.journal
 
KeyValue.DeleteStoreEntry - Class in alluxio.proto.journal
Protobuf type alluxio.proto.journal.DeleteStoreEntry
KeyValue.DeleteStoreEntry.Builder - Class in alluxio.proto.journal
Protobuf type alluxio.proto.journal.DeleteStoreEntry
KeyValue.DeleteStoreEntryOrBuilder - Interface in alluxio.proto.journal
 
KeyValue.MergeStoreEntry - Class in alluxio.proto.journal
Protobuf type alluxio.proto.journal.MergeStoreEntry
KeyValue.MergeStoreEntry.Builder - Class in alluxio.proto.journal
Protobuf type alluxio.proto.journal.MergeStoreEntry
KeyValue.MergeStoreEntryOrBuilder - Interface in alluxio.proto.journal
 
KeyValue.RenameStoreEntry - Class in alluxio.proto.journal
Protobuf type alluxio.proto.journal.RenameStoreEntry
KeyValue.RenameStoreEntry.Builder - Class in alluxio.proto.journal
Protobuf type alluxio.proto.journal.RenameStoreEntry
KeyValue.RenameStoreEntryOrBuilder - Interface in alluxio.proto.journal
 
KEYVALUE_SESSION_ID - Static variable in class alluxio.Sessions
 
KeyValueInputFormat - Class in alluxio.hadoop.mapreduce
Implementation of org.apache.hadoop.mapred.InputFormat for MapReduce programs to access KeyValueSystem.
KeyValueInputFormat() - Constructor for class alluxio.hadoop.mapreduce.KeyValueInputFormat
Constructs a new KeyValueInputFormat.
KeyValueIterable - Interface in alluxio.client.keyvalue
Interface to be implemented in classes that support iterating over key-value pairs.
KeyValueIterator - Interface in alluxio.client.keyvalue
Iterator to iterate over key-value pairs in KeyValueSystem or its partitions.
KeyValueMaster - Interface in alluxio.master.keyvalue
Interface of key-value master that stores key-value store information in Alluxio, including the partitions of each key-value store.
KeyValueMasterClient - Class in alluxio.client.keyvalue
A wrapper for the thrift client to interact with the key-value master, used by Alluxio clients.
KeyValueMasterClient(MasterClientConfig) - Constructor for class alluxio.client.keyvalue.KeyValueMasterClient
Creates a new key-value master client.
KeyValueMasterClientService - Class in alluxio.thrift
 
KeyValueMasterClientService() - Constructor for class alluxio.thrift.KeyValueMasterClientService
 
KeyValueMasterClientService.AsyncClient - Class in alluxio.thrift
 
KeyValueMasterClientService.AsyncClient.completePartition_call - Class in alluxio.thrift
 
KeyValueMasterClientService.AsyncClient.completeStore_call - Class in alluxio.thrift
 
KeyValueMasterClientService.AsyncClient.createStore_call - Class in alluxio.thrift
 
KeyValueMasterClientService.AsyncClient.deleteStore_call - Class in alluxio.thrift
 
KeyValueMasterClientService.AsyncClient.Factory - Class in alluxio.thrift
 
KeyValueMasterClientService.AsyncClient.getPartitionInfo_call - Class in alluxio.thrift
 
KeyValueMasterClientService.AsyncClient.mergeStore_call - Class in alluxio.thrift
 
KeyValueMasterClientService.AsyncClient.renameStore_call - Class in alluxio.thrift
 
KeyValueMasterClientService.AsyncIface - Interface in alluxio.thrift
 
KeyValueMasterClientService.AsyncProcessor<I extends KeyValueMasterClientService.AsyncIface> - Class in alluxio.thrift
 
KeyValueMasterClientService.AsyncProcessor.completePartition<I extends KeyValueMasterClientService.AsyncIface> - Class in alluxio.thrift
 
KeyValueMasterClientService.AsyncProcessor.completeStore<I extends KeyValueMasterClientService.AsyncIface> - Class in alluxio.thrift
 
KeyValueMasterClientService.AsyncProcessor.createStore<I extends KeyValueMasterClientService.AsyncIface> - Class in alluxio.thrift
 
KeyValueMasterClientService.AsyncProcessor.deleteStore<I extends KeyValueMasterClientService.AsyncIface> - Class in alluxio.thrift
 
KeyValueMasterClientService.AsyncProcessor.getPartitionInfo<I extends KeyValueMasterClientService.AsyncIface> - Class in alluxio.thrift
 
KeyValueMasterClientService.AsyncProcessor.mergeStore<I extends KeyValueMasterClientService.AsyncIface> - Class in alluxio.thrift
 
KeyValueMasterClientService.AsyncProcessor.renameStore<I extends KeyValueMasterClientService.AsyncIface> - Class in alluxio.thrift
 
KeyValueMasterClientService.Client - Class in alluxio.thrift
 
KeyValueMasterClientService.Client.Factory - Class in alluxio.thrift
 
KeyValueMasterClientService.completePartition_args - Class in alluxio.thrift
 
KeyValueMasterClientService.completePartition_args._Fields - Enum in alluxio.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
KeyValueMasterClientService.completePartition_result - Class in alluxio.thrift
 
KeyValueMasterClientService.completePartition_result._Fields - Enum in alluxio.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
KeyValueMasterClientService.completeStore_args - Class in alluxio.thrift
 
KeyValueMasterClientService.completeStore_args._Fields - Enum in alluxio.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
KeyValueMasterClientService.completeStore_result - Class in alluxio.thrift
 
KeyValueMasterClientService.completeStore_result._Fields - Enum in alluxio.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
KeyValueMasterClientService.createStore_args - Class in alluxio.thrift
 
KeyValueMasterClientService.createStore_args._Fields - Enum in alluxio.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
KeyValueMasterClientService.createStore_result - Class in alluxio.thrift
 
KeyValueMasterClientService.createStore_result._Fields - Enum in alluxio.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
KeyValueMasterClientService.deleteStore_args - Class in alluxio.thrift
 
KeyValueMasterClientService.deleteStore_args._Fields - Enum in alluxio.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
KeyValueMasterClientService.deleteStore_result - Class in alluxio.thrift
 
KeyValueMasterClientService.deleteStore_result._Fields - Enum in alluxio.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
KeyValueMasterClientService.getPartitionInfo_args - Class in alluxio.thrift
 
KeyValueMasterClientService.getPartitionInfo_args._Fields - Enum in alluxio.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
KeyValueMasterClientService.getPartitionInfo_result - Class in alluxio.thrift
 
KeyValueMasterClientService.getPartitionInfo_result._Fields - Enum in alluxio.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
KeyValueMasterClientService.Iface - Interface in alluxio.thrift
This interface contains key-value master service endpoints for Alluxio clients.
KeyValueMasterClientService.mergeStore_args - Class in alluxio.thrift
 
KeyValueMasterClientService.mergeStore_args._Fields - Enum in alluxio.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
KeyValueMasterClientService.mergeStore_result - Class in alluxio.thrift
 
KeyValueMasterClientService.mergeStore_result._Fields - Enum in alluxio.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
KeyValueMasterClientService.Processor<I extends KeyValueMasterClientService.Iface> - Class in alluxio.thrift
 
KeyValueMasterClientService.Processor.completePartition<I extends KeyValueMasterClientService.Iface> - Class in alluxio.thrift
 
KeyValueMasterClientService.Processor.completeStore<I extends KeyValueMasterClientService.Iface> - Class in alluxio.thrift
 
KeyValueMasterClientService.Processor.createStore<I extends KeyValueMasterClientService.Iface> - Class in alluxio.thrift
 
KeyValueMasterClientService.Processor.deleteStore<I extends KeyValueMasterClientService.Iface> - Class in alluxio.thrift
 
KeyValueMasterClientService.Processor.getPartitionInfo<I extends KeyValueMasterClientService.Iface> - Class in alluxio.thrift
 
KeyValueMasterClientService.Processor.mergeStore<I extends KeyValueMasterClientService.Iface> - Class in alluxio.thrift
 
KeyValueMasterClientService.Processor.renameStore<I extends KeyValueMasterClientService.Iface> - Class in alluxio.thrift
 
KeyValueMasterClientService.renameStore_args - Class in alluxio.thrift
 
KeyValueMasterClientService.renameStore_args._Fields - Enum in alluxio.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
KeyValueMasterClientService.renameStore_result - Class in alluxio.thrift
 
KeyValueMasterClientService.renameStore_result._Fields - Enum in alluxio.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
KeyValueMasterClientServiceHandler - Class in alluxio.master.keyvalue
This class is a Thrift handler for key-value master RPCs invoked by an Alluxio client.
KeyValueMasterFactory - Class in alluxio.master.keyvalue
Factory to create a KeyValueMaster instance.
KeyValueMasterFactory() - Constructor for class alluxio.master.keyvalue.KeyValueMasterFactory
Constructs a new KeyValueMasterFactory.
KeyValueOutputCommitter - Class in alluxio.hadoop.mapreduce
Extension of FileOutputCommitter where creating, completing, or deleting a KeyValueSystem in different phases of a job's or task's lifecycle is considered.
KeyValueOutputCommitter(Path, TaskAttemptContext) - Constructor for class alluxio.hadoop.mapreduce.KeyValueOutputCommitter
Constructor.
KeyValueOutputFormat - Class in alluxio.hadoop.mapreduce
An OutputFormat implementation to let MapReduce job write to a key-value store under the MapReduce output directory.
KeyValueOutputFormat() - Constructor for class alluxio.hadoop.mapreduce.KeyValueOutputFormat
Constructs a new KeyValueOutputFormat.
KeyValuePair - Class in alluxio.client.keyvalue
A key-value pair.
KeyValuePair(ByteBuffer, ByteBuffer) - Constructor for class alluxio.client.keyvalue.KeyValuePair
Constructs a key-value pair.
KeyValuePair(byte[], byte[]) - Constructor for class alluxio.client.keyvalue.KeyValuePair
Constructs a key-value pair.
KeyValuePartitionReader - Interface in alluxio.client.keyvalue
Interface for a reader which accesses an Alluxio key-value partition.
KeyValuePartitionReader.Factory - Class in alluxio.client.keyvalue
KeyValuePartitionWriter - Interface in alluxio.client.keyvalue
Interface for a writer which creates an Alluxio key-value partition.
KeyValuePartitionWriter.Factory - Class in alluxio.client.keyvalue
KeyValueStoreIterator - Class in alluxio.client.keyvalue
KeyValueIterator to iterate over key-value pairs in KeyValueSystem.
KeyValueStoreIterator(List<PartitionInfo>) - Constructor for class alluxio.client.keyvalue.KeyValueStoreIterator
 
KeyValueStoreOperations - Class in alluxio.examples.keyvalue
This example illustrates how to create a key-value store, put key-value pairs into the store, and read the store afterwards.
KeyValueStoreOperations(AlluxioURI) - Constructor for class alluxio.examples.keyvalue.KeyValueStoreOperations
 
KeyValueStoreQuickStart - Class in alluxio.examples.keyvalue
A quick start tutorial for creating a key-value store, putting and getting some key-value pairs.
KeyValueStoreReader - Interface in alluxio.client.keyvalue
Interface for readers which accesses key-value stores in Alluxio.
KeyValueStoreWriter - Interface in alluxio.client.keyvalue
Interface for writers which create new key-value stores in Alluxio.
KeyValueSystem - Interface in alluxio.client.keyvalue
Client to access or create key-value stores in Alluxio.
KeyValueSystem.Factory - Class in alluxio.client.keyvalue
Factory for the KeyValueSystem.
KeyValueWorker - Class in alluxio.worker.keyvalue
A worker serving key-value queries.
KeyValueWorkerClient - Class in alluxio.client.keyvalue
Client for talking to a key-value worker server.
KeyValueWorkerClient(WorkerNetAddress) - Constructor for class alluxio.client.keyvalue.KeyValueWorkerClient
KeyValueWorkerClientService - Class in alluxio.thrift
 
KeyValueWorkerClientService() - Constructor for class alluxio.thrift.KeyValueWorkerClientService
 
KeyValueWorkerClientService.AsyncClient - Class in alluxio.thrift
 
KeyValueWorkerClientService.AsyncClient.Factory - Class in alluxio.thrift
 
KeyValueWorkerClientService.AsyncClient.get_call - Class in alluxio.thrift
 
KeyValueWorkerClientService.AsyncClient.getNextKeys_call - Class in alluxio.thrift
 
KeyValueWorkerClientService.AsyncClient.getSize_call - Class in alluxio.thrift
 
KeyValueWorkerClientService.AsyncIface - Interface in alluxio.thrift
 
KeyValueWorkerClientService.AsyncProcessor<I extends KeyValueWorkerClientService.AsyncIface> - Class in alluxio.thrift
 
KeyValueWorkerClientService.AsyncProcessor.get<I extends KeyValueWorkerClientService.AsyncIface> - Class in alluxio.thrift
 
KeyValueWorkerClientService.AsyncProcessor.getNextKeys<I extends KeyValueWorkerClientService.AsyncIface> - Class in alluxio.thrift
 
KeyValueWorkerClientService.AsyncProcessor.getSize<I extends KeyValueWorkerClientService.AsyncIface> - Class in alluxio.thrift
 
KeyValueWorkerClientService.Client - Class in alluxio.thrift
 
KeyValueWorkerClientService.Client.Factory - Class in alluxio.thrift
 
KeyValueWorkerClientService.get_args - Class in alluxio.thrift
 
KeyValueWorkerClientService.get_args._Fields - Enum in alluxio.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
KeyValueWorkerClientService.get_result - Class in alluxio.thrift
 
KeyValueWorkerClientService.get_result._Fields - Enum in alluxio.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
KeyValueWorkerClientService.getNextKeys_args - Class in alluxio.thrift
 
KeyValueWorkerClientService.getNextKeys_args._Fields - Enum in alluxio.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
KeyValueWorkerClientService.getNextKeys_result - Class in alluxio.thrift
 
KeyValueWorkerClientService.getNextKeys_result._Fields - Enum in alluxio.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
KeyValueWorkerClientService.getSize_args - Class in alluxio.thrift
 
KeyValueWorkerClientService.getSize_args._Fields - Enum in alluxio.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
KeyValueWorkerClientService.getSize_result - Class in alluxio.thrift
 
KeyValueWorkerClientService.getSize_result._Fields - Enum in alluxio.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
KeyValueWorkerClientService.Iface - Interface in alluxio.thrift
 
KeyValueWorkerClientService.Processor<I extends KeyValueWorkerClientService.Iface> - Class in alluxio.thrift
 
KeyValueWorkerClientService.Processor.get<I extends KeyValueWorkerClientService.Iface> - Class in alluxio.thrift
 
KeyValueWorkerClientService.Processor.getNextKeys<I extends KeyValueWorkerClientService.Iface> - Class in alluxio.thrift
 
KeyValueWorkerClientService.Processor.getSize<I extends KeyValueWorkerClientService.Iface> - Class in alluxio.thrift
 
KeyValueWorkerClientServiceHandler - Class in alluxio.worker.keyvalue
RPC service handler on worker side to read a local key-value block.
KeyValueWorkerFactory - Class in alluxio.worker.keyvalue
Factory to create a KeyValueWorker instance.
KeyValueWorkerFactory() - Constructor for class alluxio.worker.keyvalue.KeyValueWorkerFactory
Constructs a new KeyValueWorkerFactory.

L

LAST_MODIFICATION_TIME_MS_FIELD_NUMBER - Static variable in class alluxio.proto.journal.File.InodeDirectoryEntry
 
LAST_MODIFICATION_TIME_MS_FIELD_NUMBER - Static variable in class alluxio.proto.journal.File.InodeFileEntry
 
LAST_MODIFICATION_TIME_MS_FIELD_NUMBER - Static variable in class alluxio.proto.journal.File.InodeLastModificationTimeEntry
 
LAST_TIER - Static variable in class alluxio.Constants
 
LastContactSecComparator() - Constructor for class alluxio.wire.WorkerInfo.LastContactSecComparator
LastContactSecComparator constructor.
LazyUfsBlockLocationCache - Class in alluxio.master.file.meta
Lazily cache the block locations only when needed.
LazyUfsBlockLocationCache(MountTable) - Constructor for class alluxio.master.file.meta.LazyUfsBlockLocationCache
Creates a new instance of UfsBlockLocationCache.
LeaderCommand - Class in alluxio.cli.fs.command
Prints the current leader master host name.
LeaderCommand(FileSystem) - Constructor for class alluxio.cli.fs.command.LeaderCommand
 
length() - Method in class alluxio.PropertyKey
 
LENGTH_FIELD_NUMBER - Static variable in class alluxio.proto.dataserver.Protocol.AsyncCacheRequest
 
LENGTH_FIELD_NUMBER - Static variable in class alluxio.proto.dataserver.Protocol.ReadRequest
 
LENGTH_FIELD_NUMBER - Static variable in class alluxio.proto.journal.Block.BlockInfoEntry
 
LENGTH_FIELD_NUMBER - Static variable in class alluxio.proto.journal.File.CompleteFileEntry
 
LENGTH_FIELD_NUMBER - Static variable in class alluxio.proto.journal.File.InodeFileEntry
 
LENGTH_FIELD_NUMBER - Static variable in class alluxio.proto.journal.File.PersistFileEntry
 
LIB_DIR - Static variable in class alluxio.extensions.ExtensionFactoryRegistry
 
LimitedLifeMasterProcess - Class in alluxio.multi.process
Wrapper around AlluxioMaster which will exit after a limited amount of time.
LimitedLifeMasterProcess() - Constructor for class alluxio.multi.process.LimitedLifeMasterProcess
 
LimitedLifeWorkerProcess - Class in alluxio.multi.process
Wrapper around AlluxioWorker which will exit after a limited amount of time.
LimitedLifeWorkerProcess() - Constructor for class alluxio.multi.process.LimitedLifeWorkerProcess
 
limitLife(long) - Static method in class alluxio.multi.process.Utils
Launches a thread to terminate the current process after the specified period has elapsed.
Lineage - Class in alluxio.master.lineage.meta
A lineage tracks the dependencies imposed by a job, including the input files the job depends on, and the output files the job generates.
Lineage(long, List<Long>, List<Long>, Job) - Constructor for class alluxio.master.lineage.meta.Lineage
Creates a new instance of Lineage.
Lineage(long, List<Long>, List<Long>, Job, long) - Constructor for class alluxio.master.lineage.meta.Lineage
Creates a new instance of Lineage.
Lineage - Class in alluxio.proto.journal
 
Lineage.DeleteLineageEntry - Class in alluxio.proto.journal
Protobuf type alluxio.proto.journal.DeleteLineageEntry
Lineage.DeleteLineageEntry.Builder - Class in alluxio.proto.journal
Protobuf type alluxio.proto.journal.DeleteLineageEntry
Lineage.DeleteLineageEntryOrBuilder - Interface in alluxio.proto.journal
 
Lineage.LineageEntry - Class in alluxio.proto.journal
Protobuf type alluxio.proto.journal.LineageEntry
Lineage.LineageEntry.Builder - Class in alluxio.proto.journal
Protobuf type alluxio.proto.journal.LineageEntry
Lineage.LineageEntryOrBuilder - Interface in alluxio.proto.journal
 
Lineage.LineageIdGeneratorEntry - Class in alluxio.proto.journal
Protobuf type alluxio.proto.journal.LineageIdGeneratorEntry
Lineage.LineageIdGeneratorEntry.Builder - Class in alluxio.proto.journal
Protobuf type alluxio.proto.journal.LineageIdGeneratorEntry
Lineage.LineageIdGeneratorEntryOrBuilder - Interface in alluxio.proto.journal
 
LINEAGE_FIELD_NUMBER - Static variable in class alluxio.proto.journal.Journal.JournalEntry
 
LINEAGE_ID_FIELD_NUMBER - Static variable in class alluxio.proto.journal.Lineage.DeleteLineageEntry
 
LINEAGE_ID_GENERATOR_FIELD_NUMBER - Static variable in class alluxio.proto.journal.Journal.JournalEntry
 
LINEAGE_MASTER_CLIENT_SERVICE_NAME - Static variable in class alluxio.Constants
 
LINEAGE_MASTER_CLIENT_SERVICE_VERSION - Static variable in class alluxio.Constants
 
LINEAGE_MASTER_NAME - Static variable in class alluxio.Constants
 
LineageContext - Enum in alluxio.client.lineage
A shared context in each client JVM for common lineage master client functionality such as a pool of lineage master clients.
LineageDeletionException - Exception in alluxio.exception
The exception thrown when a lineage deletion fails in Alluxio.
LineageDeletionException(String) - Constructor for exception alluxio.exception.LineageDeletionException
Constructs a new exception with the specified detail message.
LineageDeletionException(String, Throwable) - Constructor for exception alluxio.exception.LineageDeletionException
Constructs a new exception with the specified detail message and cause.
LineageDeletionException(ExceptionMessage, Object...) - Constructor for exception alluxio.exception.LineageDeletionException
Constructs a new exception with the specified exception message and multiple parameters.
LineageDeletionException(ExceptionMessage, Throwable, Object...) - Constructor for exception alluxio.exception.LineageDeletionException
Constructs a new exception with the specified exception message, the cause and multiple parameters.
LineageDoesNotExistException - Exception in alluxio.exception
The exception thrown when a lineage does not exist in Alluxio.
LineageDoesNotExistException(String) - Constructor for exception alluxio.exception.LineageDoesNotExistException
Constructs a new exception with the specified detail message.
LineageDoesNotExistException(String, Throwable) - Constructor for exception alluxio.exception.LineageDoesNotExistException
Constructs a new exception with the specified detail message and cause.
LineageDoesNotExistException(ExceptionMessage, Object...) - Constructor for exception alluxio.exception.LineageDoesNotExistException
Constructs a new exception with the specified exception message and multiple parameters.
LineageDoesNotExistException(ExceptionMessage, Throwable, Object...) - Constructor for exception alluxio.exception.LineageDoesNotExistException
Constructs a new exception with the specified exception message, the cause and multiple parameters.
LineageFileOutStream - Class in alluxio.client.lineage
A stream API to write a file when lineage is enabled.
LineageFileOutStream(FileSystemContext, AlluxioURI, OutStreamOptions) - Constructor for class alluxio.client.lineage.LineageFileOutStream
Creates a new file output stream when lineage is enabled.
LineageFileSystem - Class in alluxio.client.lineage
Alluxio lineage file system client.
LineageIdGenerator - Class in alluxio.master.lineage.meta
Generates the lineage id as sequence number.
LineageIdGenerator() - Constructor for class alluxio.master.lineage.meta.LineageIdGenerator
Creates a new instance of LineageIdGenerator.
LineageInfo - Class in alluxio.thrift
 
LineageInfo() - Constructor for class alluxio.thrift.LineageInfo
 
LineageInfo(long, List<String>, List<String>, CommandLineJobInfo, long, List<Long>, List<Long>) - Constructor for class alluxio.thrift.LineageInfo
 
LineageInfo(LineageInfo) - Constructor for class alluxio.thrift.LineageInfo
Performs a deep copy on other.
LineageInfo - Class in alluxio.wire
The lineage information.
LineageInfo() - Constructor for class alluxio.wire.LineageInfo
Creates a new instance of LineageInfo.
LineageInfo._Fields - Enum in alluxio.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
LineageMaster - Interface in alluxio.master.lineage
The lineage master interface stores the lineage metadata in Alluxio, this interface contains common components that manage all lineage-related activities.
LineageMasterClient - Class in alluxio.client.lineage
A wrapper for the thrift client to interact with the lineage master, used by alluxio clients.
LineageMasterClient(MasterClientConfig) - Constructor for class alluxio.client.lineage.LineageMasterClient
Creates a new lineage master client.
LineageMasterClientRestServiceHandler - Class in alluxio.master.lineage
Deprecated.
since version 1.4 and will be removed in version 2.0
LineageMasterClientRestServiceHandler(ServletContext) - Constructor for class alluxio.master.lineage.LineageMasterClientRestServiceHandler
Deprecated.
LineageMasterClientService - Class in alluxio.thrift
 
LineageMasterClientService() - Constructor for class alluxio.thrift.LineageMasterClientService
 
LineageMasterClientService.AsyncClient - Class in alluxio.thrift
 
LineageMasterClientService.AsyncClient.createLineage_call - Class in alluxio.thrift
 
LineageMasterClientService.AsyncClient.deleteLineage_call - Class in alluxio.thrift
 
LineageMasterClientService.AsyncClient.Factory - Class in alluxio.thrift
 
LineageMasterClientService.AsyncClient.getLineageInfoList_call - Class in alluxio.thrift
 
LineageMasterClientService.AsyncClient.reinitializeFile_call - Class in alluxio.thrift
 
LineageMasterClientService.AsyncClient.reportLostFile_call - Class in alluxio.thrift
 
LineageMasterClientService.AsyncIface - Interface in alluxio.thrift
 
LineageMasterClientService.AsyncProcessor<I extends LineageMasterClientService.AsyncIface> - Class in alluxio.thrift
 
LineageMasterClientService.AsyncProcessor.createLineage<I extends LineageMasterClientService.AsyncIface> - Class in alluxio.thrift
 
LineageMasterClientService.AsyncProcessor.deleteLineage<I extends LineageMasterClientService.AsyncIface> - Class in alluxio.thrift
 
LineageMasterClientService.AsyncProcessor.getLineageInfoList<I extends LineageMasterClientService.AsyncIface> - Class in alluxio.thrift
 
LineageMasterClientService.AsyncProcessor.reinitializeFile<I extends LineageMasterClientService.AsyncIface> - Class in alluxio.thrift
 
LineageMasterClientService.AsyncProcessor.reportLostFile<I extends LineageMasterClientService.AsyncIface> - Class in alluxio.thrift
 
LineageMasterClientService.Client - Class in alluxio.thrift
 
LineageMasterClientService.Client.Factory - Class in alluxio.thrift
 
LineageMasterClientService.createLineage_args - Class in alluxio.thrift
 
LineageMasterClientService.createLineage_args._Fields - Enum in alluxio.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
LineageMasterClientService.createLineage_result - Class in alluxio.thrift
 
LineageMasterClientService.createLineage_result._Fields - Enum in alluxio.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
LineageMasterClientService.deleteLineage_args - Class in alluxio.thrift
 
LineageMasterClientService.deleteLineage_args._Fields - Enum in alluxio.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
LineageMasterClientService.deleteLineage_result - Class in alluxio.thrift
 
LineageMasterClientService.deleteLineage_result._Fields - Enum in alluxio.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
LineageMasterClientService.getLineageInfoList_args - Class in alluxio.thrift
 
LineageMasterClientService.getLineageInfoList_args._Fields - Enum in alluxio.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
LineageMasterClientService.getLineageInfoList_result - Class in alluxio.thrift
 
LineageMasterClientService.getLineageInfoList_result._Fields - Enum in alluxio.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
LineageMasterClientService.Iface - Interface in alluxio.thrift
This interface contains lineage master service endpoints for Alluxio clients.
LineageMasterClientService.Processor<I extends LineageMasterClientService.Iface> - Class in alluxio.thrift
 
LineageMasterClientService.Processor.createLineage<I extends LineageMasterClientService.Iface> - Class in alluxio.thrift
 
LineageMasterClientService.Processor.deleteLineage<I extends LineageMasterClientService.Iface> - Class in alluxio.thrift
 
LineageMasterClientService.Processor.getLineageInfoList<I extends LineageMasterClientService.Iface> - Class in alluxio.thrift
 
LineageMasterClientService.Processor.reinitializeFile<I extends LineageMasterClientService.Iface> - Class in alluxio.thrift
 
LineageMasterClientService.Processor.reportLostFile<I extends LineageMasterClientService.Iface> - Class in alluxio.thrift
 
LineageMasterClientService.reinitializeFile_args - Class in alluxio.thrift
 
LineageMasterClientService.reinitializeFile_args._Fields - Enum in alluxio.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
LineageMasterClientService.reinitializeFile_result - Class in alluxio.thrift
 
LineageMasterClientService.reinitializeFile_result._Fields - Enum in alluxio.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
LineageMasterClientService.reportLostFile_args - Class in alluxio.thrift
 
LineageMasterClientService.reportLostFile_args._Fields - Enum in alluxio.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
LineageMasterClientService.reportLostFile_result - Class in alluxio.thrift
 
LineageMasterClientService.reportLostFile_result._Fields - Enum in alluxio.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
LineageMasterClientServiceHandler - Class in alluxio.master.lineage
This class is a Thrift handler for lineage master RPCs invoked by an Alluxio client.
LineageMasterFactory - Class in alluxio.master.lineage
Factory to create a LineageMaster instance.
LineageMasterFactory() - Constructor for class alluxio.master.lineage.LineageMasterFactory
Constructs a new LineageMasterFactory.
LineageStateUtils - Class in alluxio.master.lineage.meta
Utility methods for checking the state of lineage files.
LineageStore - Class in alluxio.master.lineage.meta
A store of lineages.
LineageStore(LineageIdGenerator) - Constructor for class alluxio.master.lineage.meta.LineageStore
Constructs the lineage store.
LineageStoreView - Class in alluxio.master.lineage.meta
This class exposes a read-only view of LineageStore to checkpoint schedulers and recompute planners.
LineageStoreView(LineageStore) - Constructor for class alluxio.master.lineage.meta.LineageStoreView
Creates a new instance of LineageStoreView.
LinearProbingIndex - Class in alluxio.client.keyvalue
Index structure using linear probing.
LIST_STATUS - Static variable in class alluxio.master.file.FileSystemMasterClientRestServiceHandler
Deprecated.
 
LIST_STATUS - Static variable in class alluxio.proxy.PathsRestServiceHandler
 
ListBucketOptions - Class in alluxio.proxy.s3
The options for list bucket operation.
ListBucketResult - Class in alluxio.proxy.s3
Get bucket result defined in http://docs.aws.amazon.com/AmazonS3/latest/API/v2-RESTBucketGET.html It will be encoded into an XML string to be returned as a response for the REST call.
ListBucketResult() - Constructor for class alluxio.proxy.s3.ListBucketResult
Creates an ListBucketResult.
ListBucketResult(String, List<URIStatus>, ListBucketOptions) - Constructor for class alluxio.proxy.s3.ListBucketResult
Creates an ListBucketResult.
ListBucketResult.Content - Class in alluxio.proxy.s3
Object metadata class.
listExtensions() - Static method in class alluxio.util.ExtensionUtils
List extension jars from the configured extensions directory.
listInternal(String, ListOptions) - Method in class alluxio.underfs.ObjectUnderFileSystem
Lists the files in the given path, the paths will be their logical names and not contain the folder suffix.
ListLineagesCommand - Class in alluxio.cli.fs.command
Lists all the lineages.
ListLineagesCommand(FileSystem) - Constructor for class alluxio.cli.fs.command.ListLineagesCommand
Constructs a new instance to list all the lineages.
ListOptions - Class in alluxio.underfs.options
Method options for listing a directory in UnderFileSystem.
ListPartsResult - Class in alluxio.proxy.s3
Result returned after requests for listing parts of a multipart upload.
ListPartsResult() - Constructor for class alluxio.proxy.s3.ListPartsResult
Constructs a default ListPartsResult.
ListPartsResult.Part - Class in alluxio.proxy.s3
Part contains metadata of a part of the object in multipart upload.
listStatus(AlluxioURI) - Method in class alluxio.client.file.BaseFileSystem
 
listStatus(AlluxioURI, ListStatusOptions) - Method in class alluxio.client.file.BaseFileSystem
 
listStatus(AlluxioURI) - Method in interface alluxio.client.file.FileSystem
Convenience method for FileSystem.listStatus(AlluxioURI, ListStatusOptions) with default options.
listStatus(AlluxioURI, ListStatusOptions) - Method in interface alluxio.client.file.FileSystem
If the path is a directory, returns the URIStatus of all the direct entries in it.
listStatus(AlluxioURI, ListStatusOptions) - Method in interface alluxio.client.file.FileSystemMasterClient
 
listStatus(AlluxioURI, ListStatusOptions) - Method in class alluxio.client.file.RetryHandlingFileSystemMasterClient
 
listStatus(AlluxioURI, ListStatusOptions) - Method in class alluxio.master.file.DefaultFileSystemMaster
 
listStatus(AlluxioURI, ListStatusOptions) - Method in interface alluxio.master.file.FileSystemMaster
Returns a list of FileInfo for a given path.
listStatus(String, boolean, String) - Method in class alluxio.master.file.FileSystemMasterClientRestServiceHandler
Deprecated.
 
listStatus(String, ListStatusTOptions) - Method in class alluxio.master.file.FileSystemMasterClientServiceHandler
 
listStatus(String, ListStatusOptions) - Method in class alluxio.proxy.PathsRestServiceHandler
 
listStatus(String, ListStatusTOptions, AsyncMethodCallback) - Method in class alluxio.thrift.FileSystemMasterClientService.AsyncClient
 
listStatus(String, ListStatusTOptions, AsyncMethodCallback) - Method in interface alluxio.thrift.FileSystemMasterClientService.AsyncIface
 
listStatus() - Constructor for class alluxio.thrift.FileSystemMasterClientService.AsyncProcessor.listStatus
 
listStatus(String, ListStatusTOptions) - Method in class alluxio.thrift.FileSystemMasterClientService.Client
 
listStatus(String, ListStatusTOptions) - Method in interface alluxio.thrift.FileSystemMasterClientService.Iface
If the path points to a file, the method returns a singleton with its file information.
listStatus() - Constructor for class alluxio.thrift.FileSystemMasterClientService.Processor.listStatus
 
listStatus(String, ListOptions) - Method in class alluxio.underfs.BaseUnderFileSystem
 
listStatus(String) - Method in class alluxio.underfs.hdfs.HdfsUnderFileSystem
 
listStatus(String) - Method in class alluxio.underfs.local.LocalUnderFileSystem
 
listStatus(String) - Method in class alluxio.underfs.ObjectUnderFileSystem
 
listStatus(String, ListOptions) - Method in class alluxio.underfs.ObjectUnderFileSystem
 
listStatus(String) - Method in interface alluxio.underfs.UnderFileSystem
Returns an array of statuses of the files and directories in the directory denoted by this abstract pathname.
listStatus(String, ListOptions) - Method in interface alluxio.underfs.UnderFileSystem
Returns an array of statuses of the files and directories in the directory denoted by this abstract pathname, with options.
listStatus(String) - Method in class alluxio.underfs.UnderFileSystemWithLogging
 
listStatus(String, ListOptions) - Method in class alluxio.underfs.UnderFileSystemWithLogging
 
listStatus_args() - Constructor for class alluxio.thrift.FileSystemMasterClientService.listStatus_args
 
listStatus_args(String, ListStatusTOptions) - Constructor for class alluxio.thrift.FileSystemMasterClientService.listStatus_args
 
listStatus_args(FileSystemMasterClientService.listStatus_args) - Constructor for class alluxio.thrift.FileSystemMasterClientService.listStatus_args
Performs a deep copy on other.
listStatus_call(String, ListStatusTOptions, AsyncMethodCallback, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class alluxio.thrift.FileSystemMasterClientService.AsyncClient.listStatus_call
 
listStatus_result() - Constructor for class alluxio.thrift.FileSystemMasterClientService.listStatus_result
 
listStatus_result(ListStatusTResponse, AlluxioTException) - Constructor for class alluxio.thrift.FileSystemMasterClientService.listStatus_result
 
listStatus_result(FileSystemMasterClientService.listStatus_result) - Constructor for class alluxio.thrift.FileSystemMasterClientService.listStatus_result
Performs a deep copy on other.
ListStatusOptions - Class in alluxio.client.file.options
Method options for listing the status.
ListStatusOptions - Class in alluxio.master.file.options
Method options for list status.
ListStatusOptions(ListStatusTOptions) - Constructor for class alluxio.master.file.options.ListStatusOptions
Create an instance of ListStatusOptions from a ListStatusTOptions.
ListStatusTOptions - Class in alluxio.thrift
 
ListStatusTOptions() - Constructor for class alluxio.thrift.ListStatusTOptions
 
ListStatusTOptions(ListStatusTOptions) - Constructor for class alluxio.thrift.ListStatusTOptions
Performs a deep copy on other.
ListStatusTOptions._Fields - Enum in alluxio.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
ListStatusTResponse - Class in alluxio.thrift
 
ListStatusTResponse() - Constructor for class alluxio.thrift.ListStatusTResponse
 
ListStatusTResponse(List<FileInfo>) - Constructor for class alluxio.thrift.ListStatusTResponse
 
ListStatusTResponse(ListStatusTResponse) - Constructor for class alluxio.thrift.ListStatusTResponse
Performs a deep copy on other.
ListStatusTResponse._Fields - Enum in alluxio.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
listToString(List<T>) - Static method in class alluxio.util.CommonUtils
Converts a list of objects to a string.
LIVE_OPTION_NAME - Static variable in class alluxio.cli.fsadmin.command.ReportCommand
 
loadClass(String, boolean) - Method in class alluxio.extensions.ExtensionsClassLoader
 
LoadCommand - Class in alluxio.cli.fs.command
Loads a file or directory in Alluxio space, making it resident in Alluxio.
LoadCommand(FileSystem) - Constructor for class alluxio.cli.fs.command.LoadCommand
Constructs a new instance to load a file or directory in Alluxio space.
loadCommands() - Method in class alluxio.cli.AbstractShell
Map structure: Command name => Command instance.
loadCommands(String, Class[], Object[]) - Static method in class alluxio.cli.CommandUtils
Get instances of all subclasses of Command in a sub-package called "command" the given package.
loadCommands() - Method in class alluxio.cli.extensions.ExtensionsShell
 
loadCommands() - Static method in class alluxio.cli.extensions.ExtensionsShellUtils
Gets all Command instances in the same package as ExtensionsShell and loads them into a map.
loadCommands() - Method in class alluxio.cli.fs.FileSystemShell
 
loadCommands(FileSystem) - Static method in class alluxio.cli.fs.FileSystemShellUtils
Gets all Command instances in the same package as FileSystemShell and load them into a map.
loadCommands() - Method in class alluxio.cli.fsadmin.FileSystemAdminShell
 
loadFromByteArray(ByteBuffer) - Static method in class alluxio.client.keyvalue.LinearProbingIndex
Creates an instance of linear probing index by loading its content from a buffer.
loadMetadata(AlluxioURI) - Method in class alluxio.client.file.BaseFileSystem
Deprecated.
since version 1.1 and will be removed in version 2.0
loadMetadata(AlluxioURI, LoadMetadataOptions) - Method in class alluxio.client.file.BaseFileSystem
Deprecated.
since version 1.1 and will be removed in version 2.0
loadMetadata(AlluxioURI) - Method in interface alluxio.client.file.FileSystem
Deprecated.
since version 1.1 and will be removed in version 2.0
loadMetadata(AlluxioURI, LoadMetadataOptions) - Method in interface alluxio.client.file.FileSystem
Deprecated.
since version 1.1 and will be removed in version 2.0
loadMetadata(AlluxioURI, LoadMetadataOptions) - Method in interface alluxio.client.file.FileSystemMasterClient
Deprecated.
since version 1.1 and will be removed in version 2.0
loadMetadata(AlluxioURI, LoadMetadataOptions) - Method in class alluxio.client.file.RetryHandlingFileSystemMasterClient
 
loadMetadata(AlluxioURI, LoadMetadataOptions) - Method in class alluxio.master.file.DefaultFileSystemMaster
 
loadMetadata(AlluxioURI, LoadMetadataOptions) - Method in interface alluxio.master.file.FileSystemMaster
Loads metadata for the object identified by the given path from UFS into Alluxio.
loadMetadata(String, boolean, LoadMetadataTOptions) - Method in class alluxio.master.file.FileSystemMasterClientServiceHandler
Deprecated.
since version 1.1 and will be removed in version 2.0
loadMetadata(String, boolean, LoadMetadataTOptions, AsyncMethodCallback) - Method in class alluxio.thrift.FileSystemMasterClientService.AsyncClient
 
loadMetadata(String, boolean, LoadMetadataTOptions, AsyncMethodCallback) - Method in interface alluxio.thrift.FileSystemMasterClientService.AsyncIface
 
loadMetadata() - Constructor for class alluxio.thrift.FileSystemMasterClientService.AsyncProcessor.loadMetadata
 
loadMetadata(String, boolean, LoadMetadataTOptions) - Method in class alluxio.thrift.FileSystemMasterClientService.Client
 
loadMetadata(String, boolean, LoadMetadataTOptions) - Method in interface alluxio.thrift.FileSystemMasterClientService.Iface
Loads metadata for the object identified by the given Alluxio path from UFS into Alluxio.
loadMetadata() - Constructor for class alluxio.thrift.FileSystemMasterClientService.Processor.loadMetadata
 
loadMetadata_args() - Constructor for class alluxio.thrift.FileSystemMasterClientService.loadMetadata_args
 
loadMetadata_args(String, boolean, LoadMetadataTOptions) - Constructor for class alluxio.thrift.FileSystemMasterClientService.loadMetadata_args
 
loadMetadata_args(FileSystemMasterClientService.loadMetadata_args) - Constructor for class alluxio.thrift.FileSystemMasterClientService.loadMetadata_args
Performs a deep copy on other.
loadMetadata_call(String, boolean, LoadMetadataTOptions, AsyncMethodCallback, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class alluxio.thrift.FileSystemMasterClientService.AsyncClient.loadMetadata_call
 
loadMetadata_result() - Constructor for class alluxio.thrift.FileSystemMasterClientService.loadMetadata_result
 
loadMetadata_result(LoadMetadataTResponse, AlluxioTException) - Constructor for class alluxio.thrift.FileSystemMasterClientService.loadMetadata_result
 
loadMetadata_result(FileSystemMasterClientService.loadMetadata_result) - Constructor for class alluxio.thrift.FileSystemMasterClientService.loadMetadata_result
Performs a deep copy on other.
LoadMetadataCommand - Class in alluxio.cli.fs.command
Deprecated.
since version 1.1
LoadMetadataCommand(FileSystem) - Constructor for class alluxio.cli.fs.command.LoadMetadataCommand
Deprecated.
Constructs a new instance to load metadata for the given Alluxio path from UFS.
LoadMetadataOptions - Class in alluxio.client.file.options
Deprecated.
since version 1.1 and will be removed in version 2.0
LoadMetadataOptions - Class in alluxio.master.file.options
Method options for loading metadata.
LoadMetadataOptions(LoadMetadataTOptions) - Constructor for class alluxio.master.file.options.LoadMetadataOptions
 
LoadMetadataTOptions - Class in alluxio.thrift
 
LoadMetadataTOptions() - Constructor for class alluxio.thrift.LoadMetadataTOptions
 
LoadMetadataTOptions(LoadMetadataTOptions) - Constructor for class alluxio.thrift.LoadMetadataTOptions
Performs a deep copy on other.
LoadMetadataTOptions._Fields - Enum in alluxio.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
LoadMetadataTResponse - Class in alluxio.thrift
 
LoadMetadataTResponse() - Constructor for class alluxio.thrift.LoadMetadataTResponse
 
LoadMetadataTResponse(long) - Constructor for class alluxio.thrift.LoadMetadataTResponse
 
LoadMetadataTResponse(LoadMetadataTResponse) - Constructor for class alluxio.thrift.LoadMetadataTResponse
Performs a deep copy on other.
LoadMetadataTResponse._Fields - Enum in alluxio.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
LoadMetadataTType - Enum in alluxio.thrift
 
LoadMetadataType - Enum in alluxio.wire
Types for loading metadata.
loadProperties(InputStream) - Static method in class alluxio.util.ConfigurationUtils
 
loadPropertiesFromFile(String) - Static method in class alluxio.util.ConfigurationUtils
Loads properties from the given file.
loadPropertiesFromResource(URL) - Static method in class alluxio.util.ConfigurationUtils
Loads properties from a resource.
LocalAlluxioCluster - Class in alluxio.master
Local Alluxio cluster for integration tests.
LocalAlluxioCluster() - Constructor for class alluxio.master.LocalAlluxioCluster
Runs a test Alluxio cluster with a single Alluxio worker.
LocalAlluxioCluster(int) - Constructor for class alluxio.master.LocalAlluxioCluster
 
LocalAlluxioMaster - Class in alluxio.master
Constructs an isolated master.
LocalFileBlockReader - Class in alluxio.worker.block.io
This class provides read access to a block data file locally stored in managed storage.
LocalFileBlockReader(String) - Constructor for class alluxio.worker.block.io.LocalFileBlockReader
Constructs a Block reader given the file path of the block.
LocalFileBlockWriter - Class in alluxio.worker.block.io
This class provides write access to a temp block data file locally stored in managed storage.
LocalFileBlockWriter(String) - Constructor for class alluxio.worker.block.io.LocalFileBlockWriter
Constructs a Block writer given the file path of the block.
LocalFilePacketReader - Class in alluxio.client.block.stream
A packet reader that simply reads packets from a local file.
LocalFilePacketReader.Factory - Class in alluxio.client.block.stream
Factory class to create LocalFilePacketReaders.
LocalFilePacketWriter - Class in alluxio.client.block.stream
A local packet writer that simply writes packets to a local file.
LocalFirstAvoidEvictionPolicy - Class in alluxio.client.file.policy
A policy that returns local host first, and if the local worker doesn't have enough availability, it randomly picks a worker from the active workers list for each block write.
LocalFirstAvoidEvictionPolicy() - Constructor for class alluxio.client.file.policy.LocalFirstAvoidEvictionPolicy
LocalFirstPolicy - Class in alluxio.client.file.policy
A policy that returns local host first, and if the local worker doesn't have enough availability, it randomly picks a worker from the active workers list for each block write.
LocalFirstPolicy() - Constructor for class alluxio.client.file.policy.LocalFirstPolicy
Constructs a LocalFirstPolicy.
localIdentity() - Static method in class alluxio.network.TieredIdentityFactory
 
LOCALITY_COMPARE_NODE_IP - Static variable in class alluxio.PropertyKey
 
LOCALITY_COMPARE_NODE_IP - Static variable in class alluxio.PropertyKey.Name
 
LOCALITY_NODE - Static variable in class alluxio.Constants
 
LOCALITY_ORDER - Static variable in class alluxio.PropertyKey
 
LOCALITY_ORDER - Static variable in class alluxio.PropertyKey.Name
 
LOCALITY_RACK - Static variable in class alluxio.Constants
 
LOCALITY_SCRIPT - Static variable in class alluxio.PropertyKey
 
LOCALITY_SCRIPT - Static variable in class alluxio.PropertyKey.Name
 
LOCALITY_TIER_NODE - Static variable in class alluxio.PropertyKey
 
LOCALITY_TIER_RACK - Static variable in class alluxio.PropertyKey
 
LocalityTier - Class in alluxio.thrift
 
LocalityTier() - Constructor for class alluxio.thrift.LocalityTier
 
LocalityTier(String, String) - Constructor for class alluxio.thrift.LocalityTier
 
LocalityTier(LocalityTier) - Constructor for class alluxio.thrift.LocalityTier
Performs a deep copy on other.
LocalityTier(String, String) - Constructor for class alluxio.wire.TieredIdentity.LocalityTier
 
LocalityTier._Fields - Enum in alluxio.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
LocalUnderFileSystem - Class in alluxio.underfs.local
Local FS UnderFileSystem implementation.
LocalUnderFileSystem(AlluxioURI, UnderFileSystemConfiguration) - Constructor for class alluxio.underfs.local.LocalUnderFileSystem
Constructs a new LocalUnderFileSystem.
LocalUnderFileSystemFactory - Class in alluxio.underfs.local
Factory for creating LocalUnderFileSystem.
LocalUnderFileSystemFactory() - Constructor for class alluxio.underfs.local.LocalUnderFileSystemFactory
Constructs a new LocalUnderFileSystemFactory.
LocationCommand - Class in alluxio.cli.fs.command
Displays a list of hosts that have the file specified in args stored.
LocationCommand(FileSystem) - Constructor for class alluxio.cli.fs.command.LocationCommand
Constructs a new instance to display a list of hosts that have the file specified in args stored.
lockBlock(long, long, LockBlockTOptions, AsyncMethodCallback) - Method in class alluxio.thrift.BlockWorkerClientService.AsyncClient
 
lockBlock(long, long, LockBlockTOptions, AsyncMethodCallback) - Method in interface alluxio.thrift.BlockWorkerClientService.AsyncIface
 
lockBlock() - Constructor for class alluxio.thrift.BlockWorkerClientService.AsyncProcessor.lockBlock
 
lockBlock(long, long, LockBlockTOptions) - Method in class alluxio.thrift.BlockWorkerClientService.Client
 
lockBlock(long, long, LockBlockTOptions) - Method in interface alluxio.thrift.BlockWorkerClientService.Iface
Locks the file in Alluxio's space while the session is reading it.
lockBlock() - Constructor for class alluxio.thrift.BlockWorkerClientService.Processor.lockBlock
 
lockBlock(long, long, BlockLockType) - Method in class alluxio.worker.block.BlockLockManager
Locks a block.
lockBlock(long, long) - Method in interface alluxio.worker.block.BlockStore
Locks an existing block and guards subsequent reads on this block.
lockBlock(long, long) - Method in interface alluxio.worker.block.BlockWorker
Obtains a read lock the block.
lockBlock(long, long, LockBlockTOptions) - Method in class alluxio.worker.block.BlockWorkerClientServiceHandler
 
lockBlock(long, long) - Method in class alluxio.worker.block.DefaultBlockWorker
 
lockBlock(long, long) - Method in class alluxio.worker.block.TieredBlockStore
 
lockBlock_args() - Constructor for class alluxio.thrift.BlockWorkerClientService.lockBlock_args
 
lockBlock_args(long, long, LockBlockTOptions) - Constructor for class alluxio.thrift.BlockWorkerClientService.lockBlock_args
 
lockBlock_args(BlockWorkerClientService.lockBlock_args) - Constructor for class alluxio.thrift.BlockWorkerClientService.lockBlock_args
Performs a deep copy on other.
lockBlock_call(long, long, LockBlockTOptions, AsyncMethodCallback, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class alluxio.thrift.BlockWorkerClientService.AsyncClient.lockBlock_call
 
lockBlock_result() - Constructor for class alluxio.thrift.BlockWorkerClientService.lockBlock_result
 
lockBlock_result(LockBlockTResponse, AlluxioTException) - Constructor for class alluxio.thrift.BlockWorkerClientService.lockBlock_result
 
lockBlock_result(BlockWorkerClientService.lockBlock_result) - Constructor for class alluxio.thrift.BlockWorkerClientService.lockBlock_result
Performs a deep copy on other.
lockBlockNoException(long, long) - Method in interface alluxio.worker.block.BlockStore
Locks an existing block and guards subsequent reads on this block.
lockBlockNoException(long, long) - Method in interface alluxio.worker.block.BlockWorker
Obtains a read lock the block without throwing an exception.
lockBlockNoException(long, long) - Method in class alluxio.worker.block.DefaultBlockWorker
 
lockBlockNoException(long, long) - Method in class alluxio.worker.block.TieredBlockStore
 
LockBlockOptions - Class in alluxio.client.block.options
Method options for locking blocks.
lockBlocks(long, List<Long>) - Method in class alluxio.worker.file.FileDataManager
Locks all the blocks of a given file Id.
LockBlockStatus - Enum in alluxio.thrift
 
LockBlockTOptions - Class in alluxio.thrift
 
LockBlockTOptions() - Constructor for class alluxio.thrift.LockBlockTOptions
 
LockBlockTOptions(String, long, long, int, long) - Constructor for class alluxio.thrift.LockBlockTOptions
 
LockBlockTOptions(LockBlockTOptions) - Constructor for class alluxio.thrift.LockBlockTOptions
Performs a deep copy on other.
LockBlockTOptions._Fields - Enum in alluxio.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
LockBlockTResponse - Class in alluxio.thrift
 
LockBlockTResponse() - Constructor for class alluxio.thrift.LockBlockTResponse
 
LockBlockTResponse(long, String, LockBlockStatus) - Constructor for class alluxio.thrift.LockBlockTResponse
 
LockBlockTResponse(LockBlockTResponse) - Constructor for class alluxio.thrift.LockBlockTResponse
Performs a deep copy on other.
LockBlockTResponse._Fields - Enum in alluxio.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
lockChildPath(LockedInodePath, InodeTree.LockMode, Inode<?>, String[]) - Method in class alluxio.master.file.meta.InodeTree
Lock from a specific poiint in the tree to the immediate child, and return a lockedInodePath.
lockDescendantPath(LockedInodePath, InodeTree.LockMode, AlluxioURI) - Method in class alluxio.master.file.meta.InodeTree
Locks from a specific point in the tree to the descendant, and return a lockedInodePath.
lockDescendants(LockedInodePath, InodeTree.LockMode) - Method in class alluxio.master.file.meta.InodeTree
Locks all descendants of a particular LockedInodePath.
LockedInodePath - Class in alluxio.master.file.meta
This class represents a path of locked Inode, starting from the root.
LockedInodePathList - Class in alluxio.master.file.meta
This class represents a list of locked inodePaths.
LockedInodePathList(List<LockedInodePath>) - Constructor for class alluxio.master.file.meta.LockedInodePathList
Creates a new instance of LockedInodePathList.
lockFullInodePath(AlluxioURI, InodeTree.LockMode) - Method in class alluxio.master.file.meta.InodeTree
Locks existing inodes on the specified path, in the specified InodeTree.LockMode.
lockFullInodePath(long, InodeTree.LockMode) - Method in class alluxio.master.file.meta.InodeTree
Locks existing inodes on the path to the inode specified by an id, in the specified InodeTree.LockMode.
LockingScheme - Class in alluxio.master.file.meta
This class represents information about how a path should be locked.
LockingScheme(AlluxioURI, InodeTree.LockMode, boolean) - Constructor for class alluxio.master.file.meta.LockingScheme
Constructs a LockingScheme.
lockInodePath(AlluxioURI, InodeTree.LockMode) - Method in class alluxio.master.file.meta.InodeTree
Locks existing inodes on the specified path, in the specified InodeTree.LockMode.
lockInodePathPair(AlluxioURI, InodeTree.LockMode, AlluxioURI, InodeTree.LockMode) - Method in class alluxio.master.file.meta.InodeTree
Locks existing inodes on the two specified paths.
lockRead() - Method in class alluxio.master.file.meta.Inode
Obtains a read lock on the inode.
lockRead(Inode<?>) - Method in class alluxio.master.file.meta.InodeLockList
Locks the given inode in read mode, and adds it to this lock list.
lockReadAndCheckNameAndParent(Inode, String) - Method in class alluxio.master.file.meta.Inode
Obtains a read lock on the inode.
lockReadAndCheckNameAndParent(Inode<?>, Inode, String) - Method in class alluxio.master.file.meta.InodeLockList
Locks the given inode in read mode, and adds it to this lock list.
lockReadAndCheckParent(Inode) - Method in class alluxio.master.file.meta.Inode
Obtains a read lock on the inode.
lockReadAndCheckParent(Inode<?>, Inode) - Method in class alluxio.master.file.meta.InodeLockList
Locks the given inode in read mode, and adds it to this lock list.
LockResource - Class in alluxio.resource
A resource lock that makes it possible to acquire and release locks using the following idiom:
LockResource(Lock) - Constructor for class alluxio.resource.LockResource
Creates a new instance of LockResource using the given lock.
lockWrite() - Method in class alluxio.master.file.meta.Inode
Obtains a write lock on the inode.
lockWrite(Inode<?>) - Method in class alluxio.master.file.meta.InodeLockList
Locks the given inode in write mode, and adds it to this lock list.
lockWriteAndCheckNameAndParent(Inode, String) - Method in class alluxio.master.file.meta.Inode
Obtains a write lock on the inode.
lockWriteAndCheckNameAndParent(Inode<?>, Inode, String) - Method in class alluxio.master.file.meta.InodeLockList
Locks the given inode in write mode, and adds it to this lock list.
lockWriteAndCheckParent(Inode) - Method in class alluxio.master.file.meta.Inode
Obtains a write lock on the inode.
lockWriteAndCheckParent(Inode<?>, Inode) - Method in class alluxio.master.file.meta.InodeLockList
Locks the given inode in write mode, and adds it to this lock list.
LOG - Static variable in class alluxio.client.block.stream.PacketWriter.Factory
 
LOG - Static variable in class alluxio.master.file.async.AsyncPersistHandler.Factory
 
LOG_ARGUMENT_LEVEL - Static variable in class alluxio.master.meta.AlluxioMasterRestServiceHandler
 
LOG_ARGUMENT_LEVEL - Static variable in class alluxio.worker.AlluxioWorkerRestServiceHandler
 
LOG_ARGUMENT_NAME - Static variable in class alluxio.master.meta.AlluxioMasterRestServiceHandler
 
LOG_ARGUMENT_NAME - Static variable in class alluxio.worker.AlluxioWorkerRestServiceHandler
 
LOG_LEVEL - Static variable in class alluxio.master.meta.AlluxioMasterRestServiceHandler
 
LOG_LEVEL - Static variable in class alluxio.worker.AlluxioWorkerRestServiceHandler
 
logAllThreads() - Static method in class alluxio.util.ThreadUtils
Logs a stack trace for all threads currently running in the JVM, similar to jstack.
logConfigReport() - Method in class alluxio.master.meta.checkconf.ServerConfigurationChecker
Logs the configuration check report information.
LOGGER_TYPE - Static variable in class alluxio.PropertyKey
 
LOGGER_TYPE - Static variable in class alluxio.PropertyKey.Name
 
login() - Method in class alluxio.security.login.AlluxioLoginModule
Authenticates the user (first phase).
login() - Method in class alluxio.security.login.AppLoginModule
Retrieves the user name by querying the property of PropertyKey.SECURITY_LOGIN_USERNAME through AppLoginModule.AppCallbackHandler.
LogInfo - Class in alluxio.wire
Information about the LogInfo.
LogInfo() - Constructor for class alluxio.wire.LogInfo
Creates a new instance of LogInfo.
LoginModuleConfiguration - Class in alluxio.security.login
A JAAS configuration that defines the login modules, by which JAAS uses to login.
LoginModuleConfiguration() - Constructor for class alluxio.security.login.LoginModuleConfiguration
Constructs a new LoginModuleConfiguration.
LoginModuleConfigurationUtils - Class in alluxio.security.login
This class provides constants used in JAAS login.
LoginUser - Class in alluxio.security
A Singleton of LoginUser, which is an instance of User.
LogLevel - Class in alluxio.cli
Sets or gets the log level for the specified server.
logLevel(String[]) - Static method in class alluxio.cli.LogLevel
Implements log level setting and getting.
logLevel(String, String) - Method in class alluxio.master.meta.AlluxioMasterRestServiceHandler
 
logLevel(String, String) - Method in class alluxio.worker.AlluxioWorkerRestServiceHandler
 
logout() - Method in class alluxio.security.login.AlluxioLoginModule
Logs out the user.
logout() - Method in class alluxio.security.login.AppLoginModule
Logs out the user
logPerIteration(long, int, String, int) - Static method in class alluxio.examples.Performance
Writes log information.
LOGS_DIR - Static variable in class alluxio.PropertyKey
 
LOGS_DIR - Static variable in class alluxio.PropertyKey.Name
 
LOGSERVER_CLIENT_LOGGER_APPENDER_NAME - Static variable in class alluxio.logserver.AlluxioLogServerProcess
Name of the appender used by log server to perform actual logging of messages received from remote Alluxio servers.
LOGSERVER_HOSTNAME - Static variable in class alluxio.PropertyKey
 
LOGSERVER_HOSTNAME - Static variable in class alluxio.PropertyKey.Name
 
LOGSERVER_LOGS_DIR - Static variable in class alluxio.PropertyKey
 
LOGSERVER_LOGS_DIR - Static variable in class alluxio.PropertyKey.Name
 
LOGSERVER_PORT - Static variable in class alluxio.PropertyKey
 
LOGSERVER_PORT - Static variable in class alluxio.PropertyKey.Name
 
LOGSERVER_THREADS_MAX - Static variable in class alluxio.PropertyKey
 
LOGSERVER_THREADS_MAX - Static variable in class alluxio.PropertyKey.Name
 
LOGSERVER_THREADS_MIN - Static variable in class alluxio.PropertyKey
 
LOGSERVER_THREADS_MIN - Static variable in class alluxio.PropertyKey.Name
 
LogUtils - Class in alluxio.util
Utility methods for working with log.
losePrimacy() - Method in interface alluxio.master.journal.JournalSystem
Transitions the journal to secondary mode.
losePrimacy() - Method in class alluxio.master.journal.noop.NoopJournalSystem
 
losePrimacy() - Method in class alluxio.master.journal.ufs.UfsJournalSystem
 
LOST_OPTION_NAME - Static variable in class alluxio.cli.fsadmin.command.ReportCommand
 
lostNodeFound(Address) - Method in class alluxio.master.meta.checkconf.ServerConfigurationStore
Updates configuration when a lost node is found.
LRFUEvictor - Class in alluxio.worker.block.evictor
This class is used to evict blocks by LRFU.
LRFUEvictor(BlockMetadataManagerView, Allocator) - Constructor for class alluxio.worker.block.evictor.LRFUEvictor
Creates a new instance of LRFUEvictor.
LRUEvictor - Class in alluxio.worker.block.evictor
Implementation of an evictor which follows the least recently used algorithm.
LRUEvictor(BlockMetadataManagerView, Allocator) - Constructor for class alluxio.worker.block.evictor.LRUEvictor
Creates a new instance of LRUEvictor.
LS_FORMAT - Static variable in class alluxio.cli.fs.command.LsCommand
 
LS_FORMAT_ALLUXIO_STATE - Static variable in class alluxio.cli.fs.command.LsCommand
 
LS_FORMAT_FILE_PATH - Static variable in class alluxio.cli.fs.command.LsCommand
 
LS_FORMAT_FILE_SIZE - Static variable in class alluxio.cli.fs.command.LsCommand
 
LS_FORMAT_GROUP_NAME - Static variable in class alluxio.cli.fs.command.LsCommand
 
LS_FORMAT_LAST_MODIFIED_TIME - Static variable in class alluxio.cli.fs.command.LsCommand
 
LS_FORMAT_NO_ACL - Static variable in class alluxio.cli.fs.command.LsCommand
 
LS_FORMAT_PERMISSION - Static variable in class alluxio.cli.fs.command.LsCommand
 
LS_FORMAT_PERSISTENCE_STATE - Static variable in class alluxio.cli.fs.command.LsCommand
 
LS_FORMAT_USER_NAME - Static variable in class alluxio.cli.fs.command.LsCommand
 
LsCommand - Class in alluxio.cli.extensions.command
Lists all installed extensions.
LsCommand() - Constructor for class alluxio.cli.extensions.command.LsCommand
Constructs a new instance of LsCommand.
LsCommand - Class in alluxio.cli.fs.command
Displays information for the path specified in args.
LsCommand(FileSystem) - Constructor for class alluxio.cli.fs.command.LsCommand
Constructs a new instance to display information for all directories and files directly under the path specified in args.

M

mAddress - Variable in class alluxio.AbstractClient
 
main(String[]) - Static method in class alluxio.checker.HiveIntegrationChecker
Main function will be triggered by hive-checker.sh.
main(String[]) - Static method in class alluxio.checker.MapReduceIntegrationChecker
Main function will be triggered via hadoop jar.
main(String[]) - Static method in class alluxio.checker.SparkIntegrationChecker
Main function will be triggered via spark-submit.
main(String[]) - Static method in class alluxio.cli.AlluxioFrameworkIntegrationTest
 
main(String[]) - Static method in class alluxio.cli.ConfigurationDocGenerator
Main entry for this util class.
main(String[]) - Static method in class alluxio.cli.extensions.ExtensionsShell
Manage Alluxio extensions.
main(String[]) - Static method in class alluxio.cli.Format
Formats the Alluxio file system.
main(String[]) - Static method in class alluxio.cli.fs.FileSystemShell
Main method, starts a new FileSystemShell.
main(String[]) - Static method in class alluxio.cli.fsadmin.FileSystemAdminShell
Manage Alluxio file system.
main(String[]) - Static method in class alluxio.cli.GetConf
Prints Alluxio configuration.
main(String[]) - Static method in class alluxio.cli.GetConfKey
Prints Alluxio configuration key.
main(String[]) - Static method in class alluxio.cli.JournalCrashTest
Runs the crash test.
main(String[]) - Static method in class alluxio.cli.LogLevel
Sets or gets log level of master and worker through their REST API.
main(String[]) - Static method in class alluxio.cli.MiniBenchmark
 
main(String[]) - Static method in class alluxio.cli.RunOperation
Tool for running an operation multiple times.
main(String[]) - Static method in class alluxio.cli.TestRunner
Console program that validates the configuration.
main(String[]) - Static method in class alluxio.cli.ValidateConf
Console program that validates the configuration.
main(String[]) - Static method in class alluxio.cli.ValidateEnv
Validates Alluxio environment.
main(String[]) - Static method in class alluxio.cli.Version
Prints the version of the current build.
main(String[]) - Static method in class alluxio.examples.BasicCheckpoint
Example program for using checkpoints.
main(String[]) - Static method in class alluxio.examples.keyvalue.hadoop.CloneStoreMapReduce
 
main(String[]) - Static method in class alluxio.examples.keyvalue.KeyValueStoreOperations
Starts in a command like java -cp ALLUXIO_JAR CLASS_NAME <key-value store URI>.
main(String[]) - Static method in class alluxio.examples.keyvalue.KeyValueStoreQuickStart
The main program.
main(String[]) - Static method in class alluxio.examples.keyvalue.SameKeyValueStoresTest
Starts in a command like java -cp ALLUXIO_JAR CLASS_NAME <key-value store URI 1> <key-value store URI 2>.
main(String[]) - Static method in class alluxio.examples.keyvalue.ShowKeyValueStore
 
main(String[]) - Static method in class alluxio.examples.MultiMount
Entry point for the MultiMount program.
main(String[]) - Static method in class alluxio.examples.Performance
Runs the performance test.
main(String[]) - Static method in class alluxio.fuse.AlluxioFuse
Running this class will mount the file system according to the options passed to this function AlluxioFuse.parseOptions(String[]).
main(String[]) - Static method in class alluxio.logserver.AlluxioLogServer
Main entry point of AlluxioLogServer.
main(String[]) - Static method in class alluxio.master.AlluxioMaster
Starts the Alluxio master.
main(String[]) - Static method in class alluxio.master.AlluxioMasterMonitor
Starts the Alluxio master monitor.
main(String[]) - Static method in class alluxio.master.AlluxioSecondaryMaster
Starts the secondary Alluxio master.
main(String[]) - Static method in class alluxio.master.journal.JournalTool
Reads a journal via java -cp \ assembly/server/target/alluxio-assembly-server-<ALLUXIO-VERSION>-jar-with-dependencies.jar \ alluxio.master.journal.JournalTool -master BlockMaster -start 0x100 -end 0x109.
main(String[]) - Static method in class alluxio.master.journal.JournalUpgrader
Reads a journal via java -cp \ assembly/server/target/alluxio-assembly-server-<ALLUXIO-VERSION>-jar-with-dependencies.jar \ alluxio.master.journal.JournalUpgrader -master BlockMaster.
main(String[]) - Static method in class alluxio.master.journalv0.JournalTool
Reads a journal via java -cp \ assembly/server/target/alluxio-assembly-server-<ALLUXIO-VERSION>-jar-with-dependencies.jar \ alluxio.master.journal.JournalTool < journal/FileSystemMaster/log.out.
main(String[]) - Static method in class alluxio.multi.process.LimitedLifeMasterProcess
 
main(String[]) - Static method in class alluxio.multi.process.LimitedLifeWorkerProcess
 
main(String[]) - Static method in class alluxio.proxy.AlluxioProxy
Starts the Alluxio proxy.
main(String[]) - Static method in class alluxio.proxy.AlluxioProxyMonitor
Starts the Alluxio proxy monitor.
main(String[]) - Static method in class alluxio.util.HFSUtils
The main class to invoke the getNumSector.
main(String[]) - Static method in class alluxio.worker.AlluxioWorker
Starts the Alluxio worker.
main(String[]) - Static method in class alluxio.worker.AlluxioWorkerMonitor
Starts the Alluxio worker monitor.
mAllocator - Variable in class alluxio.worker.block.evictor.AbstractEvictor
 
map(Object, Object, Mapper<Object, Object, Text, Text>.Context) - Method in class alluxio.checker.MapReduceIntegrationChecker.CheckerMapper
Records the Status and IP address of each mapper task node.
map(BytesWritable, BytesWritable, Mapper<BytesWritable, BytesWritable, BytesWritable, BytesWritable>.Context) - Method in class alluxio.examples.keyvalue.hadoop.CloneStoreMapReduce.CloneStoreMapper
 
map(Function<T, R>, Collection<T>) - Static method in class alluxio.util.StreamUtils
 
MapReduceIntegrationChecker - Class in alluxio.checker
A MapReduce job to test the integration of MapReduce with Alluxio.
MapReduceIntegrationChecker() - Constructor for class alluxio.checker.MapReduceIntegrationChecker
 
MapReduceIntegrationChecker.CheckerMapper - Class in alluxio.checker
In each mapper node, we will check whether this node can recognize Alluxio classes and filesystem.
MapReduceIntegrationChecker.CheckerReducer - Class in alluxio.checker
In each reducer node, we will combine the IP addresses that have the same Status.
markBlockMoveIn(long, long) - Method in class alluxio.worker.block.meta.StorageDirView
Marks a block to move into this dir view, which is used by the evictor.
markBlockMoveOut(long, long) - Method in class alluxio.worker.block.meta.StorageDirView
Marks a block to move out of this dir view, which is used by the evictor.
Master - Interface in alluxio.master
This interface contains common operations for all masters.
Master - Class in alluxio.multi.process
Class for running and interacting with an Alluxio master in a separate process.
Master(File, Map<PropertyKey, String>) - Constructor for class alluxio.multi.process.Master
 
MASTER_AUDIT_LOGGING_ENABLED - Static variable in class alluxio.PropertyKey
Master related properties.
MASTER_AUDIT_LOGGING_ENABLED - Static variable in class alluxio.PropertyKey.Name
 
MASTER_AUDIT_LOGGING_QUEUE_CAPACITY - Static variable in class alluxio.PropertyKey
 
MASTER_AUDIT_LOGGING_QUEUE_CAPACITY - Static variable in class alluxio.PropertyKey.Name
 
MASTER_BACKUP_DIRECTORY - Static variable in class alluxio.PropertyKey
 
MASTER_BACKUP_DIRECTORY - Static variable in class alluxio.PropertyKey.Name
 
MASTER_BACKUP_ENTRY_BATCH_SIZE - Static variable in class alluxio.PropertyKey
 
MASTER_BACKUP_ENTRY_BATCH_SIZE - Static variable in class alluxio.PropertyKey.Name
 
MASTER_BIND_HOST - Static variable in class alluxio.PropertyKey
 
MASTER_BIND_HOST - Static variable in class alluxio.PropertyKey.Name
 
MASTER_BLOCK_INTEGRITY_CHECK - Static variable in class alluxio.heartbeat.HeartbeatContext
 
MASTER_CHECKPOINT_SCHEDULING - Static variable in class alluxio.heartbeat.HeartbeatContext
 
MASTER_CLIENT_SOCKET_CLEANUP_INTERVAL - Static variable in class alluxio.PropertyKey
 
MASTER_CLIENT_SOCKET_CLEANUP_INTERVAL - Static variable in class alluxio.PropertyKey.Name
 
MASTER_CLUSTER_METRICS_UPDATE_INTERVAL - Static variable in class alluxio.PropertyKey
 
MASTER_CLUSTER_METRICS_UPDATE_INTERVAL - Static variable in class alluxio.PropertyKey.Name
 
MASTER_CLUSTER_METRICS_UPDATER - Static variable in class alluxio.heartbeat.HeartbeatContext
 
MASTER_COLUMN_FILE_PREFIX - Static variable in class alluxio.Constants
 
MASTER_COMMAND_SESSION_ID - Static variable in class alluxio.Sessions
 
MASTER_CONNECTION_TIMEOUT_MS - Static variable in class alluxio.PropertyKey
 
MASTER_CONNECTION_TIMEOUT_MS - Static variable in class alluxio.PropertyKey.Name
 
MASTER_DAILY_BACKUP - Static variable in class alluxio.heartbeat.HeartbeatContext
 
MASTER_DAILY_BACKUP_ENABLED - Static variable in class alluxio.PropertyKey
 
MASTER_DAILY_BACKUP_ENABLED - Static variable in class alluxio.PropertyKey.Name
 
MASTER_DAILY_BACKUP_FILES_RETAINED - Static variable in class alluxio.PropertyKey
 
MASTER_DAILY_BACKUP_FILES_RETAINED - Static variable in class alluxio.PropertyKey.Name
 
MASTER_DAILY_BACKUP_TIME - Static variable in class alluxio.PropertyKey
 
MASTER_DAILY_BACKUP_TIME - Static variable in class alluxio.PropertyKey.Name
 
MASTER_FILE_ASYNC_PERSIST_HANDLER - Static variable in class alluxio.PropertyKey
 
MASTER_FILE_ASYNC_PERSIST_HANDLER - Static variable in class alluxio.PropertyKey.Name
 
MASTER_FILE_RECOMPUTATION - Static variable in class alluxio.heartbeat.HeartbeatContext
 
MASTER_FORMAT_FILE_PREFIX - Static variable in class alluxio.PropertyKey
 
MASTER_FORMAT_FILE_PREFIX - Static variable in class alluxio.PropertyKey.Name
 
MASTER_HEARTBEAT_TIMEOUT - Static variable in class alluxio.PropertyKey
 
MASTER_HEARTBEAT_TIMEOUT - Static variable in class alluxio.PropertyKey.Name
 
MASTER_HOSTNAME - Static variable in class alluxio.PropertyKey
 
MASTER_HOSTNAME - Static variable in class alluxio.PropertyKey.Name
 
MASTER_JOURNAL_CHECKPOINT_PERIOD_ENTRIES - Static variable in class alluxio.PropertyKey
 
MASTER_JOURNAL_CHECKPOINT_PERIOD_ENTRIES - Static variable in class alluxio.PropertyKey.Name
 
MASTER_JOURNAL_FLUSH_BATCH_TIME_MS - Static variable in class alluxio.PropertyKey
 
MASTER_JOURNAL_FLUSH_BATCH_TIME_MS - Static variable in class alluxio.PropertyKey.Name
 
MASTER_JOURNAL_FLUSH_RETRY_INTERVAL - Static variable in class alluxio.PropertyKey
 
MASTER_JOURNAL_FLUSH_RETRY_INTERVAL - Static variable in class alluxio.PropertyKey.Name
 
MASTER_JOURNAL_FLUSH_TIMEOUT_MS - Static variable in class alluxio.PropertyKey
 
MASTER_JOURNAL_FLUSH_TIMEOUT_MS - Static variable in class alluxio.PropertyKey.Name
 
MASTER_JOURNAL_FOLDER - Static variable in class alluxio.PropertyKey
 
MASTER_JOURNAL_FOLDER - Static variable in class alluxio.PropertyKey.Name
 
MASTER_JOURNAL_FORMATTER_CLASS - Static variable in class alluxio.PropertyKey
Deprecated.
since 1.5.0 and will be removed in 2.0.
MASTER_JOURNAL_FORMATTER_CLASS - Static variable in class alluxio.PropertyKey.Name
 
MASTER_JOURNAL_GC_PERIOD_MS - Static variable in class alluxio.PropertyKey
 
MASTER_JOURNAL_GC_PERIOD_MS - Static variable in class alluxio.PropertyKey.Name
 
MASTER_JOURNAL_GC_THRESHOLD_MS - Static variable in class alluxio.PropertyKey
 
MASTER_JOURNAL_GC_THRESHOLD_MS - Static variable in class alluxio.PropertyKey.Name
 
MASTER_JOURNAL_INIT_FROM_BACKUP - Static variable in class alluxio.PropertyKey
 
MASTER_JOURNAL_INIT_FROM_BACKUP - Static variable in class alluxio.PropertyKey.Name
 
MASTER_JOURNAL_LOG_SIZE_BYTES_MAX - Static variable in class alluxio.PropertyKey
 
MASTER_JOURNAL_LOG_SIZE_BYTES_MAX - Static variable in class alluxio.PropertyKey.Name
 
MASTER_JOURNAL_TAILER_SHUTDOWN_QUIET_WAIT_TIME_MS - Static variable in class alluxio.PropertyKey
 
MASTER_JOURNAL_TAILER_SHUTDOWN_QUIET_WAIT_TIME_MS - Static variable in class alluxio.PropertyKey.Name
 
MASTER_JOURNAL_TAILER_SLEEP_TIME_MS - Static variable in class alluxio.PropertyKey
 
MASTER_JOURNAL_TAILER_SLEEP_TIME_MS - Static variable in class alluxio.PropertyKey.Name
 
MASTER_JOURNAL_TEMPORARY_FILE_GC_THRESHOLD_MS - Static variable in class alluxio.PropertyKey
 
MASTER_JOURNAL_TEMPORARY_FILE_GC_THRESHOLD_MS - Static variable in class alluxio.PropertyKey.Name
 
MASTER_JOURNAL_TYPE - Static variable in class alluxio.PropertyKey
 
MASTER_JOURNAL_TYPE - Static variable in class alluxio.PropertyKey.Name
 
MASTER_JOURNAL_UFS_OPTION - Static variable in class alluxio.PropertyKey
 
MASTER_JVM_MONITOR_ENABLED - Static variable in class alluxio.PropertyKey
 
MASTER_JVM_MONITOR_ENABLED - Static variable in class alluxio.PropertyKey.Name
 
MASTER_KEYTAB_KEY_FILE - Static variable in class alluxio.PropertyKey
 
MASTER_KEYTAB_KEY_FILE - Static variable in class alluxio.PropertyKey.Name
 
MASTER_LINEAGE_CHECKPOINT_CLASS - Static variable in class alluxio.PropertyKey
 
MASTER_LINEAGE_CHECKPOINT_CLASS - Static variable in class alluxio.PropertyKey.Name
 
MASTER_LINEAGE_CHECKPOINT_INTERVAL_MS - Static variable in class alluxio.PropertyKey
 
MASTER_LINEAGE_CHECKPOINT_INTERVAL_MS - Static variable in class alluxio.PropertyKey.Name
 
MASTER_LINEAGE_RECOMPUTE_INTERVAL_MS - Static variable in class alluxio.PropertyKey
 
MASTER_LINEAGE_RECOMPUTE_INTERVAL_MS - Static variable in class alluxio.PropertyKey.Name
 
MASTER_LINEAGE_RECOMPUTE_LOG_PATH - Static variable in class alluxio.PropertyKey
 
MASTER_LINEAGE_RECOMPUTE_LOG_PATH - Static variable in class alluxio.PropertyKey.Name
 
MASTER_LOG_CONFIG_REPORT_HEARTBEAT_INTERVAL - Static variable in class alluxio.PropertyKey
 
MASTER_LOG_CONFIG_REPORT_HEARTBEAT_INTERVAL - Static variable in class alluxio.PropertyKey.Name
 
MASTER_LOG_CONFIG_REPORT_SCHEDULING - Static variable in class alluxio.heartbeat.HeartbeatContext
 
MASTER_LOST_FILES_DETECTION - Static variable in class alluxio.heartbeat.HeartbeatContext
 
MASTER_LOST_MASTER_DETECTION - Static variable in class alluxio.heartbeat.HeartbeatContext
 
MASTER_LOST_WORKER_DETECTION - Static variable in class alluxio.heartbeat.HeartbeatContext
 
MASTER_MASTER_HEARTBEAT_INTERVAL - Static variable in class alluxio.PropertyKey
 
MASTER_MASTER_HEARTBEAT_INTERVAL - Static variable in class alluxio.PropertyKey.Name
 
MASTER_METASTORE_INODE_INHERIT_OWNER_AND_GROUP - Static variable in class alluxio.PropertyKey
 
MASTER_METASTORE_INODE_INHERIT_OWNER_AND_GROUP - Static variable in class alluxio.PropertyKey.Name
 
MASTER_METRICS_SERVICE_THREADS - Static variable in class alluxio.PropertyKey
 
MASTER_METRICS_SERVICE_THREADS - Static variable in class alluxio.PropertyKey.Name
 
MASTER_METRICS_SYNC - Static variable in class alluxio.heartbeat.HeartbeatContext
 
MASTER_MOUNT_TABLE_ROOT_ALLUXIO - Static variable in class alluxio.PropertyKey
 
MASTER_MOUNT_TABLE_ROOT_OPTION - Static variable in class alluxio.PropertyKey
 
MASTER_MOUNT_TABLE_ROOT_READONLY - Static variable in class alluxio.PropertyKey
 
MASTER_MOUNT_TABLE_ROOT_SHARED - Static variable in class alluxio.PropertyKey
 
MASTER_MOUNT_TABLE_ROOT_UFS - Static variable in class alluxio.PropertyKey
 
MASTER_PERIODIC_BLOCK_INTEGRITY_CHECK_INTERVAL - Static variable in class alluxio.PropertyKey
 
MASTER_PERIODIC_BLOCK_INTEGRITY_CHECK_INTERVAL - Static variable in class alluxio.PropertyKey.Name
 
MASTER_PERIODIC_BLOCK_INTEGRITY_CHECK_REPAIR - Static variable in class alluxio.PropertyKey
 
MASTER_PERIODIC_BLOCK_INTEGRITY_CHECK_REPAIR - Static variable in class alluxio.PropertyKey.Name
 
MASTER_PRINCIPAL - Static variable in class alluxio.PropertyKey
 
MASTER_PRINCIPAL - Static variable in class alluxio.PropertyKey.Name
 
MASTER_RETRY - Static variable in class alluxio.PropertyKey.Name
 
MASTER_RPC_PORT - Static variable in class alluxio.PropertyKey
 
MASTER_RPC_PORT - Static variable in class alluxio.PropertyKey.Name
 
MASTER_SERVING_THREAD_TIMEOUT - Static variable in class alluxio.PropertyKey
 
MASTER_SERVING_THREAD_TIMEOUT - Static variable in class alluxio.PropertyKey.Name
 
MASTER_STARTUP_BLOCK_INTEGRITY_CHECK_ENABLED - Static variable in class alluxio.PropertyKey
 
MASTER_STARTUP_BLOCK_INTEGRITY_CHECK_ENABLED - Static variable in class alluxio.PropertyKey.Name
 
MASTER_STARTUP_CONSISTENCY_CHECK_ENABLED - Static variable in class alluxio.PropertyKey
 
MASTER_STARTUP_CONSISTENCY_CHECK_ENABLED - Static variable in class alluxio.PropertyKey.Name
 
MASTER_THRIFT_SHUTDOWN_TIMEOUT - Static variable in class alluxio.PropertyKey
 
MASTER_THRIFT_SHUTDOWN_TIMEOUT - Static variable in class alluxio.PropertyKey.Name
 
MASTER_TIERED_STORE_GLOBAL_LEVEL0_ALIAS - Static variable in class alluxio.PropertyKey
 
MASTER_TIERED_STORE_GLOBAL_LEVEL0_ALIAS - Static variable in class alluxio.PropertyKey.Name
 
MASTER_TIERED_STORE_GLOBAL_LEVEL1_ALIAS - Static variable in class alluxio.PropertyKey
 
MASTER_TIERED_STORE_GLOBAL_LEVEL1_ALIAS - Static variable in class alluxio.PropertyKey.Name
 
MASTER_TIERED_STORE_GLOBAL_LEVEL2_ALIAS - Static variable in class alluxio.PropertyKey
 
MASTER_TIERED_STORE_GLOBAL_LEVEL2_ALIAS - Static variable in class alluxio.PropertyKey.Name
 
MASTER_TIERED_STORE_GLOBAL_LEVELS - Static variable in class alluxio.PropertyKey
 
MASTER_TIERED_STORE_GLOBAL_LEVELS - Static variable in class alluxio.PropertyKey.Name
 
MASTER_TTL_CHECK - Static variable in class alluxio.heartbeat.HeartbeatContext
 
MASTER_TTL_CHECKER_INTERVAL_MS - Static variable in class alluxio.PropertyKey
 
MASTER_TTL_CHECKER_INTERVAL_MS - Static variable in class alluxio.PropertyKey.Name
 
MASTER_UFS_BLOCK_LOCATION_CACHE_CAPACITY - Static variable in class alluxio.PropertyKey
 
MASTER_UFS_BLOCK_LOCATION_CACHE_CAPACITY - Static variable in class alluxio.PropertyKey.Name
 
MASTER_UFS_PATH_CACHE_CAPACITY - Static variable in class alluxio.PropertyKey
 
MASTER_UFS_PATH_CACHE_CAPACITY - Static variable in class alluxio.PropertyKey.Name
 
MASTER_UFS_PATH_CACHE_THREADS - Static variable in class alluxio.PropertyKey
 
MASTER_UFS_PATH_CACHE_THREADS - Static variable in class alluxio.PropertyKey.Name
 
MASTER_WEB_BIND_HOST - Static variable in class alluxio.PropertyKey
 
MASTER_WEB_BIND_HOST - Static variable in class alluxio.PropertyKey.Name
 
MASTER_WEB_HOSTNAME - Static variable in class alluxio.PropertyKey
 
MASTER_WEB_HOSTNAME - Static variable in class alluxio.PropertyKey.Name
 
MASTER_WEB_PORT - Static variable in class alluxio.PropertyKey
 
MASTER_WEB_PORT - Static variable in class alluxio.PropertyKey.Name
 
MASTER_WHITELIST - Static variable in class alluxio.PropertyKey
 
MASTER_WHITELIST - Static variable in class alluxio.PropertyKey.Name
 
MASTER_WORKER_CONNECT_WAIT_TIME - Static variable in class alluxio.PropertyKey
 
MASTER_WORKER_CONNECT_WAIT_TIME - Static variable in class alluxio.PropertyKey.Name
 
MASTER_WORKER_HEARTBEAT_INTERVAL - Static variable in class alluxio.PropertyKey
 
MASTER_WORKER_HEARTBEAT_INTERVAL - Static variable in class alluxio.PropertyKey.Name
 
MASTER_WORKER_THREADS_MAX - Static variable in class alluxio.PropertyKey
 
MASTER_WORKER_THREADS_MAX - Static variable in class alluxio.PropertyKey.Name
 
MASTER_WORKER_THREADS_MIN - Static variable in class alluxio.PropertyKey
 
MASTER_WORKER_THREADS_MIN - Static variable in class alluxio.PropertyKey.Name
 
MASTER_WORKER_TIMEOUT_MS - Static variable in class alluxio.PropertyKey
 
MASTER_WORKER_TIMEOUT_MS - Static variable in class alluxio.PropertyKey.Name
 
MasterBlockInfo - Class in alluxio.master.block.meta
The metadata for an Alluxio block, managed by the block master.
MasterBlockInfo(long, long) - Constructor for class alluxio.master.block.meta.MasterBlockInfo
Creates a new instance of MasterBlockInfo.
MasterBlockLocation - Class in alluxio.master.block.meta
The location of an Alluxio block.
MasterClientConfig - Class in alluxio.master
Configuration for constructing an Alluxio master client.
MasterClientConfig() - Constructor for class alluxio.master.MasterClientConfig
 
MasterContext - Class in alluxio.master
Stores context information for Alluxio masters.
MasterContext(JournalSystem, SafeModeManager, BackupManager, long, int) - Constructor for class alluxio.master.MasterContext
Creates a new master context.
MasterFactory - Interface in alluxio.master
Interface for factory of Master.
MasterHealthCheckClient - Class in alluxio.master
MasterHealthCheckClient check whether Alluxio master is serving RPC requests and if the AlluxioMaster process is running in all master hosts.
MasterHealthCheckClient(String, boolean) - Constructor for class alluxio.master.MasterHealthCheckClient
Creates a new instance of MasterHealthCheckClient.
MasterHealthCheckClient.Builder - Class in alluxio.master
MasterHealthCheckClient.MasterServingCheckRunnable - Class in alluxio.master
Runnable for checking if the AlluxioMaster is serving RPCs.
MasterHealthCheckClient.ProcessCheckRunnable - Class in alluxio.master
Runnable for checking if the AlluxioMaster process are running in all the masters hosts.
masterHeartbeat(long) - Method in class alluxio.master.meta.DefaultMetaMaster
 
masterHeartbeat(long) - Method in interface alluxio.master.meta.MetaMaster
A standby master periodically heartbeats with the leader master.
masterHeartbeat(long, MasterHeartbeatTOptions) - Method in class alluxio.master.meta.MetaMasterMasterServiceHandler
 
masterHeartbeat(long, MasterHeartbeatTOptions, AsyncMethodCallback) - Method in class alluxio.thrift.MetaMasterMasterService.AsyncClient
 
masterHeartbeat(long, MasterHeartbeatTOptions, AsyncMethodCallback) - Method in interface alluxio.thrift.MetaMasterMasterService.AsyncIface
 
masterHeartbeat() - Constructor for class alluxio.thrift.MetaMasterMasterService.AsyncProcessor.masterHeartbeat
 
masterHeartbeat(long, MasterHeartbeatTOptions) - Method in class alluxio.thrift.MetaMasterMasterService.Client
 
masterHeartbeat(long, MasterHeartbeatTOptions) - Method in interface alluxio.thrift.MetaMasterMasterService.Iface
Heartbeats to indicate the master is lost or not.
masterHeartbeat() - Constructor for class alluxio.thrift.MetaMasterMasterService.Processor.masterHeartbeat
 
masterHeartbeat_args() - Constructor for class alluxio.thrift.MetaMasterMasterService.masterHeartbeat_args
 
masterHeartbeat_args(long, MasterHeartbeatTOptions) - Constructor for class alluxio.thrift.MetaMasterMasterService.masterHeartbeat_args
 
masterHeartbeat_args(MetaMasterMasterService.masterHeartbeat_args) - Constructor for class alluxio.thrift.MetaMasterMasterService.masterHeartbeat_args
Performs a deep copy on other.
masterHeartbeat_call(long, MasterHeartbeatTOptions, AsyncMethodCallback, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class alluxio.thrift.MetaMasterMasterService.AsyncClient.masterHeartbeat_call
 
masterHeartbeat_result() - Constructor for class alluxio.thrift.MetaMasterMasterService.masterHeartbeat_result
 
masterHeartbeat_result(MasterHeartbeatTResponse, AlluxioTException) - Constructor for class alluxio.thrift.MetaMasterMasterService.masterHeartbeat_result
 
masterHeartbeat_result(MetaMasterMasterService.masterHeartbeat_result) - Constructor for class alluxio.thrift.MetaMasterMasterService.masterHeartbeat_result
Performs a deep copy on other.
MasterHeartbeatTOptions - Class in alluxio.thrift
 
MasterHeartbeatTOptions() - Constructor for class alluxio.thrift.MasterHeartbeatTOptions
 
MasterHeartbeatTOptions(MasterHeartbeatTOptions) - Constructor for class alluxio.thrift.MasterHeartbeatTOptions
Performs a deep copy on other.
MasterHeartbeatTOptions._Fields - Enum in alluxio.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
MasterHeartbeatTResponse - Class in alluxio.thrift
 
MasterHeartbeatTResponse() - Constructor for class alluxio.thrift.MasterHeartbeatTResponse
 
MasterHeartbeatTResponse(MetaCommand) - Constructor for class alluxio.thrift.MasterHeartbeatTResponse
 
MasterHeartbeatTResponse(MasterHeartbeatTResponse) - Constructor for class alluxio.thrift.MasterHeartbeatTResponse
Performs a deep copy on other.
MasterHeartbeatTResponse._Fields - Enum in alluxio.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
masterHostConfigured() - Static method in class alluxio.util.ConfigurationUtils
 
MasterInfo - Class in alluxio.master.meta
Master information.
MasterInfo(long, Address) - Constructor for class alluxio.master.meta.MasterInfo
Creates a new instance of MasterInfo.
MasterInfo - Class in alluxio.thrift
 
MasterInfo() - Constructor for class alluxio.thrift.MasterInfo
 
MasterInfo(String, List<MasterNetAddress>, int, boolean, long, long, String, int, List<MasterNetAddress>, List<String>) - Constructor for class alluxio.thrift.MasterInfo
 
MasterInfo(MasterInfo) - Constructor for class alluxio.thrift.MasterInfo
Performs a deep copy on other.
MasterInfo - Class in alluxio.wire
The information of the Alluxio leader master.
MasterInfo() - Constructor for class alluxio.wire.MasterInfo
Creates a new instance of MasterInfo.
MasterInfo._Fields - Enum in alluxio.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
MasterInfo.MasterInfoField - Enum in alluxio.wire
Enum representing the fields of the master info.
MasterInfoCommand - Class in alluxio.cli.fs.command
Prints information regarding master fault tolerance such as leader address, list of master addresses, and the configured Zookeeper address.
MasterInfoCommand(FileSystem) - Constructor for class alluxio.cli.fs.command.MasterInfoCommand
 
MasterInfoField - Enum in alluxio.thrift
 
MasterInquireClient - Interface in alluxio.master
Client for determining the primary master.
MasterInquireClient.ConnectDetails - Interface in alluxio.master
Interface for representing master inquire connect details.
MasterInquireClient.Factory - Class in alluxio.master
Factory for getting a master inquire client.
MasterJournalContext - Class in alluxio.master.journal
Context for storing master journal information.
MasterJournalContext(AsyncJournalWriter) - Constructor for class alluxio.master.journal.MasterJournalContext
Constructs a MasterJournalContext.
MasterMetrics - Class in alluxio.metrics
Metrics of Alluxio master.
MasterNetAddress - Class in alluxio.multi.process
Network addresses for an Alluxio master.
MasterNetAddress(String, int, int) - Constructor for class alluxio.multi.process.MasterNetAddress
 
MasterNetAddress - Class in alluxio.thrift
 
MasterNetAddress() - Constructor for class alluxio.thrift.MasterNetAddress
 
MasterNetAddress(String, int) - Constructor for class alluxio.thrift.MasterNetAddress
 
MasterNetAddress(MasterNetAddress) - Constructor for class alluxio.thrift.MasterNetAddress
Performs a deep copy on other.
MasterNetAddress._Fields - Enum in alluxio.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
MasterProcess - Interface in alluxio.master
A master process in the Alluxio system.
MasterProcess.Factory - Class in alluxio.master
Factory for creating MasterProcess.
masterRegister(long, RegisterMasterTOptions) - Method in class alluxio.master.meta.DefaultMetaMaster
 
masterRegister(long, RegisterMasterTOptions) - Method in interface alluxio.master.meta.MetaMaster
A standby master registers with the leader master.
MasterRegistry - Class in alluxio.master
A master registry.
MasterRegistry() - Constructor for class alluxio.master.MasterRegistry
Creates a new instance of MasterRegistry.
MasterServingCheckRunnable() - Constructor for class alluxio.master.MasterHealthCheckClient.MasterServingCheckRunnable
 
MasterStorageTierAssoc - Class in alluxio
StorageTierAssoc for masters.
MasterStorageTierAssoc() - Constructor for class alluxio.MasterStorageTierAssoc
Creates a new instance of MasterStorageTierAssoc.
MasterStorageTierAssoc(List<String>) - Constructor for class alluxio.MasterStorageTierAssoc
Creates a new instance of MasterStorageTierAssoc.
MasterUfsManager - Class in alluxio.underfs
A class that manages the UFS for master servers.
MasterUfsManager() - Constructor for class alluxio.underfs.MasterUfsManager
Constructs the instance of MasterUfsManager.
MasterUfsManager.UfsState - Class in alluxio.underfs
UnderFileSystem.UfsMode and mount ids corresponding to a physical ufs.
MasterWebServer - Class in alluxio.web
The Alluxio master web server.
MasterWebServer(String, InetSocketAddress, MasterProcess) - Constructor for class alluxio.web.MasterWebServer
Creates a new instance of MasterWebServer.
MasterWorkerInfo - Class in alluxio.master.block.meta
Metadata for an Alluxio worker.
MasterWorkerInfo(long, WorkerNetAddress) - Constructor for class alluxio.master.block.meta.MasterWorkerInfo
Creates a new instance of MasterWorkerInfo.
match(String, String) - Static method in class alluxio.cli.fs.FileSystemShellUtils
Returns whether or not filePath matches patternPath.
match(String) - Method in enum alluxio.PropertyKey.Template
 
matchContent(Fingerprint) - Method in class alluxio.underfs.Fingerprint
Returns true if the serialized fingerprint matches the fingerprint in the content part.
matches(String) - Method in enum alluxio.PropertyKey.Template
 
matches(TieredIdentity.LocalityTier) - Method in class alluxio.wire.TieredIdentity.LocalityTier
Locality comparison for wire type locality tiers, two locality tiers matches if both name and values are equal, or for the "node" tier, if the node names resolve to the same IP address.
matchMetadata(Fingerprint) - Method in class alluxio.underfs.Fingerprint
Returns true if the serialized fingerprint matches the fingerprint in metadata.
MAX_PORT - Static variable in class alluxio.Constants
 
MAX_PROBES - Static variable in class alluxio.client.keyvalue.LinearProbingIndex
Max number of probes for linear probing.
MAX_TEST_DURATION_MS - Static variable in class alluxio.Constants
 
MAX_TEST_PROCESS_LIFETIME_MS - Static variable in class alluxio.Constants
 
MaxFreeAllocator - Class in alluxio.worker.block.allocator
An allocator that allocates a block in the storage dir with most free space.
MaxFreeAllocator(BlockMetadataManagerView) - Constructor for class alluxio.worker.block.allocator.MaxFreeAllocator
Creates a new instance of MaxFreeAllocator.
MAXUFSREADCONCURRENCY_FIELD_NUMBER - Static variable in class alluxio.proto.dataserver.Protocol.OpenUfsBlockOptions
 
MB - Static variable in class alluxio.Constants
 
mBackupManager - Variable in class alluxio.master.AbstractMaster
The manager for creating and restoring backups.
mBlockClient - Variable in class alluxio.cli.fsadmin.command.AbstractFsAdminCommand
 
mBlockId - Variable in class alluxio.worker.block.meta.AbstractBlockMeta
 
mBuf - Variable in class alluxio.examples.Performance.Worker
 
mBytesWritten - Variable in class alluxio.client.AbstractOutStream
The number of bytes written.
mClock - Variable in class alluxio.master.AbstractMaster
The clock to use for determining the time.
mClock - Variable in class alluxio.resource.DynamicResourcePool
 
mClosed - Variable in class alluxio.AbstractClient
Is true if this client was closed by the user.
mClosed - Variable in class alluxio.underfs.MultiRangeObjectInputStream
Has the stream been closed.
mCloser - Variable in class alluxio.underfs.AbstractUfsManager
 
mCommonOptions - Variable in class alluxio.master.file.options.CreatePathOptions
 
mConnected - Variable in class alluxio.AbstractClient
Is true if this client is currently connected.
mContentHash - Variable in class alluxio.underfs.UfsFileStatus
 
mContentLength - Variable in class alluxio.underfs.UfsFileStatus
 
mContext - Variable in class alluxio.client.lineage.AbstractLineageClient
 
mCreationTimeMs - Variable in class alluxio.master.file.meta.Inode
 
mCurrentCapacity - Variable in class alluxio.resource.ResourcePool
It represents the total number of resources that have been created by this pool.
mDir - Variable in class alluxio.worker.block.meta.AbstractBlockMeta
 
mDirectory - Variable in class alluxio.master.file.meta.Inode
 
MECHANISM - Static variable in class alluxio.security.authentication.PlainSaslServerProvider
 
memoize(Supplier<T>) - Static method in class alluxio.util.CommonUtils
Memoize implementation for java.util.function.supplier.
memoryCopyPartition() - Method in class alluxio.examples.Performance.GeneralWorker
Copies a partition in memory.
mEndPos - Variable in class alluxio.underfs.MultiRangeObjectInputStream
Position the current stream was open till (exclusive).
merge(Map<?, ?>, Source) - Method in interface alluxio.AlluxioConfiguration
Merges the current configuration properties with new properties.
merge(Map<?, ?>, Source) - Method in class alluxio.conf.AlluxioProperties
Merges the current configuration properties with new properties.
merge(Map<?, ?>, Source) - Method in class alluxio.conf.InstancedConfiguration
 
merge(Map<?, ?>, Source) - Static method in class alluxio.Configuration
Merges the current configuration properties with new properties.
MERGE_STORE_FIELD_NUMBER - Static variable in class alluxio.proto.journal.Journal.JournalEntry
 
mergeAddMountPoint(File.AddMountPointEntry) - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
optional .alluxio.proto.journal.AddMountPointEntry add_mount_point = 2;
mergeAsyncPersistRequest(File.AsyncPersistRequestEntry) - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
optional .alluxio.proto.journal.AsyncPersistRequestEntry async_persist_request = 16;
mergeBlockContainerIdGenerator(Block.BlockContainerIdGeneratorEntry) - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
optional .alluxio.proto.journal.BlockContainerIdGeneratorEntry block_container_id_generator = 3;
mergeBlockInfo(Block.BlockInfoEntry) - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
optional .alluxio.proto.journal.BlockInfoEntry block_info = 4;
mergeCompleteFile(File.CompleteFileEntry) - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
optional .alluxio.proto.journal.CompleteFileEntry complete_file = 5;
mergeCompletePartition(KeyValue.CompletePartitionEntry) - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
optional .alluxio.proto.journal.CompletePartitionEntry complete_partition = 21;
mergeCompleteStore(KeyValue.CompleteStoreEntry) - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
optional .alluxio.proto.journal.CompleteStoreEntry complete_store = 22;
mergeCreateStore(KeyValue.CreateStoreEntry) - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
optional .alluxio.proto.journal.CreateStoreEntry create_store = 23;
mergeCreateUfsFileOptions(Protocol.CreateUfsFileOptions) - Method in class alluxio.proto.dataserver.Protocol.WriteRequest.Builder
optional .alluxio.proto.dataserver.CreateUfsFileOptions create_ufs_file_options = 7;
mergeDeleteBlock(Block.DeleteBlockEntry) - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
optional .alluxio.proto.journal.DeleteBlockEntry delete_block = 29;
mergeDeleteFile(File.DeleteFileEntry) - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
optional .alluxio.proto.journal.DeleteFileEntry delete_file = 6;
mergeDeleteLineage(Lineage.DeleteLineageEntry) - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
optional .alluxio.proto.journal.DeleteLineageEntry delete_lineage = 7;
mergeDeleteMountPoint(File.DeleteMountPointEntry) - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
optional .alluxio.proto.journal.DeleteMountPointEntry delete_mount_point = 8;
mergeDeleteStore(KeyValue.DeleteStoreEntry) - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
optional .alluxio.proto.journal.DeleteStoreEntry delete_store = 25;
mergeFrom(Message) - Method in class alluxio.proto.dataserver.Protocol.AsyncCacheRequest.Builder
 
mergeFrom(Protocol.AsyncCacheRequest) - Method in class alluxio.proto.dataserver.Protocol.AsyncCacheRequest.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class alluxio.proto.dataserver.Protocol.AsyncCacheRequest.Builder
 
mergeFrom(Message) - Method in class alluxio.proto.dataserver.Protocol.CreateUfsFileOptions.Builder
 
mergeFrom(Protocol.CreateUfsFileOptions) - Method in class alluxio.proto.dataserver.Protocol.CreateUfsFileOptions.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class alluxio.proto.dataserver.Protocol.CreateUfsFileOptions.Builder
 
mergeFrom(Message) - Method in class alluxio.proto.dataserver.Protocol.Heartbeat.Builder
 
mergeFrom(Protocol.Heartbeat) - Method in class alluxio.proto.dataserver.Protocol.Heartbeat.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class alluxio.proto.dataserver.Protocol.Heartbeat.Builder
 
mergeFrom(Message) - Method in class alluxio.proto.dataserver.Protocol.LocalBlockCloseRequest.Builder
 
mergeFrom(Protocol.LocalBlockCloseRequest) - Method in class alluxio.proto.dataserver.Protocol.LocalBlockCloseRequest.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class alluxio.proto.dataserver.Protocol.LocalBlockCloseRequest.Builder
 
mergeFrom(Message) - Method in class alluxio.proto.dataserver.Protocol.LocalBlockCompleteRequest.Builder
 
mergeFrom(Protocol.LocalBlockCompleteRequest) - Method in class alluxio.proto.dataserver.Protocol.LocalBlockCompleteRequest.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class alluxio.proto.dataserver.Protocol.LocalBlockCompleteRequest.Builder
 
mergeFrom(Message) - Method in class alluxio.proto.dataserver.Protocol.LocalBlockCreateRequest.Builder
 
mergeFrom(Protocol.LocalBlockCreateRequest) - Method in class alluxio.proto.dataserver.Protocol.LocalBlockCreateRequest.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class alluxio.proto.dataserver.Protocol.LocalBlockCreateRequest.Builder
 
mergeFrom(Message) - Method in class alluxio.proto.dataserver.Protocol.LocalBlockCreateResponse.Builder
 
mergeFrom(Protocol.LocalBlockCreateResponse) - Method in class alluxio.proto.dataserver.Protocol.LocalBlockCreateResponse.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class alluxio.proto.dataserver.Protocol.LocalBlockCreateResponse.Builder
 
mergeFrom(Message) - Method in class alluxio.proto.dataserver.Protocol.LocalBlockOpenRequest.Builder
 
mergeFrom(Protocol.LocalBlockOpenRequest) - Method in class alluxio.proto.dataserver.Protocol.LocalBlockOpenRequest.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class alluxio.proto.dataserver.Protocol.LocalBlockOpenRequest.Builder
 
mergeFrom(Message) - Method in class alluxio.proto.dataserver.Protocol.LocalBlockOpenResponse.Builder
 
mergeFrom(Protocol.LocalBlockOpenResponse) - Method in class alluxio.proto.dataserver.Protocol.LocalBlockOpenResponse.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class alluxio.proto.dataserver.Protocol.LocalBlockOpenResponse.Builder
 
mergeFrom(Message) - Method in class alluxio.proto.dataserver.Protocol.OpenUfsBlockOptions.Builder
 
mergeFrom(Protocol.OpenUfsBlockOptions) - Method in class alluxio.proto.dataserver.Protocol.OpenUfsBlockOptions.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class alluxio.proto.dataserver.Protocol.OpenUfsBlockOptions.Builder
 
mergeFrom(Message) - Method in class alluxio.proto.dataserver.Protocol.ReadRequest.Builder
 
mergeFrom(Protocol.ReadRequest) - Method in class alluxio.proto.dataserver.Protocol.ReadRequest.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class alluxio.proto.dataserver.Protocol.ReadRequest.Builder
 
mergeFrom(Message) - Method in class alluxio.proto.dataserver.Protocol.ReadResponse.Builder
 
mergeFrom(Protocol.ReadResponse) - Method in class alluxio.proto.dataserver.Protocol.ReadResponse.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class alluxio.proto.dataserver.Protocol.ReadResponse.Builder
 
mergeFrom(Message) - Method in class alluxio.proto.dataserver.Protocol.Response.Builder
 
mergeFrom(Protocol.Response) - Method in class alluxio.proto.dataserver.Protocol.Response.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class alluxio.proto.dataserver.Protocol.Response.Builder
 
mergeFrom(Message) - Method in class alluxio.proto.dataserver.Protocol.WriteRequest.Builder
 
mergeFrom(Protocol.WriteRequest) - Method in class alluxio.proto.dataserver.Protocol.WriteRequest.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class alluxio.proto.dataserver.Protocol.WriteRequest.Builder
 
mergeFrom(Message) - Method in class alluxio.proto.journal.Block.BlockContainerIdGeneratorEntry.Builder
 
mergeFrom(Block.BlockContainerIdGeneratorEntry) - Method in class alluxio.proto.journal.Block.BlockContainerIdGeneratorEntry.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class alluxio.proto.journal.Block.BlockContainerIdGeneratorEntry.Builder
 
mergeFrom(Message) - Method in class alluxio.proto.journal.Block.BlockInfoEntry.Builder
 
mergeFrom(Block.BlockInfoEntry) - Method in class alluxio.proto.journal.Block.BlockInfoEntry.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class alluxio.proto.journal.Block.BlockInfoEntry.Builder
 
mergeFrom(Message) - Method in class alluxio.proto.journal.Block.DeleteBlockEntry.Builder
 
mergeFrom(Block.DeleteBlockEntry) - Method in class alluxio.proto.journal.Block.DeleteBlockEntry.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class alluxio.proto.journal.Block.DeleteBlockEntry.Builder
 
mergeFrom(Message) - Method in class alluxio.proto.journal.File.AddMountPointEntry.Builder
 
mergeFrom(File.AddMountPointEntry) - Method in class alluxio.proto.journal.File.AddMountPointEntry.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class alluxio.proto.journal.File.AddMountPointEntry.Builder
 
mergeFrom(Message) - Method in class alluxio.proto.journal.File.AsyncPersistRequestEntry.Builder
 
mergeFrom(File.AsyncPersistRequestEntry) - Method in class alluxio.proto.journal.File.AsyncPersistRequestEntry.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class alluxio.proto.journal.File.AsyncPersistRequestEntry.Builder
 
mergeFrom(Message) - Method in class alluxio.proto.journal.File.CompleteFileEntry.Builder
 
mergeFrom(File.CompleteFileEntry) - Method in class alluxio.proto.journal.File.CompleteFileEntry.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class alluxio.proto.journal.File.CompleteFileEntry.Builder
 
mergeFrom(Message) - Method in class alluxio.proto.journal.File.DeleteFileEntry.Builder
 
mergeFrom(File.DeleteFileEntry) - Method in class alluxio.proto.journal.File.DeleteFileEntry.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class alluxio.proto.journal.File.DeleteFileEntry.Builder
 
mergeFrom(Message) - Method in class alluxio.proto.journal.File.DeleteMountPointEntry.Builder
 
mergeFrom(File.DeleteMountPointEntry) - Method in class alluxio.proto.journal.File.DeleteMountPointEntry.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class alluxio.proto.journal.File.DeleteMountPointEntry.Builder
 
mergeFrom(Message) - Method in class alluxio.proto.journal.File.InodeDirectoryEntry.Builder
 
mergeFrom(File.InodeDirectoryEntry) - Method in class alluxio.proto.journal.File.InodeDirectoryEntry.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class alluxio.proto.journal.File.InodeDirectoryEntry.Builder
 
mergeFrom(Message) - Method in class alluxio.proto.journal.File.InodeDirectoryIdGeneratorEntry.Builder
 
mergeFrom(File.InodeDirectoryIdGeneratorEntry) - Method in class alluxio.proto.journal.File.InodeDirectoryIdGeneratorEntry.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class alluxio.proto.journal.File.InodeDirectoryIdGeneratorEntry.Builder
 
mergeFrom(Message) - Method in class alluxio.proto.journal.File.InodeFileEntry.Builder
 
mergeFrom(File.InodeFileEntry) - Method in class alluxio.proto.journal.File.InodeFileEntry.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class alluxio.proto.journal.File.InodeFileEntry.Builder
 
mergeFrom(Message) - Method in class alluxio.proto.journal.File.InodeLastModificationTimeEntry.Builder
 
mergeFrom(File.InodeLastModificationTimeEntry) - Method in class alluxio.proto.journal.File.InodeLastModificationTimeEntry.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class alluxio.proto.journal.File.InodeLastModificationTimeEntry.Builder
 
mergeFrom(Message) - Method in class alluxio.proto.journal.File.PersistDirectoryEntry.Builder
 
mergeFrom(File.PersistDirectoryEntry) - Method in class alluxio.proto.journal.File.PersistDirectoryEntry.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class alluxio.proto.journal.File.PersistDirectoryEntry.Builder
 
mergeFrom(Message) - Method in class alluxio.proto.journal.File.PersistFileEntry.Builder
 
mergeFrom(File.PersistFileEntry) - Method in class alluxio.proto.journal.File.PersistFileEntry.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class alluxio.proto.journal.File.PersistFileEntry.Builder
 
mergeFrom(Message) - Method in class alluxio.proto.journal.File.ReinitializeFileEntry.Builder
 
mergeFrom(File.ReinitializeFileEntry) - Method in class alluxio.proto.journal.File.ReinitializeFileEntry.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class alluxio.proto.journal.File.ReinitializeFileEntry.Builder
 
mergeFrom(Message) - Method in class alluxio.proto.journal.File.RenameEntry.Builder
 
mergeFrom(File.RenameEntry) - Method in class alluxio.proto.journal.File.RenameEntry.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class alluxio.proto.journal.File.RenameEntry.Builder
 
mergeFrom(Message) - Method in class alluxio.proto.journal.File.SetAttributeEntry.Builder
 
mergeFrom(File.SetAttributeEntry) - Method in class alluxio.proto.journal.File.SetAttributeEntry.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class alluxio.proto.journal.File.SetAttributeEntry.Builder
 
mergeFrom(Message) - Method in class alluxio.proto.journal.File.StringPairEntry.Builder
 
mergeFrom(File.StringPairEntry) - Method in class alluxio.proto.journal.File.StringPairEntry.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class alluxio.proto.journal.File.StringPairEntry.Builder
 
mergeFrom(Message) - Method in class alluxio.proto.journal.File.UpdateUfsModeEntry.Builder
 
mergeFrom(File.UpdateUfsModeEntry) - Method in class alluxio.proto.journal.File.UpdateUfsModeEntry.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class alluxio.proto.journal.File.UpdateUfsModeEntry.Builder
 
mergeFrom(Message) - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
 
mergeFrom(Journal.JournalEntry) - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
 
mergeFrom(Message) - Method in class alluxio.proto.journal.KeyValue.CompletePartitionEntry.Builder
 
mergeFrom(KeyValue.CompletePartitionEntry) - Method in class alluxio.proto.journal.KeyValue.CompletePartitionEntry.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class alluxio.proto.journal.KeyValue.CompletePartitionEntry.Builder
 
mergeFrom(Message) - Method in class alluxio.proto.journal.KeyValue.CompleteStoreEntry.Builder
 
mergeFrom(KeyValue.CompleteStoreEntry) - Method in class alluxio.proto.journal.KeyValue.CompleteStoreEntry.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class alluxio.proto.journal.KeyValue.CompleteStoreEntry.Builder
 
mergeFrom(Message) - Method in class alluxio.proto.journal.KeyValue.CreateStoreEntry.Builder
 
mergeFrom(KeyValue.CreateStoreEntry) - Method in class alluxio.proto.journal.KeyValue.CreateStoreEntry.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class alluxio.proto.journal.KeyValue.CreateStoreEntry.Builder
 
mergeFrom(Message) - Method in class alluxio.proto.journal.KeyValue.DeleteStoreEntry.Builder
 
mergeFrom(KeyValue.DeleteStoreEntry) - Method in class alluxio.proto.journal.KeyValue.DeleteStoreEntry.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class alluxio.proto.journal.KeyValue.DeleteStoreEntry.Builder
 
mergeFrom(Message) - Method in class alluxio.proto.journal.KeyValue.MergeStoreEntry.Builder
 
mergeFrom(KeyValue.MergeStoreEntry) - Method in class alluxio.proto.journal.KeyValue.MergeStoreEntry.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class alluxio.proto.journal.KeyValue.MergeStoreEntry.Builder
 
mergeFrom(Message) - Method in class alluxio.proto.journal.KeyValue.RenameStoreEntry.Builder
 
mergeFrom(KeyValue.RenameStoreEntry) - Method in class alluxio.proto.journal.KeyValue.RenameStoreEntry.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class alluxio.proto.journal.KeyValue.RenameStoreEntry.Builder
 
mergeFrom(Message) - Method in class alluxio.proto.journal.Lineage.DeleteLineageEntry.Builder
 
mergeFrom(Lineage.DeleteLineageEntry) - Method in class alluxio.proto.journal.Lineage.DeleteLineageEntry.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class alluxio.proto.journal.Lineage.DeleteLineageEntry.Builder
 
mergeFrom(Message) - Method in class alluxio.proto.journal.Lineage.LineageEntry.Builder
 
mergeFrom(Lineage.LineageEntry) - Method in class alluxio.proto.journal.Lineage.LineageEntry.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class alluxio.proto.journal.Lineage.LineageEntry.Builder
 
mergeFrom(Message) - Method in class alluxio.proto.journal.Lineage.LineageIdGeneratorEntry.Builder
 
mergeFrom(Lineage.LineageIdGeneratorEntry) - Method in class alluxio.proto.journal.Lineage.LineageIdGeneratorEntry.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class alluxio.proto.journal.Lineage.LineageIdGeneratorEntry.Builder
 
mergeHadoopConfiguration(Configuration, AlluxioConfiguration) - Static method in class alluxio.hadoop.HadoopConfigurationUtils
Merges Hadoop Configuration into the Alluxio configuration.
mergeInodeDirectory(File.InodeDirectoryEntry) - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
optional .alluxio.proto.journal.InodeDirectoryEntry inode_directory = 9;
mergeInodeDirectoryIdGenerator(File.InodeDirectoryIdGeneratorEntry) - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
optional .alluxio.proto.journal.InodeDirectoryIdGeneratorEntry inode_directory_id_generator = 10;
mergeInodeFile(File.InodeFileEntry) - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
optional .alluxio.proto.journal.InodeFileEntry inode_file = 11;
mergeInodeLastModificationTime(File.InodeLastModificationTimeEntry) - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
optional .alluxio.proto.journal.InodeLastModificationTimeEntry inode_last_modification_time = 12;
mergeLineage(Lineage.LineageEntry) - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
optional .alluxio.proto.journal.LineageEntry lineage = 13;
mergeLineageIdGenerator(Lineage.LineageIdGeneratorEntry) - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
optional .alluxio.proto.journal.LineageIdGeneratorEntry lineage_id_generator = 14;
mergeMergeStore(KeyValue.MergeStoreEntry) - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
optional .alluxio.proto.journal.MergeStoreEntry merge_store = 26;
mergeOpenUfsBlockOptions(Protocol.OpenUfsBlockOptions) - Method in class alluxio.proto.dataserver.Protocol.AsyncCacheRequest.Builder
optional .alluxio.proto.dataserver.OpenUfsBlockOptions open_ufs_block_options = 4;
mergeOpenUfsBlockOptions(Protocol.OpenUfsBlockOptions) - Method in class alluxio.proto.dataserver.Protocol.ReadRequest.Builder
optional .alluxio.proto.dataserver.OpenUfsBlockOptions open_ufs_block_options = 6;
mergePersistDirectory(File.PersistDirectoryEntry) - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
optional .alluxio.proto.journal.PersistDirectoryEntry persist_directory = 15;
mergeReinitializeFile(File.ReinitializeFileEntry) - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
optional .alluxio.proto.journal.ReinitializeFileEntry reinitialize_file = 18;
mergeRename(File.RenameEntry) - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
optional .alluxio.proto.journal.RenameEntry rename = 19;
mergeRenameStore(KeyValue.RenameStoreEntry) - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
optional .alluxio.proto.journal.RenameStoreEntry rename_store = 28;
mergeSetAttribute(File.SetAttributeEntry) - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
optional .alluxio.proto.journal.SetAttributeEntry set_attribute = 27;
mergeStore(AlluxioURI, AlluxioURI) - Method in class alluxio.client.keyvalue.BaseKeyValueSystem
 
mergeStore(AlluxioURI, AlluxioURI) - Method in interface alluxio.client.keyvalue.KeyValueSystem
Merges one completed key-value store to another completed key-value store.
mergeStore(AlluxioURI, AlluxioURI) - Method in class alluxio.master.keyvalue.DefaultKeyValueMaster
 
mergeStore(AlluxioURI, AlluxioURI) - Method in interface alluxio.master.keyvalue.KeyValueMaster
Merges one completed key-value store to another completed key-value store.
mergeStore(String, String, MergeStoreTOptions) - Method in class alluxio.master.keyvalue.KeyValueMasterClientServiceHandler
 
mergeStore(String, String, MergeStoreTOptions, AsyncMethodCallback) - Method in class alluxio.thrift.KeyValueMasterClientService.AsyncClient
 
mergeStore(String, String, MergeStoreTOptions, AsyncMethodCallback) - Method in interface alluxio.thrift.KeyValueMasterClientService.AsyncIface
 
mergeStore() - Constructor for class alluxio.thrift.KeyValueMasterClientService.AsyncProcessor.mergeStore
 
mergeStore(String, String, MergeStoreTOptions) - Method in class alluxio.thrift.KeyValueMasterClientService.Client
 
mergeStore(String, String, MergeStoreTOptions) - Method in interface alluxio.thrift.KeyValueMasterClientService.Iface
Merges one completed key-value store to another completed key-value store.
mergeStore() - Constructor for class alluxio.thrift.KeyValueMasterClientService.Processor.mergeStore
 
mergeStore_args() - Constructor for class alluxio.thrift.KeyValueMasterClientService.mergeStore_args
 
mergeStore_args(String, String, MergeStoreTOptions) - Constructor for class alluxio.thrift.KeyValueMasterClientService.mergeStore_args
 
mergeStore_args(KeyValueMasterClientService.mergeStore_args) - Constructor for class alluxio.thrift.KeyValueMasterClientService.mergeStore_args
Performs a deep copy on other.
mergeStore_call(String, String, MergeStoreTOptions, AsyncMethodCallback, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class alluxio.thrift.KeyValueMasterClientService.AsyncClient.mergeStore_call
 
mergeStore_result() - Constructor for class alluxio.thrift.KeyValueMasterClientService.mergeStore_result
 
mergeStore_result(MergeStoreTResponse, AlluxioTException) - Constructor for class alluxio.thrift.KeyValueMasterClientService.mergeStore_result
 
mergeStore_result(KeyValueMasterClientService.mergeStore_result) - Constructor for class alluxio.thrift.KeyValueMasterClientService.mergeStore_result
Performs a deep copy on other.
MergeStoreTOptions - Class in alluxio.thrift
 
MergeStoreTOptions() - Constructor for class alluxio.thrift.MergeStoreTOptions
 
MergeStoreTOptions(MergeStoreTOptions) - Constructor for class alluxio.thrift.MergeStoreTOptions
Performs a deep copy on other.
MergeStoreTOptions._Fields - Enum in alluxio.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
MergeStoreTResponse - Class in alluxio.thrift
 
MergeStoreTResponse() - Constructor for class alluxio.thrift.MergeStoreTResponse
 
MergeStoreTResponse(MergeStoreTResponse) - Constructor for class alluxio.thrift.MergeStoreTResponse
Performs a deep copy on other.
MergeStoreTResponse._Fields - Enum in alluxio.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
mergeUpdateUfsMode(File.UpdateUfsModeEntry) - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
optional .alluxio.proto.journal.UpdateUfsModeEntry update_ufs_mode = 30;
MESOS_LOCAL_INSTALL - Static variable in class alluxio.Constants
 
MESOS_RESOURCE_CPUS - Static variable in class alluxio.Constants
 
MESOS_RESOURCE_DISK - Static variable in class alluxio.Constants
 
MESOS_RESOURCE_MEM - Static variable in class alluxio.Constants
 
MESOS_RESOURCE_PORTS - Static variable in class alluxio.Constants
 
MESSAGE_FIELD_NUMBER - Static variable in class alluxio.proto.dataserver.Protocol.Response
 
META_MASTER_CLIENT_SERVICE_NAME - Static variable in class alluxio.Constants
 
META_MASTER_CLIENT_SERVICE_VERSION - Static variable in class alluxio.Constants
 
META_MASTER_MASTER_SERVICE_NAME - Static variable in class alluxio.Constants
 
META_MASTER_MASTER_SERVICE_VERSION - Static variable in class alluxio.Constants
 
META_MASTER_NAME - Static variable in class alluxio.Constants
 
META_MASTER_SYNC - Static variable in class alluxio.heartbeat.HeartbeatContext
 
MetaCommand - Enum in alluxio.thrift
 
metaDataMap - Static variable in class alluxio.thrift.AccessBlockTOptions
 
metaDataMap - Static variable in class alluxio.thrift.AccessBlockTResponse
 
metaDataMap - Static variable in class alluxio.thrift.AlluxioService.getServiceVersion_args
 
metaDataMap - Static variable in class alluxio.thrift.AlluxioService.getServiceVersion_result
 
metaDataMap - Static variable in exception alluxio.thrift.AlluxioTException
 
metaDataMap - Static variable in class alluxio.thrift.BackupTOptions
 
metaDataMap - Static variable in class alluxio.thrift.BackupTResponse
 
metaDataMap - Static variable in class alluxio.thrift.BlockHeartbeatTOptions
 
metaDataMap - Static variable in class alluxio.thrift.BlockHeartbeatTResponse
 
metaDataMap - Static variable in class alluxio.thrift.BlockInfo
 
metaDataMap - Static variable in class alluxio.thrift.BlockLocation
 
metaDataMap - Static variable in class alluxio.thrift.BlockMasterClientService.getBlockInfo_args
 
metaDataMap - Static variable in class alluxio.thrift.BlockMasterClientService.getBlockInfo_result
 
metaDataMap - Static variable in class alluxio.thrift.BlockMasterClientService.getBlockMasterInfo_args
 
metaDataMap - Static variable in class alluxio.thrift.BlockMasterClientService.getBlockMasterInfo_result
 
metaDataMap - Static variable in class alluxio.thrift.BlockMasterClientService.getCapacityBytes_args
 
metaDataMap - Static variable in class alluxio.thrift.BlockMasterClientService.getCapacityBytes_result
 
metaDataMap - Static variable in class alluxio.thrift.BlockMasterClientService.getUsedBytes_args
 
metaDataMap - Static variable in class alluxio.thrift.BlockMasterClientService.getUsedBytes_result
 
metaDataMap - Static variable in class alluxio.thrift.BlockMasterClientService.getWorkerInfoList_args
 
metaDataMap - Static variable in class alluxio.thrift.BlockMasterClientService.getWorkerInfoList_result
 
metaDataMap - Static variable in class alluxio.thrift.BlockMasterClientService.getWorkerReport_args
 
metaDataMap - Static variable in class alluxio.thrift.BlockMasterClientService.getWorkerReport_result
 
metaDataMap - Static variable in class alluxio.thrift.BlockMasterInfo
 
metaDataMap - Static variable in class alluxio.thrift.BlockMasterWorkerService.blockHeartbeat_args
 
metaDataMap - Static variable in class alluxio.thrift.BlockMasterWorkerService.blockHeartbeat_result
 
metaDataMap - Static variable in class alluxio.thrift.BlockMasterWorkerService.commitBlock_args
 
metaDataMap - Static variable in class alluxio.thrift.BlockMasterWorkerService.commitBlock_result
 
metaDataMap - Static variable in class alluxio.thrift.BlockMasterWorkerService.getWorkerId_args
 
metaDataMap - Static variable in class alluxio.thrift.BlockMasterWorkerService.getWorkerId_result
 
metaDataMap - Static variable in class alluxio.thrift.BlockMasterWorkerService.registerWorker_args
 
metaDataMap - Static variable in class alluxio.thrift.BlockMasterWorkerService.registerWorker_result
 
metaDataMap - Static variable in class alluxio.thrift.BlockWorkerClientService.accessBlock_args
 
metaDataMap - Static variable in class alluxio.thrift.BlockWorkerClientService.accessBlock_result
 
metaDataMap - Static variable in class alluxio.thrift.BlockWorkerClientService.cacheBlock_args
 
metaDataMap - Static variable in class alluxio.thrift.BlockWorkerClientService.cacheBlock_result
 
metaDataMap - Static variable in class alluxio.thrift.BlockWorkerClientService.cancelBlock_args
 
metaDataMap - Static variable in class alluxio.thrift.BlockWorkerClientService.cancelBlock_result
 
metaDataMap - Static variable in class alluxio.thrift.BlockWorkerClientService.lockBlock_args
 
metaDataMap - Static variable in class alluxio.thrift.BlockWorkerClientService.lockBlock_result
 
metaDataMap - Static variable in class alluxio.thrift.BlockWorkerClientService.promoteBlock_args
 
metaDataMap - Static variable in class alluxio.thrift.BlockWorkerClientService.promoteBlock_result
 
metaDataMap - Static variable in class alluxio.thrift.BlockWorkerClientService.removeBlock_args
 
metaDataMap - Static variable in class alluxio.thrift.BlockWorkerClientService.removeBlock_result
 
metaDataMap - Static variable in class alluxio.thrift.BlockWorkerClientService.requestBlockLocation_args
 
metaDataMap - Static variable in class alluxio.thrift.BlockWorkerClientService.requestBlockLocation_result
 
metaDataMap - Static variable in class alluxio.thrift.BlockWorkerClientService.requestSpace_args
 
metaDataMap - Static variable in class alluxio.thrift.BlockWorkerClientService.requestSpace_result
 
metaDataMap - Static variable in class alluxio.thrift.BlockWorkerClientService.sessionBlockHeartbeat_args
 
metaDataMap - Static variable in class alluxio.thrift.BlockWorkerClientService.sessionBlockHeartbeat_result
 
metaDataMap - Static variable in class alluxio.thrift.BlockWorkerClientService.unlockBlock_args
 
metaDataMap - Static variable in class alluxio.thrift.BlockWorkerClientService.unlockBlock_result
 
metaDataMap - Static variable in class alluxio.thrift.CacheBlockTOptions
 
metaDataMap - Static variable in class alluxio.thrift.CacheBlockTResponse
 
metaDataMap - Static variable in class alluxio.thrift.CancelBlockTOptions
 
metaDataMap - Static variable in class alluxio.thrift.CancelBlockTResponse
 
metaDataMap - Static variable in class alluxio.thrift.CancelUfsFileTOptions
 
metaDataMap - Static variable in class alluxio.thrift.CancelUfsFileTResponse
 
metaDataMap - Static variable in class alluxio.thrift.CheckConsistencyTOptions
 
metaDataMap - Static variable in class alluxio.thrift.CheckConsistencyTResponse
 
metaDataMap - Static variable in class alluxio.thrift.CloseUfsFileTOptions
 
metaDataMap - Static variable in class alluxio.thrift.CloseUfsFileTResponse
 
metaDataMap - Static variable in class alluxio.thrift.Command
 
metaDataMap - Static variable in class alluxio.thrift.CommandLineJobInfo
 
metaDataMap - Static variable in class alluxio.thrift.CommitBlockTOptions
 
metaDataMap - Static variable in class alluxio.thrift.CommitBlockTResponse
 
metaDataMap - Static variable in class alluxio.thrift.CompleteFileTOptions
 
metaDataMap - Static variable in class alluxio.thrift.CompleteFileTResponse
 
metaDataMap - Static variable in class alluxio.thrift.CompletePartitionTOptions
 
metaDataMap - Static variable in class alluxio.thrift.CompletePartitionTResponse
 
metaDataMap - Static variable in class alluxio.thrift.CompleteStoreTOptions
 
metaDataMap - Static variable in class alluxio.thrift.CompleteStoreTResponse
 
metaDataMap - Static variable in class alluxio.thrift.CompleteUfsFileTOptions
 
metaDataMap - Static variable in class alluxio.thrift.CompleteUfsFileTReponse
 
metaDataMap - Static variable in class alluxio.thrift.ConfigCheckReport
 
metaDataMap - Static variable in class alluxio.thrift.ConfigProperty
 
metaDataMap - Static variable in class alluxio.thrift.CreateDirectoryTOptions
 
metaDataMap - Static variable in class alluxio.thrift.CreateDirectoryTResponse
 
metaDataMap - Static variable in class alluxio.thrift.CreateFileTOptions
 
metaDataMap - Static variable in class alluxio.thrift.CreateFileTResponse
 
metaDataMap - Static variable in class alluxio.thrift.CreateLineageTOptions
 
metaDataMap - Static variable in class alluxio.thrift.CreateLineageTResponse
 
metaDataMap - Static variable in class alluxio.thrift.CreateStoreTOptions
 
metaDataMap - Static variable in class alluxio.thrift.CreateStoreTResponse
 
metaDataMap - Static variable in class alluxio.thrift.CreateUfsFileTOptions
 
metaDataMap - Static variable in class alluxio.thrift.CreateUfsFileTResponse
 
metaDataMap - Static variable in class alluxio.thrift.DeleteLineageTOptions
 
metaDataMap - Static variable in class alluxio.thrift.DeleteLineageTResponse
 
metaDataMap - Static variable in class alluxio.thrift.DeleteStoreTOptions
 
metaDataMap - Static variable in class alluxio.thrift.DeleteStoreTResponse
 
metaDataMap - Static variable in class alluxio.thrift.DeleteTOptions
 
metaDataMap - Static variable in class alluxio.thrift.DeleteTResponse
 
metaDataMap - Static variable in class alluxio.thrift.DependencyInfo
 
metaDataMap - Static variable in class alluxio.thrift.FileBlockInfo
 
metaDataMap - Static variable in class alluxio.thrift.FileInfo
 
metaDataMap - Static variable in class alluxio.thrift.FileSystemCommand
 
metaDataMap - Static variable in class alluxio.thrift.FileSystemCommandOptions
 
metaDataMap - Static variable in class alluxio.thrift.FileSystemHeartbeatTOptions
 
metaDataMap - Static variable in class alluxio.thrift.FileSystemHeartbeatTResponse
 
metaDataMap - Static variable in class alluxio.thrift.FileSystemMasterClientService.checkConsistency_args
 
metaDataMap - Static variable in class alluxio.thrift.FileSystemMasterClientService.checkConsistency_result
 
metaDataMap - Static variable in class alluxio.thrift.FileSystemMasterClientService.completeFile_args
 
metaDataMap - Static variable in class alluxio.thrift.FileSystemMasterClientService.completeFile_result
 
metaDataMap - Static variable in class alluxio.thrift.FileSystemMasterClientService.createDirectory_args
 
metaDataMap - Static variable in class alluxio.thrift.FileSystemMasterClientService.createDirectory_result
 
metaDataMap - Static variable in class alluxio.thrift.FileSystemMasterClientService.createFile_args
 
metaDataMap - Static variable in class alluxio.thrift.FileSystemMasterClientService.createFile_result
 
metaDataMap - Static variable in class alluxio.thrift.FileSystemMasterClientService.free_args
 
metaDataMap - Static variable in class alluxio.thrift.FileSystemMasterClientService.free_result
 
metaDataMap - Static variable in class alluxio.thrift.FileSystemMasterClientService.getFilePath_args
 
metaDataMap - Static variable in class alluxio.thrift.FileSystemMasterClientService.getFilePath_result
 
metaDataMap - Static variable in class alluxio.thrift.FileSystemMasterClientService.getMountTable_args
 
metaDataMap - Static variable in class alluxio.thrift.FileSystemMasterClientService.getMountTable_result
 
metaDataMap - Static variable in class alluxio.thrift.FileSystemMasterClientService.getNewBlockIdForFile_args
 
metaDataMap - Static variable in class alluxio.thrift.FileSystemMasterClientService.getNewBlockIdForFile_result
 
metaDataMap - Static variable in class alluxio.thrift.FileSystemMasterClientService.getStatus_args
 
metaDataMap - Static variable in class alluxio.thrift.FileSystemMasterClientService.getStatus_result
 
metaDataMap - Static variable in class alluxio.thrift.FileSystemMasterClientService.listStatus_args
 
metaDataMap - Static variable in class alluxio.thrift.FileSystemMasterClientService.listStatus_result
 
metaDataMap - Static variable in class alluxio.thrift.FileSystemMasterClientService.loadMetadata_args
 
metaDataMap - Static variable in class alluxio.thrift.FileSystemMasterClientService.loadMetadata_result
 
metaDataMap - Static variable in class alluxio.thrift.FileSystemMasterClientService.mount_args
 
metaDataMap - Static variable in class alluxio.thrift.FileSystemMasterClientService.mount_result
 
metaDataMap - Static variable in class alluxio.thrift.FileSystemMasterClientService.remove_args
 
metaDataMap - Static variable in class alluxio.thrift.FileSystemMasterClientService.remove_result
 
metaDataMap - Static variable in class alluxio.thrift.FileSystemMasterClientService.rename_args
 
metaDataMap - Static variable in class alluxio.thrift.FileSystemMasterClientService.rename_result
 
metaDataMap - Static variable in class alluxio.thrift.FileSystemMasterClientService.scheduleAsyncPersistence_args
 
metaDataMap - Static variable in class alluxio.thrift.FileSystemMasterClientService.scheduleAsyncPersistence_result
 
metaDataMap - Static variable in class alluxio.thrift.FileSystemMasterClientService.setAttribute_args
 
metaDataMap - Static variable in class alluxio.thrift.FileSystemMasterClientService.setAttribute_result
 
metaDataMap - Static variable in class alluxio.thrift.FileSystemMasterClientService.unmount_args
 
metaDataMap - Static variable in class alluxio.thrift.FileSystemMasterClientService.unmount_result
 
metaDataMap - Static variable in class alluxio.thrift.FileSystemMasterClientService.updateUfsMode_args
 
metaDataMap - Static variable in class alluxio.thrift.FileSystemMasterClientService.updateUfsMode_result
 
metaDataMap - Static variable in class alluxio.thrift.FileSystemMasterCommonTOptions
 
metaDataMap - Static variable in class alluxio.thrift.FileSystemMasterWorkerService.fileSystemHeartbeat_args
 
metaDataMap - Static variable in class alluxio.thrift.FileSystemMasterWorkerService.fileSystemHeartbeat_result
 
metaDataMap - Static variable in class alluxio.thrift.FileSystemMasterWorkerService.getFileInfo_args
 
metaDataMap - Static variable in class alluxio.thrift.FileSystemMasterWorkerService.getFileInfo_result
 
metaDataMap - Static variable in class alluxio.thrift.FileSystemMasterWorkerService.getPinnedFileIds_args
 
metaDataMap - Static variable in class alluxio.thrift.FileSystemMasterWorkerService.getPinnedFileIds_result
 
metaDataMap - Static variable in class alluxio.thrift.FileSystemMasterWorkerService.getUfsInfo_args
 
metaDataMap - Static variable in class alluxio.thrift.FileSystemMasterWorkerService.getUfsInfo_result
 
metaDataMap - Static variable in class alluxio.thrift.FileSystemWorkerClientService.cancelUfsFile_args
 
metaDataMap - Static variable in class alluxio.thrift.FileSystemWorkerClientService.cancelUfsFile_result
 
metaDataMap - Static variable in class alluxio.thrift.FileSystemWorkerClientService.closeUfsFile_args
 
metaDataMap - Static variable in class alluxio.thrift.FileSystemWorkerClientService.closeUfsFile_result
 
metaDataMap - Static variable in class alluxio.thrift.FileSystemWorkerClientService.completeUfsFile_args
 
metaDataMap - Static variable in class alluxio.thrift.FileSystemWorkerClientService.completeUfsFile_result
 
metaDataMap - Static variable in class alluxio.thrift.FileSystemWorkerClientService.createUfsFile_args
 
metaDataMap - Static variable in class alluxio.thrift.FileSystemWorkerClientService.createUfsFile_result
 
metaDataMap - Static variable in class alluxio.thrift.FileSystemWorkerClientService.openUfsFile_args
 
metaDataMap - Static variable in class alluxio.thrift.FileSystemWorkerClientService.openUfsFile_result
 
metaDataMap - Static variable in class alluxio.thrift.FileSystemWorkerClientService.sessionFileSystemHeartbeat_args
 
metaDataMap - Static variable in class alluxio.thrift.FileSystemWorkerClientService.sessionFileSystemHeartbeat_result
 
metaDataMap - Static variable in class alluxio.thrift.FreeTOptions
 
metaDataMap - Static variable in class alluxio.thrift.FreeTResponse
 
metaDataMap - Static variable in class alluxio.thrift.GetBlockInfoTOptions
 
metaDataMap - Static variable in class alluxio.thrift.GetBlockInfoTResponse
 
metaDataMap - Static variable in class alluxio.thrift.GetBlockMasterInfoTOptions
 
metaDataMap - Static variable in class alluxio.thrift.GetBlockMasterInfoTResponse
 
metaDataMap - Static variable in class alluxio.thrift.GetCapacityBytesTOptions
 
metaDataMap - Static variable in class alluxio.thrift.GetCapacityBytesTResponse
 
metaDataMap - Static variable in class alluxio.thrift.GetConfigReportTOptions
 
metaDataMap - Static variable in class alluxio.thrift.GetConfigReportTResponse
 
metaDataMap - Static variable in class alluxio.thrift.GetConfigurationTOptions
 
metaDataMap - Static variable in class alluxio.thrift.GetConfigurationTResponse
 
metaDataMap - Static variable in class alluxio.thrift.GetFileInfoTOptions
 
metaDataMap - Static variable in class alluxio.thrift.GetFileInfoTResponse
 
metaDataMap - Static variable in class alluxio.thrift.GetFilePathTOptions
 
metaDataMap - Static variable in class alluxio.thrift.GetFilePathTResponse
 
metaDataMap - Static variable in class alluxio.thrift.GetLineageInfoListTOptions
 
metaDataMap - Static variable in class alluxio.thrift.GetLineageInfoListTResponse
 
metaDataMap - Static variable in class alluxio.thrift.GetMasterIdTOptions
 
metaDataMap - Static variable in class alluxio.thrift.GetMasterIdTResponse
 
metaDataMap - Static variable in class alluxio.thrift.GetMasterInfoTOptions
 
metaDataMap - Static variable in class alluxio.thrift.GetMasterInfoTResponse
 
metaDataMap - Static variable in class alluxio.thrift.GetMetricsTOptions
 
metaDataMap - Static variable in class alluxio.thrift.GetMetricsTResponse
 
metaDataMap - Static variable in class alluxio.thrift.GetMountTableTResponse
 
metaDataMap - Static variable in class alluxio.thrift.GetNewBlockIdForFileTOptions
 
metaDataMap - Static variable in class alluxio.thrift.GetNewBlockIdForFileTResponse
 
metaDataMap - Static variable in class alluxio.thrift.GetNextKeysTOptions
 
metaDataMap - Static variable in class alluxio.thrift.GetNextKeysTResponse
 
metaDataMap - Static variable in class alluxio.thrift.GetPartitionInfoTOptions
 
metaDataMap - Static variable in class alluxio.thrift.GetPartitionInfoTResponse
 
metaDataMap - Static variable in class alluxio.thrift.GetPinnedFileIdsTOptions
 
metaDataMap - Static variable in class alluxio.thrift.GetPinnedFileIdsTResponse
 
metaDataMap - Static variable in class alluxio.thrift.GetServiceVersionTOptions
 
metaDataMap - Static variable in class alluxio.thrift.GetServiceVersionTResponse
 
metaDataMap - Static variable in class alluxio.thrift.GetSizeTOptions
 
metaDataMap - Static variable in class alluxio.thrift.GetSizeTResponse
 
metaDataMap - Static variable in class alluxio.thrift.GetStatusTOptions
 
metaDataMap - Static variable in class alluxio.thrift.GetStatusTResponse
 
metaDataMap - Static variable in class alluxio.thrift.GetTOptions
 
metaDataMap - Static variable in class alluxio.thrift.GetTResponse
 
metaDataMap - Static variable in class alluxio.thrift.GetUfsInfoTOptions
 
metaDataMap - Static variable in class alluxio.thrift.GetUfsInfoTResponse
 
metaDataMap - Static variable in class alluxio.thrift.GetUsedBytesTOptions
 
metaDataMap - Static variable in class alluxio.thrift.GetUsedBytesTResponse
 
metaDataMap - Static variable in class alluxio.thrift.GetWorkerIdTOptions
 
metaDataMap - Static variable in class alluxio.thrift.GetWorkerIdTResponse
 
metaDataMap - Static variable in class alluxio.thrift.GetWorkerInfoListTOptions
 
metaDataMap - Static variable in class alluxio.thrift.GetWorkerInfoListTResponse
 
metaDataMap - Static variable in class alluxio.thrift.GetWorkerReportTOptions
 
metaDataMap - Static variable in class alluxio.thrift.InconsistentProperty
 
metaDataMap - Static variable in class alluxio.thrift.JobConfInfo
 
metaDataMap - Static variable in class alluxio.thrift.KeyValueMasterClientService.completePartition_args
 
metaDataMap - Static variable in class alluxio.thrift.KeyValueMasterClientService.completePartition_result
 
metaDataMap - Static variable in class alluxio.thrift.KeyValueMasterClientService.completeStore_args
 
metaDataMap - Static variable in class alluxio.thrift.KeyValueMasterClientService.completeStore_result
 
metaDataMap - Static variable in class alluxio.thrift.KeyValueMasterClientService.createStore_args
 
metaDataMap - Static variable in class alluxio.thrift.KeyValueMasterClientService.createStore_result
 
metaDataMap - Static variable in class alluxio.thrift.KeyValueMasterClientService.deleteStore_args
 
metaDataMap - Static variable in class alluxio.thrift.KeyValueMasterClientService.deleteStore_result
 
metaDataMap - Static variable in class alluxio.thrift.KeyValueMasterClientService.getPartitionInfo_args
 
metaDataMap - Static variable in class alluxio.thrift.KeyValueMasterClientService.getPartitionInfo_result
 
metaDataMap - Static variable in class alluxio.thrift.KeyValueMasterClientService.mergeStore_args
 
metaDataMap - Static variable in class alluxio.thrift.KeyValueMasterClientService.mergeStore_result
 
metaDataMap - Static variable in class alluxio.thrift.KeyValueMasterClientService.renameStore_args
 
metaDataMap - Static variable in class alluxio.thrift.KeyValueMasterClientService.renameStore_result
 
metaDataMap - Static variable in class alluxio.thrift.KeyValueWorkerClientService.get_args
 
metaDataMap - Static variable in class alluxio.thrift.KeyValueWorkerClientService.get_result
 
metaDataMap - Static variable in class alluxio.thrift.KeyValueWorkerClientService.getNextKeys_args
 
metaDataMap - Static variable in class alluxio.thrift.KeyValueWorkerClientService.getNextKeys_result
 
metaDataMap - Static variable in class alluxio.thrift.KeyValueWorkerClientService.getSize_args
 
metaDataMap - Static variable in class alluxio.thrift.KeyValueWorkerClientService.getSize_result
 
metaDataMap - Static variable in class alluxio.thrift.LineageInfo
 
metaDataMap - Static variable in class alluxio.thrift.LineageMasterClientService.createLineage_args
 
metaDataMap - Static variable in class alluxio.thrift.LineageMasterClientService.createLineage_result
 
metaDataMap - Static variable in class alluxio.thrift.LineageMasterClientService.deleteLineage_args
 
metaDataMap - Static variable in class alluxio.thrift.LineageMasterClientService.deleteLineage_result
 
metaDataMap - Static variable in class alluxio.thrift.LineageMasterClientService.getLineageInfoList_args
 
metaDataMap - Static variable in class alluxio.thrift.LineageMasterClientService.getLineageInfoList_result
 
metaDataMap - Static variable in class alluxio.thrift.LineageMasterClientService.reinitializeFile_args
 
metaDataMap - Static variable in class alluxio.thrift.LineageMasterClientService.reinitializeFile_result
 
metaDataMap - Static variable in class alluxio.thrift.LineageMasterClientService.reportLostFile_args
 
metaDataMap - Static variable in class alluxio.thrift.LineageMasterClientService.reportLostFile_result
 
metaDataMap - Static variable in class alluxio.thrift.ListStatusTOptions
 
metaDataMap - Static variable in class alluxio.thrift.ListStatusTResponse
 
metaDataMap - Static variable in class alluxio.thrift.LoadMetadataTOptions
 
metaDataMap - Static variable in class alluxio.thrift.LoadMetadataTResponse
 
metaDataMap - Static variable in class alluxio.thrift.LocalityTier
 
metaDataMap - Static variable in class alluxio.thrift.LockBlockTOptions
 
metaDataMap - Static variable in class alluxio.thrift.LockBlockTResponse
 
metaDataMap - Static variable in class alluxio.thrift.MasterHeartbeatTOptions
 
metaDataMap - Static variable in class alluxio.thrift.MasterHeartbeatTResponse
 
metaDataMap - Static variable in class alluxio.thrift.MasterInfo
 
metaDataMap - Static variable in class alluxio.thrift.MasterNetAddress
 
metaDataMap - Static variable in class alluxio.thrift.MergeStoreTOptions
 
metaDataMap - Static variable in class alluxio.thrift.MergeStoreTResponse
 
metaDataMap - Static variable in class alluxio.thrift.MetaMasterClientService.backup_args
 
metaDataMap - Static variable in class alluxio.thrift.MetaMasterClientService.backup_result
 
metaDataMap - Static variable in class alluxio.thrift.MetaMasterClientService.getConfigReport_args
 
metaDataMap - Static variable in class alluxio.thrift.MetaMasterClientService.getConfigReport_result
 
metaDataMap - Static variable in class alluxio.thrift.MetaMasterClientService.getConfiguration_args
 
metaDataMap - Static variable in class alluxio.thrift.MetaMasterClientService.getConfiguration_result
 
metaDataMap - Static variable in class alluxio.thrift.MetaMasterClientService.getMasterInfo_args
 
metaDataMap - Static variable in class alluxio.thrift.MetaMasterClientService.getMasterInfo_result
 
metaDataMap - Static variable in class alluxio.thrift.MetaMasterClientService.getMetrics_args
 
metaDataMap - Static variable in class alluxio.thrift.MetaMasterClientService.getMetrics_result
 
metaDataMap - Static variable in class alluxio.thrift.MetaMasterMasterService.getMasterId_args
 
metaDataMap - Static variable in class alluxio.thrift.MetaMasterMasterService.getMasterId_result
 
metaDataMap - Static variable in class alluxio.thrift.MetaMasterMasterService.masterHeartbeat_args
 
metaDataMap - Static variable in class alluxio.thrift.MetaMasterMasterService.masterHeartbeat_result
 
metaDataMap - Static variable in class alluxio.thrift.MetaMasterMasterService.registerMaster_args
 
metaDataMap - Static variable in class alluxio.thrift.MetaMasterMasterService.registerMaster_result
 
metaDataMap - Static variable in class alluxio.thrift.Metric
 
metaDataMap - Static variable in class alluxio.thrift.MetricsHeartbeatTOptions
 
metaDataMap - Static variable in class alluxio.thrift.MetricsHeartbeatTResponse
 
metaDataMap - Static variable in class alluxio.thrift.MetricsMasterClientService.metricsHeartbeat_args
 
metaDataMap - Static variable in class alluxio.thrift.MetricsMasterClientService.metricsHeartbeat_result
 
metaDataMap - Static variable in class alluxio.thrift.MetricValue
 
metaDataMap - Static variable in class alluxio.thrift.MountPointInfo
 
metaDataMap - Static variable in class alluxio.thrift.MountTOptions
 
metaDataMap - Static variable in class alluxio.thrift.MountTResponse
 
metaDataMap - Static variable in class alluxio.thrift.OpenUfsFileTOptions
 
metaDataMap - Static variable in class alluxio.thrift.OpenUfsFileTResponse
 
metaDataMap - Static variable in class alluxio.thrift.OptionalString
 
metaDataMap - Static variable in class alluxio.thrift.PartitionInfo
 
metaDataMap - Static variable in class alluxio.thrift.PersistCommandOptions
 
metaDataMap - Static variable in class alluxio.thrift.PersistFile
 
metaDataMap - Static variable in class alluxio.thrift.PromoteBlockTOptions
 
metaDataMap - Static variable in class alluxio.thrift.PromoteBlockTResponse
 
metaDataMap - Static variable in class alluxio.thrift.RegisterMasterTOptions
 
metaDataMap - Static variable in class alluxio.thrift.RegisterMasterTResponse
 
metaDataMap - Static variable in class alluxio.thrift.RegisterWorkerTOptions
 
metaDataMap - Static variable in class alluxio.thrift.RegisterWorkerTResponse
 
metaDataMap - Static variable in class alluxio.thrift.ReinitializeFileTOptions
 
metaDataMap - Static variable in class alluxio.thrift.ReinitializeFileTResponse
 
metaDataMap - Static variable in class alluxio.thrift.RemoveBlockTOptions
 
metaDataMap - Static variable in class alluxio.thrift.RemoveBlockTResponse
 
metaDataMap - Static variable in class alluxio.thrift.RenameStoreTOptions
 
metaDataMap - Static variable in class alluxio.thrift.RenameStoreTResponse
 
metaDataMap - Static variable in class alluxio.thrift.RenameTOptions
 
metaDataMap - Static variable in class alluxio.thrift.RenameTResponse
 
metaDataMap - Static variable in class alluxio.thrift.ReportLostFileTOptions
 
metaDataMap - Static variable in class alluxio.thrift.ReportLostFileTResponse
 
metaDataMap - Static variable in class alluxio.thrift.RequestBlockLocationTOptions
 
metaDataMap - Static variable in class alluxio.thrift.RequestBlockLocationTResponse
 
metaDataMap - Static variable in class alluxio.thrift.RequestSpaceTOptions
 
metaDataMap - Static variable in class alluxio.thrift.RequestSpaceTResponse
 
metaDataMap - Static variable in class alluxio.thrift.ScheduleAsyncPersistenceTOptions
 
metaDataMap - Static variable in class alluxio.thrift.ScheduleAsyncPersistenceTResponse
 
metaDataMap - Static variable in class alluxio.thrift.SessionBlockHeartbeatTOptions
 
metaDataMap - Static variable in class alluxio.thrift.SessionBlockHeartbeatTResponse
 
metaDataMap - Static variable in class alluxio.thrift.SessionFileSystemHeartbeatTOptions
 
metaDataMap - Static variable in class alluxio.thrift.SessionFileSystemHeartbeatTResponse
 
metaDataMap - Static variable in class alluxio.thrift.SetAttributeTOptions
 
metaDataMap - Static variable in class alluxio.thrift.SetAttributeTResponse
 
metaDataMap - Static variable in class alluxio.thrift.SyncMetadataTOptions
 
metaDataMap - Static variable in class alluxio.thrift.SyncMetadataTResponse
 
metaDataMap - Static variable in class alluxio.thrift.TieredIdentity
 
metaDataMap - Static variable in class alluxio.thrift.UfsInfo
 
metaDataMap - Static variable in class alluxio.thrift.UnlockBlockTOptions
 
metaDataMap - Static variable in class alluxio.thrift.UnlockBlockTResponse
 
metaDataMap - Static variable in class alluxio.thrift.UnmountTOptions
 
metaDataMap - Static variable in class alluxio.thrift.UnmountTResponse
 
metaDataMap - Static variable in class alluxio.thrift.UpdateUfsModeTOptions
 
metaDataMap - Static variable in class alluxio.thrift.UpdateUfsModeTResponse
 
metaDataMap - Static variable in class alluxio.thrift.WorkerInfo
 
metaDataMap - Static variable in class alluxio.thrift.WorkerNetAddress
 
MetaMaster - Interface in alluxio.master.meta
The interface of meta master.
MetaMasterClient - Interface in alluxio.client
Interface for a meta master client.
MetaMasterClientService - Class in alluxio.thrift
 
MetaMasterClientService() - Constructor for class alluxio.thrift.MetaMasterClientService
 
MetaMasterClientService.AsyncClient - Class in alluxio.thrift
 
MetaMasterClientService.AsyncClient.backup_call - Class in alluxio.thrift
 
MetaMasterClientService.AsyncClient.Factory - Class in alluxio.thrift
 
MetaMasterClientService.AsyncClient.getConfigReport_call - Class in alluxio.thrift
 
MetaMasterClientService.AsyncClient.getConfiguration_call - Class in alluxio.thrift
 
MetaMasterClientService.AsyncClient.getMasterInfo_call - Class in alluxio.thrift
 
MetaMasterClientService.AsyncClient.getMetrics_call - Class in alluxio.thrift
 
MetaMasterClientService.AsyncIface - Interface in alluxio.thrift
 
MetaMasterClientService.AsyncProcessor<I extends MetaMasterClientService.AsyncIface> - Class in alluxio.thrift
 
MetaMasterClientService.AsyncProcessor.backup<I extends MetaMasterClientService.AsyncIface> - Class in alluxio.thrift
 
MetaMasterClientService.AsyncProcessor.getConfigReport<I extends MetaMasterClientService.AsyncIface> - Class in alluxio.thrift
 
MetaMasterClientService.AsyncProcessor.getConfiguration<I extends MetaMasterClientService.AsyncIface> - Class in alluxio.thrift
 
MetaMasterClientService.AsyncProcessor.getMasterInfo<I extends MetaMasterClientService.AsyncIface> - Class in alluxio.thrift
 
MetaMasterClientService.AsyncProcessor.getMetrics<I extends MetaMasterClientService.AsyncIface> - Class in alluxio.thrift
 
MetaMasterClientService.backup_args - Class in alluxio.thrift
 
MetaMasterClientService.backup_args._Fields - Enum in alluxio.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
MetaMasterClientService.backup_result - Class in alluxio.thrift
 
MetaMasterClientService.backup_result._Fields - Enum in alluxio.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
MetaMasterClientService.Client - Class in alluxio.thrift
 
MetaMasterClientService.Client.Factory - Class in alluxio.thrift
 
MetaMasterClientService.getConfigReport_args - Class in alluxio.thrift
 
MetaMasterClientService.getConfigReport_args._Fields - Enum in alluxio.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
MetaMasterClientService.getConfigReport_result - Class in alluxio.thrift
 
MetaMasterClientService.getConfigReport_result._Fields - Enum in alluxio.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
MetaMasterClientService.getConfiguration_args - Class in alluxio.thrift
 
MetaMasterClientService.getConfiguration_args._Fields - Enum in alluxio.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
MetaMasterClientService.getConfiguration_result - Class in alluxio.thrift
 
MetaMasterClientService.getConfiguration_result._Fields - Enum in alluxio.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
MetaMasterClientService.getMasterInfo_args - Class in alluxio.thrift
 
MetaMasterClientService.getMasterInfo_args._Fields - Enum in alluxio.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
MetaMasterClientService.getMasterInfo_result - Class in alluxio.thrift
 
MetaMasterClientService.getMasterInfo_result._Fields - Enum in alluxio.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
MetaMasterClientService.getMetrics_args - Class in alluxio.thrift
 
MetaMasterClientService.getMetrics_args._Fields - Enum in alluxio.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
MetaMasterClientService.getMetrics_result - Class in alluxio.thrift
 
MetaMasterClientService.getMetrics_result._Fields - Enum in alluxio.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
MetaMasterClientService.Iface - Interface in alluxio.thrift
This interface contains meta master service endpoints for Alluxio clients.
MetaMasterClientService.Processor<I extends MetaMasterClientService.Iface> - Class in alluxio.thrift
 
MetaMasterClientService.Processor.backup<I extends MetaMasterClientService.Iface> - Class in alluxio.thrift
 
MetaMasterClientService.Processor.getConfigReport<I extends MetaMasterClientService.Iface> - Class in alluxio.thrift
 
MetaMasterClientService.Processor.getConfiguration<I extends MetaMasterClientService.Iface> - Class in alluxio.thrift
 
MetaMasterClientService.Processor.getMasterInfo<I extends MetaMasterClientService.Iface> - Class in alluxio.thrift
 
MetaMasterClientService.Processor.getMetrics<I extends MetaMasterClientService.Iface> - Class in alluxio.thrift
 
MetaMasterClientServiceHandler - Class in alluxio.master.meta
This class is a Thrift handler for meta master RPCs.
MetaMasterClientServiceHandler(MetaMaster) - Constructor for class alluxio.master.meta.MetaMasterClientServiceHandler
 
MetaMasterFactory - Class in alluxio.master.meta
Factory to create a MetaMaster instance.
MetaMasterFactory() - Constructor for class alluxio.master.meta.MetaMasterFactory
Constructs a new MetaMasterFactory.
MetaMasterMasterService - Class in alluxio.thrift
 
MetaMasterMasterService() - Constructor for class alluxio.thrift.MetaMasterMasterService
 
MetaMasterMasterService.AsyncClient - Class in alluxio.thrift
 
MetaMasterMasterService.AsyncClient.Factory - Class in alluxio.thrift
 
MetaMasterMasterService.AsyncClient.getMasterId_call - Class in alluxio.thrift
 
MetaMasterMasterService.AsyncClient.masterHeartbeat_call - Class in alluxio.thrift
 
MetaMasterMasterService.AsyncClient.registerMaster_call - Class in alluxio.thrift
 
MetaMasterMasterService.AsyncIface - Interface in alluxio.thrift
 
MetaMasterMasterService.AsyncProcessor<I extends MetaMasterMasterService.AsyncIface> - Class in alluxio.thrift
 
MetaMasterMasterService.AsyncProcessor.getMasterId<I extends MetaMasterMasterService.AsyncIface> - Class in alluxio.thrift
 
MetaMasterMasterService.AsyncProcessor.masterHeartbeat<I extends MetaMasterMasterService.AsyncIface> - Class in alluxio.thrift
 
MetaMasterMasterService.AsyncProcessor.registerMaster<I extends MetaMasterMasterService.AsyncIface> - Class in alluxio.thrift
 
MetaMasterMasterService.Client - Class in alluxio.thrift
 
MetaMasterMasterService.Client.Factory - Class in alluxio.thrift
 
MetaMasterMasterService.getMasterId_args - Class in alluxio.thrift
 
MetaMasterMasterService.getMasterId_args._Fields - Enum in alluxio.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
MetaMasterMasterService.getMasterId_result - Class in alluxio.thrift
 
MetaMasterMasterService.getMasterId_result._Fields - Enum in alluxio.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
MetaMasterMasterService.Iface - Interface in alluxio.thrift
This interface contains meta master service endpoints for Alluxio standby masters.
MetaMasterMasterService.masterHeartbeat_args - Class in alluxio.thrift
 
MetaMasterMasterService.masterHeartbeat_args._Fields - Enum in alluxio.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
MetaMasterMasterService.masterHeartbeat_result - Class in alluxio.thrift
 
MetaMasterMasterService.masterHeartbeat_result._Fields - Enum in alluxio.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
MetaMasterMasterService.Processor<I extends MetaMasterMasterService.Iface> - Class in alluxio.thrift
 
MetaMasterMasterService.Processor.getMasterId<I extends MetaMasterMasterService.Iface> - Class in alluxio.thrift
 
MetaMasterMasterService.Processor.masterHeartbeat<I extends MetaMasterMasterService.Iface> - Class in alluxio.thrift
 
MetaMasterMasterService.Processor.registerMaster<I extends MetaMasterMasterService.Iface> - Class in alluxio.thrift
 
MetaMasterMasterService.registerMaster_args - Class in alluxio.thrift
 
MetaMasterMasterService.registerMaster_args._Fields - Enum in alluxio.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
MetaMasterMasterService.registerMaster_result - Class in alluxio.thrift
 
MetaMasterMasterService.registerMaster_result._Fields - Enum in alluxio.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
MetaMasterMasterServiceHandler - Class in alluxio.master.meta
This class is a Thrift handler for meta master RPCs invoked by an Alluxio standby master.
MetaMasterSync - Class in alluxio.master.meta
If a master is detected as a standby master.
MetaMasterSync(Address, RetryHandlingMetaMasterMasterClient) - Constructor for class alluxio.master.meta.MetaMasterSync
Creates a new instance of MetaMasterSync.
meter(String) - Static method in class alluxio.metrics.MetricsSystem
 
Metric - Class in alluxio.metrics
A metric of a given instance.
Metric(MetricsSystem.InstanceType, String, String, Double) - Constructor for class alluxio.metrics.Metric
Constructs a Metric instance.
Metric(MetricsSystem.InstanceType, String, String, String, Double) - Constructor for class alluxio.metrics.Metric
Constructs a Metric instance.
Metric - Class in alluxio.thrift
 
Metric() - Constructor for class alluxio.thrift.Metric
 
Metric(String, String, String, String, double, Map<String, String>) - Constructor for class alluxio.thrift.Metric
 
Metric(Metric) - Constructor for class alluxio.thrift.Metric
Performs a deep copy on other.
Metric._Fields - Enum in alluxio.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
METRIC_REGISTRY - Static variable in class alluxio.metrics.MetricsSystem
 
METRICS_CONF_FILE - Static variable in class alluxio.PropertyKey
 
METRICS_CONF_FILE - Static variable in class alluxio.PropertyKey.Name
 
METRICS_MASTER_CLIENT_SERVICE_NAME - Static variable in class alluxio.Constants
 
METRICS_MASTER_CLIENT_SERVICE_VERSION - Static variable in class alluxio.Constants
 
METRICS_MASTER_NAME - Static variable in class alluxio.Constants
 
MetricsAggregator - Interface in alluxio.metrics
Interface for the aggregator that aggregates a cluster-level metric from the metrics of different hosts.
MetricsCommand - Class in alluxio.cli.fsadmin.report
Prints Alluxio metrics information.
MetricsCommand(MetaMasterClient, PrintStream) - Constructor for class alluxio.cli.fsadmin.report.MetricsCommand
Creates a new instance of MetricsCommand.
MetricsConfig - Class in alluxio.metrics
Configurations used by the metrics system.
MetricsConfig(String) - Constructor for class alluxio.metrics.MetricsConfig
Creates a new MetricsConfig using the given config file.
MetricsConfig(Properties) - Constructor for class alluxio.metrics.MetricsConfig
Creates a new MetricsConfig using the given Properties.
MetricsFilter - Class in alluxio.metrics
A filter that matches the instance-level metrics by the instance type and metric name.
MetricsFilter(MetricsSystem.InstanceType, String) - Constructor for class alluxio.metrics.MetricsFilter
Constructs a new MetricsFilter instance.
metricsHeartbeat(String, String, MetricsHeartbeatTOptions) - Method in class alluxio.master.metrics.MetricsMasterClientServiceHandler
 
metricsHeartbeat(String, String, MetricsHeartbeatTOptions, AsyncMethodCallback) - Method in class alluxio.thrift.MetricsMasterClientService.AsyncClient
 
metricsHeartbeat(String, String, MetricsHeartbeatTOptions, AsyncMethodCallback) - Method in interface alluxio.thrift.MetricsMasterClientService.AsyncIface
 
metricsHeartbeat() - Constructor for class alluxio.thrift.MetricsMasterClientService.AsyncProcessor.metricsHeartbeat
 
metricsHeartbeat(String, String, MetricsHeartbeatTOptions) - Method in class alluxio.thrift.MetricsMasterClientService.Client
 
metricsHeartbeat(String, String, MetricsHeartbeatTOptions) - Method in interface alluxio.thrift.MetricsMasterClientService.Iface
Periodic metrics master client heartbeat.
metricsHeartbeat() - Constructor for class alluxio.thrift.MetricsMasterClientService.Processor.metricsHeartbeat
 
metricsHeartbeat_args() - Constructor for class alluxio.thrift.MetricsMasterClientService.metricsHeartbeat_args
 
metricsHeartbeat_args(String, String, MetricsHeartbeatTOptions) - Constructor for class alluxio.thrift.MetricsMasterClientService.metricsHeartbeat_args
 
metricsHeartbeat_args(MetricsMasterClientService.metricsHeartbeat_args) - Constructor for class alluxio.thrift.MetricsMasterClientService.metricsHeartbeat_args
Performs a deep copy on other.
metricsHeartbeat_call(String, String, MetricsHeartbeatTOptions, AsyncMethodCallback, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class alluxio.thrift.MetricsMasterClientService.AsyncClient.metricsHeartbeat_call
 
metricsHeartbeat_result() - Constructor for class alluxio.thrift.MetricsMasterClientService.metricsHeartbeat_result
 
metricsHeartbeat_result(MetricsHeartbeatTResponse, AlluxioTException) - Constructor for class alluxio.thrift.MetricsMasterClientService.metricsHeartbeat_result
 
metricsHeartbeat_result(MetricsMasterClientService.metricsHeartbeat_result) - Constructor for class alluxio.thrift.MetricsMasterClientService.metricsHeartbeat_result
Performs a deep copy on other.
MetricsHeartbeatTOptions - Class in alluxio.thrift
 
MetricsHeartbeatTOptions() - Constructor for class alluxio.thrift.MetricsHeartbeatTOptions
 
MetricsHeartbeatTOptions(List<Metric>) - Constructor for class alluxio.thrift.MetricsHeartbeatTOptions
 
MetricsHeartbeatTOptions(MetricsHeartbeatTOptions) - Constructor for class alluxio.thrift.MetricsHeartbeatTOptions
Performs a deep copy on other.
MetricsHeartbeatTOptions._Fields - Enum in alluxio.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
MetricsHeartbeatTResponse - Class in alluxio.thrift
 
MetricsHeartbeatTResponse() - Constructor for class alluxio.thrift.MetricsHeartbeatTResponse
 
MetricsHeartbeatTResponse(MetricsHeartbeatTResponse) - Constructor for class alluxio.thrift.MetricsHeartbeatTResponse
Performs a deep copy on other.
MetricsHeartbeatTResponse._Fields - Enum in alluxio.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
MetricsMaster - Interface in alluxio.master.metrics
Interface of the metrics master that aggregates the cluster-level metrics from workers and clients.
MetricsMasterClient - Class in alluxio.client.metrics
A client to use for interacting with a metrics master.
MetricsMasterClient(MasterClientConfig) - Constructor for class alluxio.client.metrics.MetricsMasterClient
Creates a new metrics master client.
MetricsMasterClientService - Class in alluxio.thrift
 
MetricsMasterClientService() - Constructor for class alluxio.thrift.MetricsMasterClientService
 
MetricsMasterClientService.AsyncClient - Class in alluxio.thrift
 
MetricsMasterClientService.AsyncClient.Factory - Class in alluxio.thrift
 
MetricsMasterClientService.AsyncClient.metricsHeartbeat_call - Class in alluxio.thrift
 
MetricsMasterClientService.AsyncIface - Interface in alluxio.thrift
 
MetricsMasterClientService.AsyncProcessor<I extends MetricsMasterClientService.AsyncIface> - Class in alluxio.thrift
 
MetricsMasterClientService.AsyncProcessor.metricsHeartbeat<I extends MetricsMasterClientService.AsyncIface> - Class in alluxio.thrift
 
MetricsMasterClientService.Client - Class in alluxio.thrift
 
MetricsMasterClientService.Client.Factory - Class in alluxio.thrift
 
MetricsMasterClientService.Iface - Interface in alluxio.thrift
This interface contains metrics master service endpoints for Alluxio clients.
MetricsMasterClientService.metricsHeartbeat_args - Class in alluxio.thrift
 
MetricsMasterClientService.metricsHeartbeat_args._Fields - Enum in alluxio.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
MetricsMasterClientService.metricsHeartbeat_result - Class in alluxio.thrift
 
MetricsMasterClientService.metricsHeartbeat_result._Fields - Enum in alluxio.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
MetricsMasterClientService.Processor<I extends MetricsMasterClientService.Iface> - Class in alluxio.thrift
 
MetricsMasterClientService.Processor.metricsHeartbeat<I extends MetricsMasterClientService.Iface> - Class in alluxio.thrift
 
MetricsMasterClientServiceHandler - Class in alluxio.master.metrics
This class is a Thrift handler for metrics master RPCs invoked by an Alluxio client.
MetricsMasterFactory - Class in alluxio.master.metrics
Factory to create a MetricsMaster instance.
MetricsMasterFactory() - Constructor for class alluxio.master.metrics.MetricsMasterFactory
Constructs a new MetricsMasterFactory.
MetricsServlet - Class in alluxio.metrics.sink
A sink that exposes metrics data in JSON format by HTTP.
MetricsServlet(MetricRegistry) - Constructor for class alluxio.metrics.sink.MetricsServlet
Creates a new MetricsServlet with a Properties and MetricRegistry.
MetricsStore - Class in alluxio.master.metrics
A store of metrics containing the metrics collected from workers and clients.
MetricsStore() - Constructor for class alluxio.master.metrics.MetricsStore
 
MetricsSystem - Class in alluxio.metrics
A MetricsSystem is created by a specific instance(master, worker).
MetricsSystem.InstanceType - Enum in alluxio.metrics
An enum of supported instance type.
MetricValue - Class in alluxio.thrift
 
MetricValue() - Constructor for class alluxio.thrift.MetricValue
 
MetricValue(MetricValue) - Constructor for class alluxio.thrift.MetricValue
Performs a deep copy on other.
MetricValue - Class in alluxio.wire
Represents the value of a metrics property, only one of longValue or doubleValue should be set.
MetricValue._Fields - Enum in alluxio.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
mExecutorService - Variable in class alluxio.master.AlluxioMasterProcess
The ExecutorService for RPC server.
mExecutorService - Variable in class alluxio.underfs.ObjectUnderFileSystem
Executor service used for parallel UFS operations such as bulk deletes.
mFileSystem - Variable in class alluxio.cli.fs.command.AbstractFileSystemCommand
 
mFileSystemContext - Variable in class alluxio.client.file.BaseFileSystem
 
mFsClient - Variable in class alluxio.cli.fsadmin.command.AbstractFsAdminCommand
 
mGroup - Variable in class alluxio.master.file.options.CreatePathOptions
 
mGroup - Variable in class alluxio.underfs.UfsStatus
 
mHostname - Variable in class alluxio.master.AbstractLocalAlluxioCluster
 
mId - Variable in class alluxio.master.file.meta.Inode
 
MidPartLongRange - Class in alluxio.underfs.swift
A range in a Swift object.
MidPartLongRange(long, long) - Constructor for class alluxio.underfs.swift.MidPartLongRange
Constructor for a range in a Swift object.
MIGRATE_DATA_SESSION_ID - Static variable in class alluxio.Sessions
 
millis() - Method in class alluxio.clock.ElapsedTimeClock
 
millis() - Method in class alluxio.clock.SystemClock
 
MiniBenchmark - Class in alluxio.cli
Mini benchmark that writes/reads one file with a given size and operation type.
mInodes - Variable in class alluxio.master.file.meta.InodeLockList
 
MINUTE - Static variable in class alluxio.Constants
 
MINUTE_MS - Static variable in class alluxio.Constants
 
mIsDirectory - Variable in class alluxio.underfs.UfsStatus
 
mJournalSystem - Variable in class alluxio.master.AlluxioMasterProcess
The journal system for writing journal entries and restoring master state.
MkdirCommand - Class in alluxio.cli.fs.command
Creates a new directory specified by the path in args, including any parent folders that are required.
MkdirCommand(FileSystem) - Constructor for class alluxio.cli.fs.command.MkdirCommand
Constructs a new instance to create a new directory.
mkdirIfNotExists(UnderFileSystem, String) - Static method in class alluxio.util.UnderFileSystemUtils
Attempts to create the directory if it does not already exist.
mkdirs(String) - Method in class alluxio.underfs.BaseUnderFileSystem
 
mkdirs(String, MkdirsOptions) - Method in class alluxio.underfs.hdfs.HdfsUnderFileSystem
 
mkdirs(String, MkdirsOptions) - Method in class alluxio.underfs.local.LocalUnderFileSystem
 
mkdirs(String, MkdirsOptions) - Method in class alluxio.underfs.ObjectUnderFileSystem
 
mkdirs(String) - Method in interface alluxio.underfs.UnderFileSystem
Creates the directory named by this abstract pathname.
mkdirs(String, MkdirsOptions) - Method in interface alluxio.underfs.UnderFileSystem
Creates the directory named by this abstract pathname, with specified MkdirsOptions.
mkdirs(String) - Method in class alluxio.underfs.UnderFileSystemWithLogging
 
mkdirs(String, MkdirsOptions) - Method in class alluxio.underfs.UnderFileSystemWithLogging
 
mkdirsInternal(String) - Method in class alluxio.underfs.ObjectUnderFileSystem
Creates a directory flagged file with the key and folder suffix.
MkdirsOptions - Class in alluxio.underfs.options
Method options for mkdirs in UnderFileSystem.
mLastModifiedTimeMs - Variable in class alluxio.underfs.UfsStatus
Last modified epoch time in ms, or null if it is not available.
mLeft - Variable in class alluxio.examples.Performance.Worker
 
mLocation - Variable in class alluxio.master.journalv0.ufs.UfsJournal
The location where this journal is stored.
mLockList - Variable in class alluxio.master.file.meta.LockedInodePath
 
mLockMode - Variable in class alluxio.master.file.meta.LockedInodePath
 
mLockModes - Variable in class alluxio.master.file.meta.InodeLockList
 
mLRUCache - Variable in class alluxio.worker.block.evictor.LRUEvictor
Access-ordered LinkedHashMap from blockId to LRUEvictor.UNUSED_MAP_VALUE(just a placeholder to occupy the value), acts as a LRU double linked list where most recently accessed element is put at the tail while least recently accessed element is put at the head.
mManagerView - Variable in class alluxio.worker.block.evictor.AbstractEvictor
 
mMaxCapacity - Variable in class alluxio.resource.ResourcePool
 
mMetaClient - Variable in class alluxio.cli.fsadmin.command.AbstractFsAdminCommand
 
mMetadataLoad - Variable in class alluxio.master.file.options.CreatePathOptions
 
mMode - Variable in class alluxio.master.file.options.CreatePathOptions
 
mMode - Variable in class alluxio.underfs.UfsStatus
 
mMountPoint - Variable in class alluxio.master.file.options.CreatePathOptions
 
mName - Variable in class alluxio.underfs.UfsStatus
 
mObjectMapper - Variable in class alluxio.web.WebInterfaceAbstractMetricsServlet
 
Mode - Class in alluxio.security.authorization
POSIX style file/directory access mode.
Mode(Mode.Bits, Mode.Bits, Mode.Bits) - Constructor for class alluxio.security.authorization.Mode
Constructs an instance of Mode with the given Mode.Bits.
Mode(short) - Constructor for class alluxio.security.authorization.Mode
Constructs an instance of Mode with the given mode.
Mode(Mode) - Constructor for class alluxio.security.authorization.Mode
Copy constructor.
Mode.Bits - Enum in alluxio.security.authorization
Mode bits.
MODE_FIELD_NUMBER - Static variable in class alluxio.proto.dataserver.Protocol.CreateUfsFileOptions
 
MODE_FIELD_NUMBER - Static variable in class alluxio.proto.journal.File.InodeDirectoryEntry
 
MODE_FIELD_NUMBER - Static variable in class alluxio.proto.journal.File.InodeFileEntry
 
ModeConverter() - Constructor for class alluxio.checker.HiveIntegrationChecker.ModeConverter
 
ModeParser - Class in alluxio.security.authorization
Parser for Mode instances.
mOperationTimeMs - Variable in class alluxio.master.file.options.CreatePathOptions
 
MostAvailableFirstPolicy - Class in alluxio.client.file.policy
A policy that returns the worker with the most available bytes.
MostAvailableFirstPolicy() - Constructor for class alluxio.client.file.policy.MostAvailableFirstPolicy
Constructs a new MostAvailableFirstPolicy.
mount(AlluxioURI, AlluxioURI) - Method in class alluxio.client.file.BaseFileSystem
 
mount(AlluxioURI, AlluxioURI, MountOptions) - Method in class alluxio.client.file.BaseFileSystem
 
mount(AlluxioURI, AlluxioURI) - Method in interface alluxio.client.file.FileSystem
Convenience method for FileSystem.mount(AlluxioURI, AlluxioURI, MountOptions) with default options.
mount(AlluxioURI, AlluxioURI, MountOptions) - Method in interface alluxio.client.file.FileSystem
Mounts a UFS subtree to the given Alluxio path.
mount(AlluxioURI, AlluxioURI, MountOptions) - Method in interface alluxio.client.file.FileSystemMasterClient
Mounts the given UFS path under the given Alluxio path.
mount(AlluxioURI, AlluxioURI, MountOptions) - Method in class alluxio.client.file.RetryHandlingFileSystemMasterClient
 
mount(AlluxioURI, AlluxioURI, MountOptions) - Method in class alluxio.master.file.DefaultFileSystemMaster
 
mount(AlluxioURI, AlluxioURI, MountOptions) - Method in interface alluxio.master.file.FileSystemMaster
Mounts a UFS path onto an Alluxio path.
MOUNT - Static variable in class alluxio.master.file.FileSystemMasterClientRestServiceHandler
Deprecated.
 
mount(String, String, Boolean, Boolean) - Method in class alluxio.master.file.FileSystemMasterClientRestServiceHandler
Deprecated.
 
mount(String, String, MountTOptions) - Method in class alluxio.master.file.FileSystemMasterClientServiceHandler
 
MOUNT - Static variable in class alluxio.proxy.PathsRestServiceHandler
 
mount(String, String, MountOptions) - Method in class alluxio.proxy.PathsRestServiceHandler
 
mount(String, String, MountTOptions, AsyncMethodCallback) - Method in class alluxio.thrift.FileSystemMasterClientService.AsyncClient
 
mount(String, String, MountTOptions, AsyncMethodCallback) - Method in interface alluxio.thrift.FileSystemMasterClientService.AsyncIface
 
mount() - Constructor for class alluxio.thrift.FileSystemMasterClientService.AsyncProcessor.mount
 
mount(String, String, MountTOptions) - Method in class alluxio.thrift.FileSystemMasterClientService.Client
 
mount(String, String, MountTOptions) - Method in interface alluxio.thrift.FileSystemMasterClientService.Iface
Creates a new "mount point", mounts the given UFS path in the Alluxio namespace at the given path.
mount() - Constructor for class alluxio.thrift.FileSystemMasterClientService.Processor.mount
 
mount_args() - Constructor for class alluxio.thrift.FileSystemMasterClientService.mount_args
 
mount_args(String, String, MountTOptions) - Constructor for class alluxio.thrift.FileSystemMasterClientService.mount_args
 
mount_args(FileSystemMasterClientService.mount_args) - Constructor for class alluxio.thrift.FileSystemMasterClientService.mount_args
Performs a deep copy on other.
mount_call(String, String, MountTOptions, AsyncMethodCallback, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class alluxio.thrift.FileSystemMasterClientService.AsyncClient.mount_call
 
MOUNT_COMMAND - Static variable in class alluxio.util.ShellUtils
a Unix command for getting mount information.
MOUNT_ID_FIELD_NUMBER - Static variable in class alluxio.proto.dataserver.Protocol.CreateUfsFileOptions
 
MOUNT_ID_FIELD_NUMBER - Static variable in class alluxio.proto.journal.File.AddMountPointEntry
 
MOUNT_OPS - Static variable in class alluxio.metrics.MasterMetrics
 
MOUNT_POINT_FIELD_NUMBER - Static variable in class alluxio.proto.journal.File.InodeDirectoryEntry
 
mount_result() - Constructor for class alluxio.thrift.FileSystemMasterClientService.mount_result
 
mount_result(MountTResponse, AlluxioTException) - Constructor for class alluxio.thrift.FileSystemMasterClientService.mount_result
 
mount_result(FileSystemMasterClientService.mount_result) - Constructor for class alluxio.thrift.FileSystemMasterClientService.mount_result
Performs a deep copy on other.
MountCommand - Class in alluxio.cli.fs.command
Mounts a UFS path onto an Alluxio path.
MountCommand(FileSystem) - Constructor for class alluxio.cli.fs.command.MountCommand
 
MOUNTID_FIELD_NUMBER - Static variable in class alluxio.proto.dataserver.Protocol.OpenUfsBlockOptions
 
MountInfo - Class in alluxio.master.file.meta.options
This class holds information about a mount point.
MountInfo(AlluxioURI, AlluxioURI, long, MountOptions) - Constructor for class alluxio.master.file.meta.options.MountInfo
Creates a new instance of MountInfo.
MountOptions - Class in alluxio.client.file.options
Method options for mounting a path.
MountOptions - Class in alluxio.master.file.options
Method option for mounting.
MountOptions(MountTOptions) - Constructor for class alluxio.master.file.options.MountOptions
Creates a new instance of MountOptions from MountTOptions.
MountOptions(File.AddMountPointEntry) - Constructor for class alluxio.master.file.options.MountOptions
Creates a new instance of MountOptions from File.AddMountPointEntry.
MountPointInfo - Class in alluxio.thrift
 
MountPointInfo() - Constructor for class alluxio.thrift.MountPointInfo
 
MountPointInfo(String, String, long, long, boolean, Map<String, String>, boolean) - Constructor for class alluxio.thrift.MountPointInfo
 
MountPointInfo(MountPointInfo) - Constructor for class alluxio.thrift.MountPointInfo
Performs a deep copy on other.
MountPointInfo - Class in alluxio.wire
The mount point information.
MountPointInfo() - Constructor for class alluxio.wire.MountPointInfo
Creates a new instance of MountPointInfo.
MountPointInfo._Fields - Enum in alluxio.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
MountTable - Class in alluxio.master.file.meta
This class is used for keeping track of Alluxio mount points.
MountTable(UfsManager) - Constructor for class alluxio.master.file.meta.MountTable
Creates a new instance of MountTable.
MountTable.Resolution - Class in alluxio.master.file.meta
This class represents a UFS path after resolution.
MountTOptions - Class in alluxio.thrift
 
MountTOptions() - Constructor for class alluxio.thrift.MountTOptions
 
MountTOptions(MountTOptions) - Constructor for class alluxio.thrift.MountTOptions
Performs a deep copy on other.
MountTOptions._Fields - Enum in alluxio.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
MountTResponse - Class in alluxio.thrift
 
MountTResponse() - Constructor for class alluxio.thrift.MountTResponse
 
MountTResponse(MountTResponse) - Constructor for class alluxio.thrift.MountTResponse
Performs a deep copy on other.
MountTResponse._Fields - Enum in alluxio.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
move(String, String) - Static method in class alluxio.util.io.FileUtils
Moves file from one place to another, can across storage devices (e.g., from memory to SSD) when File.renameTo(java.io.File) may not work.
moveBlock(long, long, BlockStoreLocation) - Method in interface alluxio.worker.block.BlockStore
Moves an existing block to a new location.
moveBlock(long, long, BlockStoreLocation, BlockStoreLocation) - Method in interface alluxio.worker.block.BlockStore
Moves an existing block to a new location.
moveBlock(long, long, String) - Method in interface alluxio.worker.block.BlockWorker
Moves a block from its current location to a target location, currently only tier level moves are supported.
moveBlock(long, long, String) - Method in class alluxio.worker.block.DefaultBlockWorker
 
moveBlock(long, long, BlockStoreLocation) - Method in class alluxio.worker.block.TieredBlockStore
 
moveBlock(long, long, BlockStoreLocation, BlockStoreLocation) - Method in class alluxio.worker.block.TieredBlockStore
 
moveBlockMeta(BlockMeta, TempBlockMeta) - Method in class alluxio.worker.block.BlockMetadataManager
Moves an existing block to another location currently hold by a temp block.
moveBlockMeta(BlockMeta, BlockStoreLocation) - Method in class alluxio.worker.block.BlockMetadataManager
Deprecated.
mOwner - Variable in class alluxio.master.file.options.CreatePathOptions
 
mOwner - Variable in class alluxio.underfs.UfsStatus
 
mPathComponents - Variable in class alluxio.master.file.meta.LockedInodePath
 
mPauseStateLock - Variable in class alluxio.master.AbstractMaster
A lock which prevents any changes to persistent (journaled) state.
mPersisted - Variable in class alluxio.master.file.options.CreatePathOptions
 
mPos - Variable in class alluxio.underfs.MultiRangeObjectInputStream
The current position of the stream.
mPosToWrite - Variable in class alluxio.worker.netty.WriteRequestContext
The next pos to write to the block worker.
mPrintStream - Variable in class alluxio.cli.fsadmin.command.AbstractFsAdminCommand
 
mProtocol - Variable in class alluxio.AbstractClient
 
mProxyProcess - Variable in class alluxio.master.AbstractLocalAlluxioCluster
 
mProxyThread - Variable in class alluxio.master.AbstractLocalAlluxioCluster
 
mRecursive - Variable in class alluxio.master.file.options.CreatePathOptions
 
mResources - Variable in class alluxio.resource.ResourcePool
 
mRight - Variable in class alluxio.examples.Performance.Worker
 
mSafeModeManager - Variable in class alluxio.master.AbstractMaster
The manager for safe mode state.
mSafeModeManager - Variable in class alluxio.master.AlluxioMasterProcess
The manager of safe mode state.
mServiceVersion - Variable in class alluxio.AbstractClient
Stores the service version; used for detecting incompatible client-server pairs.
mStateChangeLock - Variable in class alluxio.master.AbstractMaster
A lock which must be taken before modifying persistent (journaled) state.
mStream - Variable in class alluxio.underfs.MultiRangeObjectInputStream
The backing input stream.
mTtl - Variable in class alluxio.master.file.meta.Inode
 
mTtlAction - Variable in class alluxio.master.file.meta.Inode
 
mType - Variable in class alluxio.conf.Source
 
mUfsConf - Variable in class alluxio.underfs.BaseUnderFileSystem
UFS Configuration options.
MULTI_PROCESS_SIMPLE_CLUSTER - Static variable in class alluxio.multi.process.PortCoordination
 
MULTI_PROCESS_ZOOKEEPER - Static variable in class alluxio.multi.process.PortCoordination
 
MultiMasterConnectDetails(List<InetSocketAddress>) - Constructor for class alluxio.master.PollingMasterInquireClient.MultiMasterConnectDetails
 
MultiMasterLocalAlluxioCluster - Class in alluxio.master
A local Alluxio cluster with multiple masters.
MultiMasterLocalAlluxioCluster(int) - Constructor for class alluxio.master.MultiMasterLocalAlluxioCluster
Runs a multi master local Alluxio cluster with a single worker.
MultiMasterLocalAlluxioCluster(int, int) - Constructor for class alluxio.master.MultiMasterLocalAlluxioCluster
 
MultiMount - Class in alluxio.examples
Example program that demonstrates Alluxio's ability to read and write data across different types of storage systems.
MultiPartSchemeURI - Class in alluxio
MultiPartSchemeURI supports multiple components for the scheme.
MultiPartSchemeURI(String, String, String, String, String) - Constructor for class alluxio.MultiPartSchemeURI
 
MultiProcessCluster - Class in alluxio.multi.process
Class for starting, stopping, and interacting with an Alluxio cluster where each master and worker runs in its own process.
MultiProcessCluster.Builder - Class in alluxio.multi.process
Builder for MultiProcessCluster.
MultiProcessCluster.DeployMode - Enum in alluxio.multi.process
Deploy mode for the cluster.
MultiRangeObjectInputStream - Class in alluxio.underfs
A stream for reading data using range queries.
MultiRangeObjectInputStream() - Constructor for class alluxio.underfs.MultiRangeObjectInputStream
 
MultiValueMetricsAggregator - Interface in alluxio.metrics
An interface for the aggregator that aggregates metrics of different hosts into multiple cluster-level metrics.
mUnderFileSystemMap - Variable in class alluxio.underfs.AbstractUfsManager
Maps from key to UnderFileSystem instances.
mUri - Variable in class alluxio.client.file.FileOutStream
 
mUri - Variable in class alluxio.master.file.meta.LockedInodePath
 
mUri - Variable in class alluxio.StandardURI
A hierarchical URI.
mUri - Variable in class alluxio.underfs.BaseUnderFileSystem
The UFS AlluxioURI used to create this BaseUnderFileSystem.
MutableJournal - Interface in alluxio.master.journalv0
The read-write journal.
MutableJournal.Factory - Class in alluxio.master.journalv0
A MutableJournal factory.
MutableLockedInodePath - Class in alluxio.master.file.meta
This class represents an LockedInodePath, where the list of inodes can be extended to gather additional inodes along the path.
MutableLockedInodePath(AlluxioURI, InodeLockList, InodeTree.LockMode) - Constructor for class alluxio.master.file.meta.MutableLockedInodePath
Creates an instance of MutableLockedInodePath.
MutableLockedInodePath(AlluxioURI, InodeLockList, String[], InodeTree.LockMode) - Constructor for class alluxio.master.file.meta.MutableLockedInodePath
Creates an instance of MutableLockedInodePath.
MutableLockedInodePath(AlluxioURI, LockedInodePath, InodeLockList) - Constructor for class alluxio.master.file.meta.MutableLockedInodePath
Creates an instance of MutableLockedInodePath.
MvCommand - Class in alluxio.cli.fs.command
Renames a file or directory specified by args.
MvCommand(FileSystem) - Constructor for class alluxio.cli.fs.command.MvCommand
 
mWebAppContext - Variable in class alluxio.web.WebServer
 
mWorkDirectory - Variable in class alluxio.master.AbstractLocalAlluxioCluster
 
mWorkerId - Variable in class alluxio.examples.Performance.Worker
 
mWorkers - Variable in class alluxio.master.AbstractLocalAlluxioCluster
 
mWorkerThreads - Variable in class alluxio.master.AbstractLocalAlluxioCluster
 

N

NAME - Static variable in class alluxio.security.authentication.PlainSaslServerProvider
 
NAME_FIELD_NUMBER - Static variable in class alluxio.proto.journal.File.InodeDirectoryEntry
 
NAME_FIELD_NUMBER - Static variable in class alluxio.proto.journal.File.InodeFileEntry
 
nearest(List<TieredIdentity>) - Method in class alluxio.wire.TieredIdentity
 
needPersistence(long) - Method in class alluxio.worker.file.FileDataManager
Checks if the given file needs persistence.
needRecompute(Lineage, FileSystemMasterView) - Static method in class alluxio.master.lineage.meta.LineageStateUtils
 
needsTaskCommit(TaskAttemptContext) - Method in class alluxio.hadoop.mapreduce.KeyValueOutputCommitter
 
NettyChannelPool - Class in alluxio.network.netty
A pool to manage netty channels.
NettyChannelPool(Bootstrap, int, int, long) - Constructor for class alluxio.network.netty.NettyChannelPool
Creates a netty channel pool instance with a minimum capacity of 1.
NettyClient - Class in alluxio.network.netty
Shared configuration and methods for the Netty client.
NettyDataServer - Class in alluxio.worker.netty
Runs a netty data server that responds to block requests.
NettyDataServer(SocketAddress, WorkerProcess) - Constructor for class alluxio.worker.netty.NettyDataServer
Creates a new instance of NettyDataServer.
NettyPacketReader - Class in alluxio.client.block.stream
A netty packet reader that streams a region from a netty data server.
NettyPacketReader.Factory - Class in alluxio.client.block.stream
Factory class to create NettyPacketReaders.
NettyPacketWriter - Class in alluxio.client.block.stream
A netty packet writer that streams a full block or a UFS file to a netty data server.
NettyRPC - Class in alluxio.network.netty
Netty blocking RPC client.
NettyRPC.RPCHandler - Class in alluxio.network.netty
Netty RPC client handler.
nettyRPCAndLog(Logger, RpcUtils.NettyRpcCallable<T>, String, String, Object...) - Static method in class alluxio.RpcUtils
Handles a netty RPC callable with logging.
NettyRPCContext - Class in alluxio.network.netty
Context to send a netty RPC.
NettyUtils - Class in alluxio.util.network
Utility methods for working with Netty.
NETWORK_HOST_RESOLUTION_TIMEOUT_MS - Static variable in class alluxio.PropertyKey.Name
 
NETWORK_HOST_RESOLUTION_TIMEOUT_MS - Static variable in class alluxio.PropertyKey
 
NETWORK_NETTY_HEARTBEAT_TIMEOUT_MS - Static variable in class alluxio.PropertyKey.Name
 
NETWORK_NETTY_HEARTBEAT_TIMEOUT_MS - Static variable in class alluxio.PropertyKey
 
NETWORK_THRIFT_FRAME_SIZE_BYTES_MAX - Static variable in class alluxio.PropertyKey.Name
 
NETWORK_THRIFT_FRAME_SIZE_BYTES_MAX - Static variable in class alluxio.PropertyKey
Deprecated.
since 1.8.0 and will be removed in 2.0.
NetworkAddressUtils - Class in alluxio.util.network
Common network address related utilities shared by all components in Alluxio.
NetworkAddressUtils.ServiceType - Enum in alluxio.util.network
Different types of services that client uses to connect.
NEVER - Static variable in class alluxio.util.WaitForOptions
 
NEW_BLOCKS_GOT - Static variable in class alluxio.metrics.MasterMetrics
 
NEW_STORE_ID_FIELD_NUMBER - Static variable in class alluxio.proto.journal.KeyValue.RenameStoreEntry
 
newBuilder(List<PortCoordination.ReservedPort>) - Static method in class alluxio.multi.process.MultiProcessCluster
 
newBuilder() - Static method in class alluxio.proto.dataserver.Protocol.AsyncCacheRequest
 
newBuilder(Protocol.AsyncCacheRequest) - Static method in class alluxio.proto.dataserver.Protocol.AsyncCacheRequest
 
newBuilder() - Static method in class alluxio.proto.dataserver.Protocol.CreateUfsFileOptions
 
newBuilder(Protocol.CreateUfsFileOptions) - Static method in class alluxio.proto.dataserver.Protocol.CreateUfsFileOptions
 
newBuilder() - Static method in class alluxio.proto.dataserver.Protocol.Heartbeat
 
newBuilder(Protocol.Heartbeat) - Static method in class alluxio.proto.dataserver.Protocol.Heartbeat
 
newBuilder() - Static method in class alluxio.proto.dataserver.Protocol.LocalBlockCloseRequest
 
newBuilder(Protocol.LocalBlockCloseRequest) - Static method in class alluxio.proto.dataserver.Protocol.LocalBlockCloseRequest
 
newBuilder() - Static method in class alluxio.proto.dataserver.Protocol.LocalBlockCompleteRequest
 
newBuilder(Protocol.LocalBlockCompleteRequest) - Static method in class alluxio.proto.dataserver.Protocol.LocalBlockCompleteRequest
 
newBuilder() - Static method in class alluxio.proto.dataserver.Protocol.LocalBlockCreateRequest
 
newBuilder(Protocol.LocalBlockCreateRequest) - Static method in class alluxio.proto.dataserver.Protocol.LocalBlockCreateRequest
 
newBuilder() - Static method in class alluxio.proto.dataserver.Protocol.LocalBlockCreateResponse
 
newBuilder(Protocol.LocalBlockCreateResponse) - Static method in class alluxio.proto.dataserver.Protocol.LocalBlockCreateResponse
 
newBuilder() - Static method in class alluxio.proto.dataserver.Protocol.LocalBlockOpenRequest
 
newBuilder(Protocol.LocalBlockOpenRequest) - Static method in class alluxio.proto.dataserver.Protocol.LocalBlockOpenRequest
 
newBuilder() - Static method in class alluxio.proto.dataserver.Protocol.LocalBlockOpenResponse
 
newBuilder(Protocol.LocalBlockOpenResponse) - Static method in class alluxio.proto.dataserver.Protocol.LocalBlockOpenResponse
 
newBuilder() - Static method in class alluxio.proto.dataserver.Protocol.OpenUfsBlockOptions
 
newBuilder(Protocol.OpenUfsBlockOptions) - Static method in class alluxio.proto.dataserver.Protocol.OpenUfsBlockOptions
 
newBuilder() - Static method in class alluxio.proto.dataserver.Protocol.ReadRequest
 
newBuilder(Protocol.ReadRequest) - Static method in class alluxio.proto.dataserver.Protocol.ReadRequest
 
newBuilder() - Static method in class alluxio.proto.dataserver.Protocol.ReadResponse
 
newBuilder(Protocol.ReadResponse) - Static method in class alluxio.proto.dataserver.Protocol.ReadResponse
 
newBuilder() - Static method in class alluxio.proto.dataserver.Protocol.Response
 
newBuilder(Protocol.Response) - Static method in class alluxio.proto.dataserver.Protocol.Response
 
newBuilder() - Static method in class alluxio.proto.dataserver.Protocol.WriteRequest
 
newBuilder(Protocol.WriteRequest) - Static method in class alluxio.proto.dataserver.Protocol.WriteRequest
 
newBuilder() - Static method in class alluxio.proto.journal.Block.BlockContainerIdGeneratorEntry
 
newBuilder(Block.BlockContainerIdGeneratorEntry) - Static method in class alluxio.proto.journal.Block.BlockContainerIdGeneratorEntry
 
newBuilder() - Static method in class alluxio.proto.journal.Block.BlockInfoEntry
 
newBuilder(Block.BlockInfoEntry) - Static method in class alluxio.proto.journal.Block.BlockInfoEntry
 
newBuilder() - Static method in class alluxio.proto.journal.Block.DeleteBlockEntry
 
newBuilder(Block.DeleteBlockEntry) - Static method in class alluxio.proto.journal.Block.DeleteBlockEntry
 
newBuilder() - Static method in class alluxio.proto.journal.File.AddMountPointEntry
 
newBuilder(File.AddMountPointEntry) - Static method in class alluxio.proto.journal.File.AddMountPointEntry
 
newBuilder() - Static method in class alluxio.proto.journal.File.AsyncPersistRequestEntry
 
newBuilder(File.AsyncPersistRequestEntry) - Static method in class alluxio.proto.journal.File.AsyncPersistRequestEntry
 
newBuilder() - Static method in class alluxio.proto.journal.File.CompleteFileEntry
 
newBuilder(File.CompleteFileEntry) - Static method in class alluxio.proto.journal.File.CompleteFileEntry
 
newBuilder() - Static method in class alluxio.proto.journal.File.DeleteFileEntry
 
newBuilder(File.DeleteFileEntry) - Static method in class alluxio.proto.journal.File.DeleteFileEntry
 
newBuilder() - Static method in class alluxio.proto.journal.File.DeleteMountPointEntry
 
newBuilder(File.DeleteMountPointEntry) - Static method in class alluxio.proto.journal.File.DeleteMountPointEntry
 
newBuilder() - Static method in class alluxio.proto.journal.File.InodeDirectoryEntry
 
newBuilder(File.InodeDirectoryEntry) - Static method in class alluxio.proto.journal.File.InodeDirectoryEntry
 
newBuilder() - Static method in class alluxio.proto.journal.File.InodeDirectoryIdGeneratorEntry
 
newBuilder(File.InodeDirectoryIdGeneratorEntry) - Static method in class alluxio.proto.journal.File.InodeDirectoryIdGeneratorEntry
 
newBuilder() - Static method in class alluxio.proto.journal.File.InodeFileEntry
 
newBuilder(File.InodeFileEntry) - Static method in class alluxio.proto.journal.File.InodeFileEntry
 
newBuilder() - Static method in class alluxio.proto.journal.File.InodeLastModificationTimeEntry
 
newBuilder(File.InodeLastModificationTimeEntry) - Static method in class alluxio.proto.journal.File.InodeLastModificationTimeEntry
 
newBuilder() - Static method in class alluxio.proto.journal.File.PersistDirectoryEntry
 
newBuilder(File.PersistDirectoryEntry) - Static method in class alluxio.proto.journal.File.PersistDirectoryEntry
 
newBuilder() - Static method in class alluxio.proto.journal.File.PersistFileEntry
 
newBuilder(File.PersistFileEntry) - Static method in class alluxio.proto.journal.File.PersistFileEntry
 
newBuilder() - Static method in class alluxio.proto.journal.File.ReinitializeFileEntry
 
newBuilder(File.ReinitializeFileEntry) - Static method in class alluxio.proto.journal.File.ReinitializeFileEntry
 
newBuilder() - Static method in class alluxio.proto.journal.File.RenameEntry
 
newBuilder(File.RenameEntry) - Static method in class alluxio.proto.journal.File.RenameEntry
 
newBuilder() - Static method in class alluxio.proto.journal.File.SetAttributeEntry
 
newBuilder(File.SetAttributeEntry) - Static method in class alluxio.proto.journal.File.SetAttributeEntry
 
newBuilder() - Static method in class alluxio.proto.journal.File.StringPairEntry
 
newBuilder(File.StringPairEntry) - Static method in class alluxio.proto.journal.File.StringPairEntry
 
newBuilder() - Static method in class alluxio.proto.journal.File.UpdateUfsModeEntry
 
newBuilder(File.UpdateUfsModeEntry) - Static method in class alluxio.proto.journal.File.UpdateUfsModeEntry
 
newBuilder() - Static method in class alluxio.proto.journal.Journal.JournalEntry
 
newBuilder(Journal.JournalEntry) - Static method in class alluxio.proto.journal.Journal.JournalEntry
 
newBuilder() - Static method in class alluxio.proto.journal.KeyValue.CompletePartitionEntry
 
newBuilder(KeyValue.CompletePartitionEntry) - Static method in class alluxio.proto.journal.KeyValue.CompletePartitionEntry
 
newBuilder() - Static method in class alluxio.proto.journal.KeyValue.CompleteStoreEntry
 
newBuilder(KeyValue.CompleteStoreEntry) - Static method in class alluxio.proto.journal.KeyValue.CompleteStoreEntry
 
newBuilder() - Static method in class alluxio.proto.journal.KeyValue.CreateStoreEntry
 
newBuilder(KeyValue.CreateStoreEntry) - Static method in class alluxio.proto.journal.KeyValue.CreateStoreEntry
 
newBuilder() - Static method in class alluxio.proto.journal.KeyValue.DeleteStoreEntry
 
newBuilder(KeyValue.DeleteStoreEntry) - Static method in class alluxio.proto.journal.KeyValue.DeleteStoreEntry
 
newBuilder() - Static method in class alluxio.proto.journal.KeyValue.MergeStoreEntry
 
newBuilder(KeyValue.MergeStoreEntry) - Static method in class alluxio.proto.journal.KeyValue.MergeStoreEntry
 
newBuilder() - Static method in class alluxio.proto.journal.KeyValue.RenameStoreEntry
 
newBuilder(KeyValue.RenameStoreEntry) - Static method in class alluxio.proto.journal.KeyValue.RenameStoreEntry
 
newBuilder() - Static method in class alluxio.proto.journal.Lineage.DeleteLineageEntry
 
newBuilder(Lineage.DeleteLineageEntry) - Static method in class alluxio.proto.journal.Lineage.DeleteLineageEntry
 
newBuilder() - Static method in class alluxio.proto.journal.Lineage.LineageEntry
 
newBuilder(Lineage.LineageEntry) - Static method in class alluxio.proto.journal.Lineage.LineageEntry
 
newBuilder() - Static method in class alluxio.proto.journal.Lineage.LineageIdGeneratorEntry
 
newBuilder(Lineage.LineageIdGeneratorEntry) - Static method in class alluxio.proto.journal.Lineage.LineageIdGeneratorEntry
 
newBuilderForType() - Method in class alluxio.proto.dataserver.Protocol.AsyncCacheRequest
 
newBuilderForType(GeneratedMessage.BuilderParent) - Method in class alluxio.proto.dataserver.Protocol.AsyncCacheRequest
 
newBuilderForType() - Method in class alluxio.proto.dataserver.Protocol.CreateUfsFileOptions
 
newBuilderForType(GeneratedMessage.BuilderParent) - Method in class alluxio.proto.dataserver.Protocol.CreateUfsFileOptions
 
newBuilderForType() - Method in class alluxio.proto.dataserver.Protocol.Heartbeat
 
newBuilderForType(GeneratedMessage.BuilderParent) - Method in class alluxio.proto.dataserver.Protocol.Heartbeat
 
newBuilderForType() - Method in class alluxio.proto.dataserver.Protocol.LocalBlockCloseRequest
 
newBuilderForType(GeneratedMessage.BuilderParent) - Method in class alluxio.proto.dataserver.Protocol.LocalBlockCloseRequest
 
newBuilderForType() - Method in class alluxio.proto.dataserver.Protocol.LocalBlockCompleteRequest
 
newBuilderForType(GeneratedMessage.BuilderParent) - Method in class alluxio.proto.dataserver.Protocol.LocalBlockCompleteRequest
 
newBuilderForType() - Method in class alluxio.proto.dataserver.Protocol.LocalBlockCreateRequest
 
newBuilderForType(GeneratedMessage.BuilderParent) - Method in class alluxio.proto.dataserver.Protocol.LocalBlockCreateRequest
 
newBuilderForType() - Method in class alluxio.proto.dataserver.Protocol.LocalBlockCreateResponse
 
newBuilderForType(GeneratedMessage.BuilderParent) - Method in class alluxio.proto.dataserver.Protocol.LocalBlockCreateResponse
 
newBuilderForType() - Method in class alluxio.proto.dataserver.Protocol.LocalBlockOpenRequest
 
newBuilderForType(GeneratedMessage.BuilderParent) - Method in class alluxio.proto.dataserver.Protocol.LocalBlockOpenRequest
 
newBuilderForType() - Method in class alluxio.proto.dataserver.Protocol.LocalBlockOpenResponse
 
newBuilderForType(GeneratedMessage.BuilderParent) - Method in class alluxio.proto.dataserver.Protocol.LocalBlockOpenResponse
 
newBuilderForType() - Method in class alluxio.proto.dataserver.Protocol.OpenUfsBlockOptions
 
newBuilderForType(GeneratedMessage.BuilderParent) - Method in class alluxio.proto.dataserver.Protocol.OpenUfsBlockOptions
 
newBuilderForType() - Method in class alluxio.proto.dataserver.Protocol.ReadRequest
 
newBuilderForType(GeneratedMessage.BuilderParent) - Method in class alluxio.proto.dataserver.Protocol.ReadRequest
 
newBuilderForType() - Method in class alluxio.proto.dataserver.Protocol.ReadResponse
 
newBuilderForType(GeneratedMessage.BuilderParent) - Method in class alluxio.proto.dataserver.Protocol.ReadResponse
 
newBuilderForType() - Method in class alluxio.proto.dataserver.Protocol.Response
 
newBuilderForType(GeneratedMessage.BuilderParent) - Method in class alluxio.proto.dataserver.Protocol.Response
 
newBuilderForType() - Method in class alluxio.proto.dataserver.Protocol.WriteRequest
 
newBuilderForType(GeneratedMessage.BuilderParent) - Method in class alluxio.proto.dataserver.Protocol.WriteRequest
 
newBuilderForType() - Method in class alluxio.proto.journal.Block.BlockContainerIdGeneratorEntry
 
newBuilderForType(GeneratedMessage.BuilderParent) - Method in class alluxio.proto.journal.Block.BlockContainerIdGeneratorEntry
 
newBuilderForType() - Method in class alluxio.proto.journal.Block.BlockInfoEntry
 
newBuilderForType(GeneratedMessage.BuilderParent) - Method in class alluxio.proto.journal.Block.BlockInfoEntry
 
newBuilderForType() - Method in class alluxio.proto.journal.Block.DeleteBlockEntry
 
newBuilderForType(GeneratedMessage.BuilderParent) - Method in class alluxio.proto.journal.Block.DeleteBlockEntry
 
newBuilderForType() - Method in class alluxio.proto.journal.File.AddMountPointEntry
 
newBuilderForType(GeneratedMessage.BuilderParent) - Method in class alluxio.proto.journal.File.AddMountPointEntry
 
newBuilderForType() - Method in class alluxio.proto.journal.File.AsyncPersistRequestEntry
 
newBuilderForType(GeneratedMessage.BuilderParent) - Method in class alluxio.proto.journal.File.AsyncPersistRequestEntry
 
newBuilderForType() - Method in class alluxio.proto.journal.File.CompleteFileEntry
 
newBuilderForType(GeneratedMessage.BuilderParent) - Method in class alluxio.proto.journal.File.CompleteFileEntry
 
newBuilderForType() - Method in class alluxio.proto.journal.File.DeleteFileEntry
 
newBuilderForType(GeneratedMessage.BuilderParent) - Method in class alluxio.proto.journal.File.DeleteFileEntry
 
newBuilderForType() - Method in class alluxio.proto.journal.File.DeleteMountPointEntry
 
newBuilderForType(GeneratedMessage.BuilderParent) - Method in class alluxio.proto.journal.File.DeleteMountPointEntry
 
newBuilderForType() - Method in class alluxio.proto.journal.File.InodeDirectoryEntry
 
newBuilderForType(GeneratedMessage.BuilderParent) - Method in class alluxio.proto.journal.File.InodeDirectoryEntry
 
newBuilderForType() - Method in class alluxio.proto.journal.File.InodeDirectoryIdGeneratorEntry
 
newBuilderForType(GeneratedMessage.BuilderParent) - Method in class alluxio.proto.journal.File.InodeDirectoryIdGeneratorEntry
 
newBuilderForType() - Method in class alluxio.proto.journal.File.InodeFileEntry
 
newBuilderForType(GeneratedMessage.BuilderParent) - Method in class alluxio.proto.journal.File.InodeFileEntry
 
newBuilderForType() - Method in class alluxio.proto.journal.File.InodeLastModificationTimeEntry
 
newBuilderForType(GeneratedMessage.BuilderParent) - Method in class alluxio.proto.journal.File.InodeLastModificationTimeEntry
 
newBuilderForType() - Method in class alluxio.proto.journal.File.PersistDirectoryEntry
 
newBuilderForType(GeneratedMessage.BuilderParent) - Method in class alluxio.proto.journal.File.PersistDirectoryEntry
 
newBuilderForType() - Method in class alluxio.proto.journal.File.PersistFileEntry
 
newBuilderForType(GeneratedMessage.BuilderParent) - Method in class alluxio.proto.journal.File.PersistFileEntry
 
newBuilderForType() - Method in class alluxio.proto.journal.File.ReinitializeFileEntry
 
newBuilderForType(GeneratedMessage.BuilderParent) - Method in class alluxio.proto.journal.File.ReinitializeFileEntry
 
newBuilderForType() - Method in class alluxio.proto.journal.File.RenameEntry
 
newBuilderForType(GeneratedMessage.BuilderParent) - Method in class alluxio.proto.journal.File.RenameEntry
 
newBuilderForType() - Method in class alluxio.proto.journal.File.SetAttributeEntry
 
newBuilderForType(GeneratedMessage.BuilderParent) - Method in class alluxio.proto.journal.File.SetAttributeEntry
 
newBuilderForType() - Method in class alluxio.proto.journal.File.StringPairEntry
 
newBuilderForType(GeneratedMessage.BuilderParent) - Method in class alluxio.proto.journal.File.StringPairEntry
 
newBuilderForType() - Method in class alluxio.proto.journal.File.UpdateUfsModeEntry
 
newBuilderForType(GeneratedMessage.BuilderParent) - Method in class alluxio.proto.journal.File.UpdateUfsModeEntry
 
newBuilderForType() - Method in class alluxio.proto.journal.Journal.JournalEntry
 
newBuilderForType(GeneratedMessage.BuilderParent) - Method in class alluxio.proto.journal.Journal.JournalEntry
 
newBuilderForType() - Method in class alluxio.proto.journal.KeyValue.CompletePartitionEntry
 
newBuilderForType(GeneratedMessage.BuilderParent) - Method in class alluxio.proto.journal.KeyValue.CompletePartitionEntry
 
newBuilderForType() - Method in class alluxio.proto.journal.KeyValue.CompleteStoreEntry
 
newBuilderForType(GeneratedMessage.BuilderParent) - Method in class alluxio.proto.journal.KeyValue.CompleteStoreEntry
 
newBuilderForType() - Method in class alluxio.proto.journal.KeyValue.CreateStoreEntry
 
newBuilderForType(GeneratedMessage.BuilderParent) - Method in class alluxio.proto.journal.KeyValue.CreateStoreEntry
 
newBuilderForType() - Method in class alluxio.proto.journal.KeyValue.DeleteStoreEntry
 
newBuilderForType(GeneratedMessage.BuilderParent) - Method in class alluxio.proto.journal.KeyValue.DeleteStoreEntry
 
newBuilderForType() - Method in class alluxio.proto.journal.KeyValue.MergeStoreEntry
 
newBuilderForType(GeneratedMessage.BuilderParent) - Method in class alluxio.proto.journal.KeyValue.MergeStoreEntry
 
newBuilderForType() - Method in class alluxio.proto.journal.KeyValue.RenameStoreEntry
 
newBuilderForType(GeneratedMessage.BuilderParent) - Method in class alluxio.proto.journal.KeyValue.RenameStoreEntry
 
newBuilderForType() - Method in class alluxio.proto.journal.Lineage.DeleteLineageEntry
 
newBuilderForType(GeneratedMessage.BuilderParent) - Method in class alluxio.proto.journal.Lineage.DeleteLineageEntry
 
newBuilderForType() - Method in class alluxio.proto.journal.Lineage.LineageEntry
 
newBuilderForType(GeneratedMessage.BuilderParent) - Method in class alluxio.proto.journal.Lineage.LineageEntry
 
newBuilderForType() - Method in class alluxio.proto.journal.Lineage.LineageIdGeneratorEntry
 
newBuilderForType(GeneratedMessage.BuilderParent) - Method in class alluxio.proto.journal.Lineage.LineageIdGeneratorEntry
 
newByteArrayFromByteBuffer(ByteBuffer) - Static method in class alluxio.util.io.BufferUtils
Creates a byte array from the given ByteBuffer, the position property of input ByteBuffer remains unchanged.
newStorageDir(StorageTier, int, long, String) - Static method in class alluxio.worker.block.meta.StorageDir
Factory method to create StorageDir.
newStorageTier(String) - Static method in class alluxio.worker.block.meta.StorageTier
Factory method to create StorageTier.
next() - Method in interface alluxio.client.keyvalue.KeyValueIterator
Throws a NoSuchElementException if there are no more pairs.
next() - Method in class alluxio.client.keyvalue.KeyValueStoreIterator
 
next() - Method in interface alluxio.master.journal.JournalFileParser
Parses a journal file and returns the next entry from the journal file.
next() - Method in class alluxio.master.journal.ufs.UfsJournalFileParser
 
NEXT_CONTAINER_ID_FIELD_NUMBER - Static variable in class alluxio.proto.journal.Block.BlockContainerIdGeneratorEntry
 
nextKey(ByteBuffer, PayloadReader) - Method in interface alluxio.client.keyvalue.Index
Gets the next key relative to the current provided key.
nextKey(ByteBuffer, PayloadReader) - Method in class alluxio.client.keyvalue.LinearProbingIndex
 
NO_ACCESS_VALUE - Static variable in enum alluxio.proto.journal.File.UfsMode
NO_ACCESS = 0;
NO_CACHE_FIELD_NUMBER - Static variable in class alluxio.proto.dataserver.Protocol.OpenUfsBlockOptions
 
NO_PARENT - Static variable in class alluxio.master.file.meta.InodeTree
Value to be used for an inode with no parent.
NO_SUCH_BUCKET - Static variable in class alluxio.proxy.s3.S3ErrorCode.Name
 
NO_SUCH_BUCKET - Static variable in class alluxio.proxy.s3.S3ErrorCode
 
NO_SUCH_KEY - Static variable in class alluxio.proxy.s3.S3ErrorCode.Name
 
NO_SUCH_KEY - Static variable in class alluxio.proxy.s3.S3ErrorCode
 
NO_SUCH_UPLOAD - Static variable in class alluxio.proxy.s3.S3ErrorCode.Name
 
NO_SUCH_UPLOAD - Static variable in class alluxio.proxy.s3.S3ErrorCode
 
NO_TTL - Static variable in class alluxio.Constants
 
NonUniqueFieldIndex<T> - Class in alluxio.collections
A class representing a non-unique index.
NonUniqueFieldIndex(IndexDefinition<T>) - Constructor for class alluxio.collections.NonUniqueFieldIndex
Constructs a new NonUniqueFieldIndex instance.
NOOP - Static variable in class alluxio.master.file.RpcContext
 
NoopBlockDeletionContext - Class in alluxio.master.file
Implementation of DefaultBlockDeletionContext which does nothing.
NoopBlockDeletionContext() - Constructor for class alluxio.master.file.NoopBlockDeletionContext
 
NoopJournal - Class in alluxio.master.journal.noop
Implementation of Journal that does nothing.
NoopJournal() - Constructor for class alluxio.master.journal.noop.NoopJournal
Creates a new instance of NoopJournal.
NoopJournalContext - Class in alluxio.master.journal
Noop version of JournalContext.
NoopJournalContext() - Constructor for class alluxio.master.journal.NoopJournalContext
Constructs the NoopJournalContext.
NoopJournalReader - Class in alluxio.master.journal.noop
Implementation of JournalReader that does nothing.
NoopJournalReader() - Constructor for class alluxio.master.journal.noop.NoopJournalReader
Creates a new instance of NoopJournalReader.
NoopJournalSystem - Class in alluxio.master.journal.noop
Journal system which doesn't do anything.
NoopJournalSystem() - Constructor for class alluxio.master.journal.noop.NoopJournalSystem
Constructs a new NoopJournalSystem.
NoopMaster - Class in alluxio.master
Master implementation that does nothing.
NoopMaster() - Constructor for class alluxio.master.NoopMaster
Creates a new NoopMaster.
NoopMaster(String) - Constructor for class alluxio.master.NoopMaster
Creates a new NoopMaster with the given name.
NoopUfsAbsentPathCache - Class in alluxio.master.file.meta
This is a noop version of UfsAbsentPathCache.
NoopUfsAbsentPathCache() - Constructor for class alluxio.master.file.meta.NoopUfsAbsentPathCache
Creates a new instance of NoopUfsAbsentPathCache.
NoopUfsDeleter - Class in alluxio.master.file
A noop version of the UfsDeleter.
NoopUfsDeleter() - Constructor for class alluxio.master.file.NoopUfsDeleter
 
normalizePath(String) - Static method in class alluxio.AlluxioURI
Normalize the path component of the AlluxioURI, by replacing all "//" and "\\" with "/", and trimming trailing slash from non-root path (ignoring windows drive).
normalizePath(String, String) - Static method in class alluxio.util.io.PathUtils
Adds a trailing separator if it does not exist in path.
NoSaslTransportProvider - Class in alluxio.security.authentication
If authentication type is AuthType.NOSASL, we use this transport provider which simply uses default Thrift TTransport.
NoSaslTransportProvider() - Constructor for class alluxio.security.authentication.NoSaslTransportProvider
Constructor for transport provider when authentication type is AuthType.NOSASL.
not() - Method in enum alluxio.security.authorization.Mode.Bits
 
NOT_FOUND_VALUE - Static variable in enum alluxio.proto.status.Status.PStatus
NOT_FOUND = 5;
NotFoundException - Exception in alluxio.exception.status
Exception indicating that some requested entity (e.g., file or directory) was not found.
NotFoundException(String) - Constructor for exception alluxio.exception.status.NotFoundException
 
NotFoundException(Throwable) - Constructor for exception alluxio.exception.status.NotFoundException
 
NotFoundException(String, Throwable) - Constructor for exception alluxio.exception.status.NotFoundException
 
notifyPrimaryMasterStarted() - Method in class alluxio.master.DefaultSafeModeManager
 
notifyPrimaryMasterStarted() - Method in interface alluxio.master.SafeModeManager
Notifies SafeModeManager that the primary master is started.
notifyRpcServerStarted() - Method in class alluxio.master.DefaultSafeModeManager
 
notifyRpcServerStarted() - Method in interface alluxio.master.SafeModeManager
Notifies SafeModeManager that the RPC server is started.
notifySuccess() - Method in class alluxio.multi.process.MultiProcessCluster
Informs the cluster that the test succeeded.
notifySyncedPath(String, DescendantType) - Method in class alluxio.master.file.meta.UfsSyncPathCache
Notifies the cache that the path was synced.
notStarted() - Static method in class alluxio.master.file.StartupConsistencyCheck
 

O

OBJECT_PARAM - Static variable in class alluxio.proxy.s3.S3RestServiceHandler
 
ObjectPermissions(String, String, short) - Constructor for class alluxio.underfs.ObjectUnderFileSystem.ObjectPermissions
Creates a new ObjectPermissions.
ObjectStatus(String, String, long, long) - Constructor for class alluxio.underfs.ObjectUnderFileSystem.ObjectStatus
 
ObjectStatus(String) - Constructor for class alluxio.underfs.ObjectUnderFileSystem.ObjectStatus
 
ObjectUnderFileSystem - Class in alluxio.underfs
An object based abstract UnderFileSystem.
ObjectUnderFileSystem(AlluxioURI, UnderFileSystemConfiguration) - Constructor for class alluxio.underfs.ObjectUnderFileSystem
Constructs an ObjectUnderFileSystem.
ObjectUnderFileSystem.DeleteBuffer - Class in alluxio.underfs
Objects added to a ObjectUnderFileSystem.DeleteBuffer will be deleted in batches.
ObjectUnderFileSystem.DeleteBuffer.DeleteThread - Class in alluxio.underfs
Thread class to delete a batch of objects.
ObjectUnderFileSystem.ObjectListingChunk - Interface in alluxio.underfs
A chunk of listing results.
ObjectUnderFileSystem.ObjectPermissions - Class in alluxio.underfs
Permissions in object UFS.
ObjectUnderFileSystem.ObjectStatus - Class in alluxio.underfs
Information about a single object in object UFS.
OFFSET_FIELD_NUMBER - Static variable in class alluxio.proto.dataserver.Protocol.ReadRequest
 
OFFSET_FIELD_NUMBER - Static variable in class alluxio.proto.dataserver.Protocol.WriteRequest
 
OFFSET_IN_FILE_FIELD_NUMBER - Static variable in class alluxio.proto.dataserver.Protocol.OpenUfsBlockOptions
 
OK_VALUE - Static variable in enum alluxio.proto.status.Status.PStatus
OK = 0;
OLD_STORE_ID_FIELD_NUMBER - Static variable in class alluxio.proto.journal.KeyValue.RenameStoreEntry
 
onAbortBlock(long, long) - Method in class alluxio.worker.block.AbstractBlockStoreEventListener
 
onAbortBlock(long, long) - Method in class alluxio.worker.block.BlockMetricsReporter
 
onAbortBlock(long, long) - Method in interface alluxio.worker.block.BlockStoreEventListener
Actions when aborting a temporary block.
onAccessBlock(long, long) - Method in class alluxio.worker.block.AbstractBlockStoreEventListener
 
onAccessBlock(long, long) - Method in class alluxio.worker.block.BlockMetricsReporter
 
onAccessBlock(long, long) - Method in interface alluxio.worker.block.BlockStoreEventListener
Actions when accessing a block.
onAccessBlock(long, long) - Method in class alluxio.worker.block.evictor.LRFUEvictor
 
onAccessBlock(long, long) - Method in class alluxio.worker.block.evictor.LRUEvictor
 
onCommitBlock(long, long, BlockStoreLocation) - Method in class alluxio.worker.block.AbstractBlockStoreEventListener
 
onCommitBlock(long, long, BlockStoreLocation) - Method in interface alluxio.worker.block.BlockStoreEventListener
Actions when committing a temporary block to a BlockStoreLocation.
onCommitBlock(long, long, BlockStoreLocation) - Method in class alluxio.worker.block.evictor.LRFUEvictor
 
onCommitBlock(long, long, BlockStoreLocation) - Method in class alluxio.worker.block.evictor.LRUEvictor
 
ONLY_RESERVE_SPACE_FIELD_NUMBER - Static variable in class alluxio.proto.dataserver.Protocol.LocalBlockCreateRequest
 
onMoveBlockByClient(long, long, BlockStoreLocation, BlockStoreLocation) - Method in class alluxio.worker.block.AbstractBlockStoreEventListener
 
onMoveBlockByClient(long, long, BlockStoreLocation, BlockStoreLocation) - Method in class alluxio.worker.block.BlockHeartbeatReporter
 
onMoveBlockByClient(long, long, BlockStoreLocation, BlockStoreLocation) - Method in class alluxio.worker.block.BlockMetricsReporter
 
onMoveBlockByClient(long, long, BlockStoreLocation, BlockStoreLocation) - Method in interface alluxio.worker.block.BlockStoreEventListener
Actions when moving a block by a client from a BlockStoreLocation to another.
onMoveBlockByWorker(long, long, BlockStoreLocation, BlockStoreLocation) - Method in class alluxio.worker.block.AbstractBlockStoreEventListener
 
onMoveBlockByWorker(long, long, BlockStoreLocation, BlockStoreLocation) - Method in class alluxio.worker.block.BlockHeartbeatReporter
 
onMoveBlockByWorker(long, long, BlockStoreLocation, BlockStoreLocation) - Method in class alluxio.worker.block.BlockMetricsReporter
 
onMoveBlockByWorker(long, long, BlockStoreLocation, BlockStoreLocation) - Method in interface alluxio.worker.block.BlockStoreEventListener
Actions when moving a block by a worker from a BlockStoreLocation to another.
onRemoveBlockByClient(long, long) - Method in class alluxio.worker.block.AbstractBlockStoreEventListener
 
onRemoveBlockByClient(long, long) - Method in class alluxio.worker.block.BlockHeartbeatReporter
 
onRemoveBlockByClient(long, long) - Method in class alluxio.worker.block.BlockMetricsReporter
 
onRemoveBlockByClient(long, long) - Method in interface alluxio.worker.block.BlockStoreEventListener
Actions when removing an existing block.
onRemoveBlockByClient(long, long) - Method in class alluxio.worker.block.evictor.LRFUEvictor
 
onRemoveBlockByClient(long, long) - Method in class alluxio.worker.block.evictor.LRUEvictor
 
onRemoveBlockByWorker(long, long) - Method in class alluxio.worker.block.AbstractBlockStoreEventListener
 
onRemoveBlockByWorker(long, long) - Method in class alluxio.worker.block.BlockHeartbeatReporter
 
onRemoveBlockByWorker(long, long) - Method in class alluxio.worker.block.BlockMetricsReporter
 
onRemoveBlockByWorker(long, long) - Method in interface alluxio.worker.block.BlockStoreEventListener
Actions when removing an existing block by worker.
onRemoveBlockByWorker(long, long) - Method in class alluxio.worker.block.evictor.LRFUEvictor
 
onRemoveBlockByWorker(long, long) - Method in class alluxio.worker.block.evictor.LRUEvictor
 
onRemoveBlockFromIterator(long) - Method in class alluxio.worker.block.evictor.AbstractEvictor
Performs additional cleanup when a block is removed from the iterator returned by AbstractEvictor.getBlockIterator().
onRemoveBlockFromIterator(long) - Method in class alluxio.worker.block.evictor.LRFUEvictor
 
onRemoveBlockFromIterator(long) - Method in class alluxio.worker.block.evictor.LRUEvictor
 
onStateChange(Consumer<PrimarySelector.State>) - Method in class alluxio.master.AbstractPrimarySelector
 
onStateChange(Consumer<PrimarySelector.State>) - Method in interface alluxio.master.PrimarySelector
Registers a listener to be executed whenever the selector's state updates.
OP_TIME_MS_FIELD_NUMBER - Static variable in class alluxio.proto.journal.File.CompleteFileEntry
 
OP_TIME_MS_FIELD_NUMBER - Static variable in class alluxio.proto.journal.File.DeleteFileEntry
 
OP_TIME_MS_FIELD_NUMBER - Static variable in class alluxio.proto.journal.File.PersistFileEntry
 
OP_TIME_MS_FIELD_NUMBER - Static variable in class alluxio.proto.journal.File.RenameEntry
 
OP_TIME_MS_FIELD_NUMBER - Static variable in class alluxio.proto.journal.File.SetAttributeEntry
 
open() - Method in class alluxio.network.thrift.BootstrapClientTransport
 
open() - Method in class alluxio.network.thrift.BootstrapServerTransport
 
open() - Method in class alluxio.network.thrift.PeekableTransport
 
open(String) - Method in class alluxio.underfs.BaseUnderFileSystem
 
open(String, OpenOptions) - Method in class alluxio.underfs.hdfs.HdfsUnderFileSystem
 
open(String, OpenOptions) - Method in class alluxio.underfs.local.LocalUnderFileSystem
 
open(String, OpenOptions) - Method in class alluxio.underfs.ObjectUnderFileSystem
 
open(String) - Method in interface alluxio.underfs.UnderFileSystem
Opens an InputStream for a file in under filesystem at the indicated path.
open(String, OpenOptions) - Method in interface alluxio.underfs.UnderFileSystem
Opens an InputStream for a file in under filesystem at the indicated path.
open(String) - Method in class alluxio.underfs.UnderFileSystemWithLogging
 
open(String, OpenOptions) - Method in class alluxio.underfs.UnderFileSystemWithLogging
 
OPEN_FILE - Static variable in class alluxio.proxy.PathsRestServiceHandler
 
OPEN_UFS_BLOCK_OPTIONS_FIELD_NUMBER - Static variable in class alluxio.proto.dataserver.Protocol.AsyncCacheRequest
 
OPEN_UFS_BLOCK_OPTIONS_FIELD_NUMBER - Static variable in class alluxio.proto.dataserver.Protocol.ReadRequest
 
openFile(AlluxioURI) - Method in class alluxio.client.file.BaseFileSystem
 
openFile(AlluxioURI, OpenFileOptions) - Method in class alluxio.client.file.BaseFileSystem
 
openFile(AlluxioURI) - Method in interface alluxio.client.file.FileSystem
Convenience method for FileSystem.openFile(AlluxioURI, OpenFileOptions) with default options.
openFile(AlluxioURI, OpenFileOptions) - Method in interface alluxio.client.file.FileSystem
Opens a file for reading.
openFile(String, OpenFileOptions) - Method in class alluxio.proxy.PathsRestServiceHandler
 
OpenFileOptions - Class in alluxio.client.file.options
Method options for opening a file for reading.
openObject(String, OpenOptions) - Method in class alluxio.underfs.cos.COSUnderFileSystem
 
openObject(String, OpenOptions) - Method in class alluxio.underfs.gcs.GCSUnderFileSystem
 
openObject(String, OpenOptions) - Method in class alluxio.underfs.ObjectUnderFileSystem
Internal function to open an input stream to an object.
openObject(String, OpenOptions) - Method in class alluxio.underfs.oss.OSSUnderFileSystem
 
openObject(String, OpenOptions) - Method in class alluxio.underfs.s3a.S3AUnderFileSystem
 
openObject(String, OpenOptions) - Method in class alluxio.underfs.swift.SwiftUnderFileSystem
 
OpenOptions - Class in alluxio.underfs.options
Method options for file locations in UnderFileSystem.
openStore(AlluxioURI) - Method in class alluxio.client.keyvalue.BaseKeyValueSystem
 
openStore(AlluxioURI) - Method in interface alluxio.client.keyvalue.KeyValueSystem
Gets a reader to access a key-value store.
openUfsBlock(long, long, Protocol.OpenUfsBlockOptions) - Method in interface alluxio.worker.block.BlockWorker
Opens a UFS block.
openUfsBlock(long, long, Protocol.OpenUfsBlockOptions) - Method in class alluxio.worker.block.DefaultBlockWorker
 
openUfsFile(long, String, OpenUfsFileTOptions, AsyncMethodCallback) - Method in class alluxio.thrift.FileSystemWorkerClientService.AsyncClient
 
openUfsFile(long, String, OpenUfsFileTOptions, AsyncMethodCallback) - Method in interface alluxio.thrift.FileSystemWorkerClientService.AsyncIface
 
openUfsFile() - Constructor for class alluxio.thrift.FileSystemWorkerClientService.AsyncProcessor.openUfsFile
 
openUfsFile(long, String, OpenUfsFileTOptions) - Method in class alluxio.thrift.FileSystemWorkerClientService.Client
 
openUfsFile(long, String, OpenUfsFileTOptions) - Method in interface alluxio.thrift.FileSystemWorkerClientService.Iface
Opens an existing file in the under file system for reading.
openUfsFile() - Constructor for class alluxio.thrift.FileSystemWorkerClientService.Processor.openUfsFile
 
openUfsFile(long, String, OpenUfsFileTOptions) - Method in class alluxio.worker.file.FileSystemWorkerClientServiceHandler
 
openUfsFile_args() - Constructor for class alluxio.thrift.FileSystemWorkerClientService.openUfsFile_args
 
openUfsFile_args(long, String, OpenUfsFileTOptions) - Constructor for class alluxio.thrift.FileSystemWorkerClientService.openUfsFile_args
 
openUfsFile_args(FileSystemWorkerClientService.openUfsFile_args) - Constructor for class alluxio.thrift.FileSystemWorkerClientService.openUfsFile_args
Performs a deep copy on other.
openUfsFile_call(long, String, OpenUfsFileTOptions, AsyncMethodCallback, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class alluxio.thrift.FileSystemWorkerClientService.AsyncClient.openUfsFile_call
 
openUfsFile_result() - Constructor for class alluxio.thrift.FileSystemWorkerClientService.openUfsFile_result
 
openUfsFile_result(OpenUfsFileTResponse, AlluxioTException) - Constructor for class alluxio.thrift.FileSystemWorkerClientService.openUfsFile_result
 
openUfsFile_result(FileSystemWorkerClientService.openUfsFile_result) - Constructor for class alluxio.thrift.FileSystemWorkerClientService.openUfsFile_result
Performs a deep copy on other.
OpenUfsFileOptions - Class in alluxio.client.file.options
Options for opening a UFS file.
OpenUfsFileTOptions - Class in alluxio.thrift
 
OpenUfsFileTOptions() - Constructor for class alluxio.thrift.OpenUfsFileTOptions
 
OpenUfsFileTOptions(OpenUfsFileTOptions) - Constructor for class alluxio.thrift.OpenUfsFileTOptions
Performs a deep copy on other.
OpenUfsFileTOptions._Fields - Enum in alluxio.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
OpenUfsFileTResponse - Class in alluxio.thrift
 
OpenUfsFileTResponse() - Constructor for class alluxio.thrift.OpenUfsFileTResponse
 
OpenUfsFileTResponse(long) - Constructor for class alluxio.thrift.OpenUfsFileTResponse
 
OpenUfsFileTResponse(OpenUfsFileTResponse) - Constructor for class alluxio.thrift.OpenUfsFileTResponse
Performs a deep copy on other.
OpenUfsFileTResponse._Fields - Enum in alluxio.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
OptionalString - Class in alluxio.thrift
 
OptionalString() - Constructor for class alluxio.thrift.OptionalString
 
OptionalString(String) - Constructor for class alluxio.thrift.OptionalString
 
OptionalString(OptionalString) - Constructor for class alluxio.thrift.OptionalString
Performs a deep copy on other.
OptionalString - Class in alluxio.wire
Wire type for an optional string.
OptionalString(Optional<String>) - Constructor for class alluxio.wire.OptionalString
 
OptionalString._Fields - Enum in alluxio.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
or(Mode.Bits) - Method in enum alluxio.security.authorization.Mode.Bits
 
OS_LOGIN_MODULE_NAME - Static variable in class alluxio.security.login.LoginModuleConfigurationUtils
Login module according to different OS type.
OS_NAME - Static variable in class alluxio.util.OSUtils
The OS name.
OS_PRINCIPAL_CLASS_NAME - Static variable in class alluxio.security.login.LoginModuleConfigurationUtils
Class name of Principal according to different OS type.
OSS_ACCESS_KEY - Static variable in class alluxio.PropertyKey.Name
 
OSS_ACCESS_KEY - Static variable in class alluxio.PropertyKey
 
OSS_ENDPOINT_KEY - Static variable in class alluxio.PropertyKey.Name
 
OSS_ENDPOINT_KEY - Static variable in class alluxio.PropertyKey
 
OSS_SECRET_KEY - Static variable in class alluxio.PropertyKey.Name
 
OSS_SECRET_KEY - Static variable in class alluxio.PropertyKey
 
OSSInputStream - Class in alluxio.underfs.oss
A stream for reading a file from OSS.
OSSOutputStream - Class in alluxio.underfs.oss
A stream for writing a file into OSS.
OSSOutputStream(String, String, OSSClient) - Constructor for class alluxio.underfs.oss.OSSOutputStream
Creates a name instance of OSSOutputStream.
OSSUnderFileSystem - Class in alluxio.underfs.oss
Aliyun OSS UnderFileSystem implementation.
OSSUnderFileSystem(AlluxioURI, OSSClient, String, UnderFileSystemConfiguration) - Constructor for class alluxio.underfs.oss.OSSUnderFileSystem
Constructor for OSSUnderFileSystem.
OSSUnderFileSystemFactory - Class in alluxio.underfs.oss
Factory for creating OSSUnderFileSystem.
OSSUnderFileSystemFactory() - Constructor for class alluxio.underfs.oss.OSSUnderFileSystemFactory
Constructs a new OSSUnderFileSystemFactory.
OSUtils - Class in alluxio.util
OS related utility functions.
OUT_OF_RANGE_VALUE - Static variable in enum alluxio.proto.status.Status.PStatus
OUT_OF_RANGE = 11;
outList(String) - Method in class alluxio.collections.PrefixList
Checks whether a prefix of path is not in the prefix list.
OutOfRangeException - Exception in alluxio.exception.status
Exception indicating that and operation was attempted past the valid range.
OutOfRangeException(String) - Constructor for exception alluxio.exception.status.OutOfRangeException
 
OutOfRangeException(Throwable) - Constructor for exception alluxio.exception.status.OutOfRangeException
 
OutOfRangeException(String, Throwable) - Constructor for exception alluxio.exception.status.OutOfRangeException
 
OUTPUT_FILE_IDS_FIELD_NUMBER - Static variable in class alluxio.proto.journal.Lineage.LineageEntry
 
OutStreamOptions - Class in alluxio.client.file.options
Method options for writing a file.
OWNER_FIELD_NUMBER - Static variable in class alluxio.proto.dataserver.Protocol.CreateUfsFileOptions
 
OWNER_FIELD_NUMBER - Static variable in class alluxio.proto.journal.File.InodeDirectoryEntry
 
OWNER_FIELD_NUMBER - Static variable in class alluxio.proto.journal.File.InodeFileEntry
 
OWNER_FIELD_NUMBER - Static variable in class alluxio.proto.journal.File.SetAttributeEntry
 

P

PACKET_SIZE_FIELD_NUMBER - Static variable in class alluxio.proto.dataserver.Protocol.ReadRequest
 
PacketReader - Interface in alluxio.client.block.stream
The interface to read packets.
PacketReader.Factory - Interface in alluxio.client.block.stream
The factory interface to create PacketReaders.
packetSize() - Method in class alluxio.client.block.stream.LocalFilePacketWriter
 
packetSize() - Method in class alluxio.client.block.stream.NettyPacketWriter
 
packetSize() - Method in interface alluxio.client.block.stream.PacketWriter
 
PacketWriter - Interface in alluxio.client.block.stream
The interface to write packets.
PacketWriter.Factory - Class in alluxio.client.block.stream
Factory for PacketWriter.
Pair<T1,T2> - Class in alluxio.collections
A pair representation defined by two elements (of type First and type Second).
Pair(T1, T2) - Constructor for class alluxio.collections.Pair
Constructs and initializes a Pair specified by the two input elements.
parametersToString(Object...) - Static method in class alluxio.util.FormatUtils
Parses a list of Objects into a String.
PARENT_ID_FIELD_NUMBER - Static variable in class alluxio.proto.journal.File.InodeDirectoryEntry
 
PARENT_ID_FIELD_NUMBER - Static variable in class alluxio.proto.journal.File.InodeFileEntry
 
parentExists(String) - Method in class alluxio.underfs.ObjectUnderFileSystem
Treating the object store as a file system, checks if the parent directory exists.
parse(String) - Static method in class alluxio.security.authorization.ModeParser
Parses the given value as a mode.
parse(String) - Static method in class alluxio.underfs.Fingerprint
Parses the input string and returns the fingerprint object.
parseAndValidateArgs(String...) - Method in interface alluxio.cli.Command
Parses and validates the arguments.
parseDelimitedFrom(InputStream) - Static method in class alluxio.proto.dataserver.Protocol.AsyncCacheRequest
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.proto.dataserver.Protocol.AsyncCacheRequest
 
parseDelimitedFrom(InputStream) - Static method in class alluxio.proto.dataserver.Protocol.CreateUfsFileOptions
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.proto.dataserver.Protocol.CreateUfsFileOptions
 
parseDelimitedFrom(InputStream) - Static method in class alluxio.proto.dataserver.Protocol.Heartbeat
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.proto.dataserver.Protocol.Heartbeat
 
parseDelimitedFrom(InputStream) - Static method in class alluxio.proto.dataserver.Protocol.LocalBlockCloseRequest
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.proto.dataserver.Protocol.LocalBlockCloseRequest
 
parseDelimitedFrom(InputStream) - Static method in class alluxio.proto.dataserver.Protocol.LocalBlockCompleteRequest
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.proto.dataserver.Protocol.LocalBlockCompleteRequest
 
parseDelimitedFrom(InputStream) - Static method in class alluxio.proto.dataserver.Protocol.LocalBlockCreateRequest
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.proto.dataserver.Protocol.LocalBlockCreateRequest
 
parseDelimitedFrom(InputStream) - Static method in class alluxio.proto.dataserver.Protocol.LocalBlockCreateResponse
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.proto.dataserver.Protocol.LocalBlockCreateResponse
 
parseDelimitedFrom(InputStream) - Static method in class alluxio.proto.dataserver.Protocol.LocalBlockOpenRequest
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.proto.dataserver.Protocol.LocalBlockOpenRequest
 
parseDelimitedFrom(InputStream) - Static method in class alluxio.proto.dataserver.Protocol.LocalBlockOpenResponse
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.proto.dataserver.Protocol.LocalBlockOpenResponse
 
parseDelimitedFrom(InputStream) - Static method in class alluxio.proto.dataserver.Protocol.OpenUfsBlockOptions
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.proto.dataserver.Protocol.OpenUfsBlockOptions
 
parseDelimitedFrom(InputStream) - Static method in class alluxio.proto.dataserver.Protocol.ReadRequest
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.proto.dataserver.Protocol.ReadRequest
 
parseDelimitedFrom(InputStream) - Static method in class alluxio.proto.dataserver.Protocol.ReadResponse
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.proto.dataserver.Protocol.ReadResponse
 
parseDelimitedFrom(InputStream) - Static method in class alluxio.proto.dataserver.Protocol.Response
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.proto.dataserver.Protocol.Response
 
parseDelimitedFrom(InputStream) - Static method in class alluxio.proto.dataserver.Protocol.WriteRequest
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.proto.dataserver.Protocol.WriteRequest
 
parseDelimitedFrom(InputStream) - Static method in class alluxio.proto.journal.Block.BlockContainerIdGeneratorEntry
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.proto.journal.Block.BlockContainerIdGeneratorEntry
 
parseDelimitedFrom(InputStream) - Static method in class alluxio.proto.journal.Block.BlockInfoEntry
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.proto.journal.Block.BlockInfoEntry
 
parseDelimitedFrom(InputStream) - Static method in class alluxio.proto.journal.Block.DeleteBlockEntry
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.proto.journal.Block.DeleteBlockEntry
 
parseDelimitedFrom(InputStream) - Static method in class alluxio.proto.journal.File.AddMountPointEntry
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.proto.journal.File.AddMountPointEntry
 
parseDelimitedFrom(InputStream) - Static method in class alluxio.proto.journal.File.AsyncPersistRequestEntry
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.proto.journal.File.AsyncPersistRequestEntry
 
parseDelimitedFrom(InputStream) - Static method in class alluxio.proto.journal.File.CompleteFileEntry
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.proto.journal.File.CompleteFileEntry
 
parseDelimitedFrom(InputStream) - Static method in class alluxio.proto.journal.File.DeleteFileEntry
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.proto.journal.File.DeleteFileEntry
 
parseDelimitedFrom(InputStream) - Static method in class alluxio.proto.journal.File.DeleteMountPointEntry
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.proto.journal.File.DeleteMountPointEntry
 
parseDelimitedFrom(InputStream) - Static method in class alluxio.proto.journal.File.InodeDirectoryEntry
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.proto.journal.File.InodeDirectoryEntry
 
parseDelimitedFrom(InputStream) - Static method in class alluxio.proto.journal.File.InodeDirectoryIdGeneratorEntry
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.proto.journal.File.InodeDirectoryIdGeneratorEntry
 
parseDelimitedFrom(InputStream) - Static method in class alluxio.proto.journal.File.InodeFileEntry
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.proto.journal.File.InodeFileEntry
 
parseDelimitedFrom(InputStream) - Static method in class alluxio.proto.journal.File.InodeLastModificationTimeEntry
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.proto.journal.File.InodeLastModificationTimeEntry
 
parseDelimitedFrom(InputStream) - Static method in class alluxio.proto.journal.File.PersistDirectoryEntry
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.proto.journal.File.PersistDirectoryEntry
 
parseDelimitedFrom(InputStream) - Static method in class alluxio.proto.journal.File.PersistFileEntry
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.proto.journal.File.PersistFileEntry
 
parseDelimitedFrom(InputStream) - Static method in class alluxio.proto.journal.File.ReinitializeFileEntry
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.proto.journal.File.ReinitializeFileEntry
 
parseDelimitedFrom(InputStream) - Static method in class alluxio.proto.journal.File.RenameEntry
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.proto.journal.File.RenameEntry
 
parseDelimitedFrom(InputStream) - Static method in class alluxio.proto.journal.File.SetAttributeEntry
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.proto.journal.File.SetAttributeEntry
 
parseDelimitedFrom(InputStream) - Static method in class alluxio.proto.journal.File.StringPairEntry
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.proto.journal.File.StringPairEntry
 
parseDelimitedFrom(InputStream) - Static method in class alluxio.proto.journal.File.UpdateUfsModeEntry
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.proto.journal.File.UpdateUfsModeEntry
 
parseDelimitedFrom(InputStream) - Static method in class alluxio.proto.journal.Journal.JournalEntry
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.proto.journal.Journal.JournalEntry
 
parseDelimitedFrom(InputStream) - Static method in class alluxio.proto.journal.KeyValue.CompletePartitionEntry
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.proto.journal.KeyValue.CompletePartitionEntry
 
parseDelimitedFrom(InputStream) - Static method in class alluxio.proto.journal.KeyValue.CompleteStoreEntry
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.proto.journal.KeyValue.CompleteStoreEntry
 
parseDelimitedFrom(InputStream) - Static method in class alluxio.proto.journal.KeyValue.CreateStoreEntry
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.proto.journal.KeyValue.CreateStoreEntry
 
parseDelimitedFrom(InputStream) - Static method in class alluxio.proto.journal.KeyValue.DeleteStoreEntry
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.proto.journal.KeyValue.DeleteStoreEntry
 
parseDelimitedFrom(InputStream) - Static method in class alluxio.proto.journal.KeyValue.MergeStoreEntry
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.proto.journal.KeyValue.MergeStoreEntry
 
parseDelimitedFrom(InputStream) - Static method in class alluxio.proto.journal.KeyValue.RenameStoreEntry
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.proto.journal.KeyValue.RenameStoreEntry
 
parseDelimitedFrom(InputStream) - Static method in class alluxio.proto.journal.Lineage.DeleteLineageEntry
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.proto.journal.Lineage.DeleteLineageEntry
 
parseDelimitedFrom(InputStream) - Static method in class alluxio.proto.journal.Lineage.LineageEntry
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.proto.journal.Lineage.LineageEntry
 
parseDelimitedFrom(InputStream) - Static method in class alluxio.proto.journal.Lineage.LineageIdGeneratorEntry
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.proto.journal.Lineage.LineageIdGeneratorEntry
 
parseFrom(ByteString) - Static method in class alluxio.proto.dataserver.Protocol.AsyncCacheRequest
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class alluxio.proto.dataserver.Protocol.AsyncCacheRequest
 
parseFrom(byte[]) - Static method in class alluxio.proto.dataserver.Protocol.AsyncCacheRequest
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class alluxio.proto.dataserver.Protocol.AsyncCacheRequest
 
parseFrom(InputStream) - Static method in class alluxio.proto.dataserver.Protocol.AsyncCacheRequest
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.proto.dataserver.Protocol.AsyncCacheRequest
 
parseFrom(CodedInputStream) - Static method in class alluxio.proto.dataserver.Protocol.AsyncCacheRequest
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class alluxio.proto.dataserver.Protocol.AsyncCacheRequest
 
parseFrom(ByteString) - Static method in class alluxio.proto.dataserver.Protocol.CreateUfsFileOptions
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class alluxio.proto.dataserver.Protocol.CreateUfsFileOptions
 
parseFrom(byte[]) - Static method in class alluxio.proto.dataserver.Protocol.CreateUfsFileOptions
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class alluxio.proto.dataserver.Protocol.CreateUfsFileOptions
 
parseFrom(InputStream) - Static method in class alluxio.proto.dataserver.Protocol.CreateUfsFileOptions
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.proto.dataserver.Protocol.CreateUfsFileOptions
 
parseFrom(CodedInputStream) - Static method in class alluxio.proto.dataserver.Protocol.CreateUfsFileOptions
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class alluxio.proto.dataserver.Protocol.CreateUfsFileOptions
 
parseFrom(ByteString) - Static method in class alluxio.proto.dataserver.Protocol.Heartbeat
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class alluxio.proto.dataserver.Protocol.Heartbeat
 
parseFrom(byte[]) - Static method in class alluxio.proto.dataserver.Protocol.Heartbeat
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class alluxio.proto.dataserver.Protocol.Heartbeat
 
parseFrom(InputStream) - Static method in class alluxio.proto.dataserver.Protocol.Heartbeat
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.proto.dataserver.Protocol.Heartbeat
 
parseFrom(CodedInputStream) - Static method in class alluxio.proto.dataserver.Protocol.Heartbeat
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class alluxio.proto.dataserver.Protocol.Heartbeat
 
parseFrom(ByteString) - Static method in class alluxio.proto.dataserver.Protocol.LocalBlockCloseRequest
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class alluxio.proto.dataserver.Protocol.LocalBlockCloseRequest
 
parseFrom(byte[]) - Static method in class alluxio.proto.dataserver.Protocol.LocalBlockCloseRequest
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class alluxio.proto.dataserver.Protocol.LocalBlockCloseRequest
 
parseFrom(InputStream) - Static method in class alluxio.proto.dataserver.Protocol.LocalBlockCloseRequest
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.proto.dataserver.Protocol.LocalBlockCloseRequest
 
parseFrom(CodedInputStream) - Static method in class alluxio.proto.dataserver.Protocol.LocalBlockCloseRequest
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class alluxio.proto.dataserver.Protocol.LocalBlockCloseRequest
 
parseFrom(ByteString) - Static method in class alluxio.proto.dataserver.Protocol.LocalBlockCompleteRequest
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class alluxio.proto.dataserver.Protocol.LocalBlockCompleteRequest
 
parseFrom(byte[]) - Static method in class alluxio.proto.dataserver.Protocol.LocalBlockCompleteRequest
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class alluxio.proto.dataserver.Protocol.LocalBlockCompleteRequest
 
parseFrom(InputStream) - Static method in class alluxio.proto.dataserver.Protocol.LocalBlockCompleteRequest
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.proto.dataserver.Protocol.LocalBlockCompleteRequest
 
parseFrom(CodedInputStream) - Static method in class alluxio.proto.dataserver.Protocol.LocalBlockCompleteRequest
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class alluxio.proto.dataserver.Protocol.LocalBlockCompleteRequest
 
parseFrom(ByteString) - Static method in class alluxio.proto.dataserver.Protocol.LocalBlockCreateRequest
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class alluxio.proto.dataserver.Protocol.LocalBlockCreateRequest
 
parseFrom(byte[]) - Static method in class alluxio.proto.dataserver.Protocol.LocalBlockCreateRequest
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class alluxio.proto.dataserver.Protocol.LocalBlockCreateRequest
 
parseFrom(InputStream) - Static method in class alluxio.proto.dataserver.Protocol.LocalBlockCreateRequest
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.proto.dataserver.Protocol.LocalBlockCreateRequest
 
parseFrom(CodedInputStream) - Static method in class alluxio.proto.dataserver.Protocol.LocalBlockCreateRequest
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class alluxio.proto.dataserver.Protocol.LocalBlockCreateRequest
 
parseFrom(ByteString) - Static method in class alluxio.proto.dataserver.Protocol.LocalBlockCreateResponse
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class alluxio.proto.dataserver.Protocol.LocalBlockCreateResponse
 
parseFrom(byte[]) - Static method in class alluxio.proto.dataserver.Protocol.LocalBlockCreateResponse
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class alluxio.proto.dataserver.Protocol.LocalBlockCreateResponse
 
parseFrom(InputStream) - Static method in class alluxio.proto.dataserver.Protocol.LocalBlockCreateResponse
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.proto.dataserver.Protocol.LocalBlockCreateResponse
 
parseFrom(CodedInputStream) - Static method in class alluxio.proto.dataserver.Protocol.LocalBlockCreateResponse
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class alluxio.proto.dataserver.Protocol.LocalBlockCreateResponse
 
parseFrom(ByteString) - Static method in class alluxio.proto.dataserver.Protocol.LocalBlockOpenRequest
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class alluxio.proto.dataserver.Protocol.LocalBlockOpenRequest
 
parseFrom(byte[]) - Static method in class alluxio.proto.dataserver.Protocol.LocalBlockOpenRequest
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class alluxio.proto.dataserver.Protocol.LocalBlockOpenRequest
 
parseFrom(InputStream) - Static method in class alluxio.proto.dataserver.Protocol.LocalBlockOpenRequest
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.proto.dataserver.Protocol.LocalBlockOpenRequest
 
parseFrom(CodedInputStream) - Static method in class alluxio.proto.dataserver.Protocol.LocalBlockOpenRequest
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class alluxio.proto.dataserver.Protocol.LocalBlockOpenRequest
 
parseFrom(ByteString) - Static method in class alluxio.proto.dataserver.Protocol.LocalBlockOpenResponse
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class alluxio.proto.dataserver.Protocol.LocalBlockOpenResponse
 
parseFrom(byte[]) - Static method in class alluxio.proto.dataserver.Protocol.LocalBlockOpenResponse
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class alluxio.proto.dataserver.Protocol.LocalBlockOpenResponse
 
parseFrom(InputStream) - Static method in class alluxio.proto.dataserver.Protocol.LocalBlockOpenResponse
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.proto.dataserver.Protocol.LocalBlockOpenResponse
 
parseFrom(CodedInputStream) - Static method in class alluxio.proto.dataserver.Protocol.LocalBlockOpenResponse
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class alluxio.proto.dataserver.Protocol.LocalBlockOpenResponse
 
parseFrom(ByteString) - Static method in class alluxio.proto.dataserver.Protocol.OpenUfsBlockOptions
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class alluxio.proto.dataserver.Protocol.OpenUfsBlockOptions
 
parseFrom(byte[]) - Static method in class alluxio.proto.dataserver.Protocol.OpenUfsBlockOptions
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class alluxio.proto.dataserver.Protocol.OpenUfsBlockOptions
 
parseFrom(InputStream) - Static method in class alluxio.proto.dataserver.Protocol.OpenUfsBlockOptions
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.proto.dataserver.Protocol.OpenUfsBlockOptions
 
parseFrom(CodedInputStream) - Static method in class alluxio.proto.dataserver.Protocol.OpenUfsBlockOptions
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class alluxio.proto.dataserver.Protocol.OpenUfsBlockOptions
 
parseFrom(ByteString) - Static method in class alluxio.proto.dataserver.Protocol.ReadRequest
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class alluxio.proto.dataserver.Protocol.ReadRequest
 
parseFrom(byte[]) - Static method in class alluxio.proto.dataserver.Protocol.ReadRequest
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class alluxio.proto.dataserver.Protocol.ReadRequest
 
parseFrom(InputStream) - Static method in class alluxio.proto.dataserver.Protocol.ReadRequest
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.proto.dataserver.Protocol.ReadRequest
 
parseFrom(CodedInputStream) - Static method in class alluxio.proto.dataserver.Protocol.ReadRequest
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class alluxio.proto.dataserver.Protocol.ReadRequest
 
parseFrom(ByteString) - Static method in class alluxio.proto.dataserver.Protocol.ReadResponse
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class alluxio.proto.dataserver.Protocol.ReadResponse
 
parseFrom(byte[]) - Static method in class alluxio.proto.dataserver.Protocol.ReadResponse
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class alluxio.proto.dataserver.Protocol.ReadResponse
 
parseFrom(InputStream) - Static method in class alluxio.proto.dataserver.Protocol.ReadResponse
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.proto.dataserver.Protocol.ReadResponse
 
parseFrom(CodedInputStream) - Static method in class alluxio.proto.dataserver.Protocol.ReadResponse
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class alluxio.proto.dataserver.Protocol.ReadResponse
 
parseFrom(ByteString) - Static method in class alluxio.proto.dataserver.Protocol.Response
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class alluxio.proto.dataserver.Protocol.Response
 
parseFrom(byte[]) - Static method in class alluxio.proto.dataserver.Protocol.Response
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class alluxio.proto.dataserver.Protocol.Response
 
parseFrom(InputStream) - Static method in class alluxio.proto.dataserver.Protocol.Response
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.proto.dataserver.Protocol.Response
 
parseFrom(CodedInputStream) - Static method in class alluxio.proto.dataserver.Protocol.Response
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class alluxio.proto.dataserver.Protocol.Response
 
parseFrom(ByteString) - Static method in class alluxio.proto.dataserver.Protocol.WriteRequest
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class alluxio.proto.dataserver.Protocol.WriteRequest
 
parseFrom(byte[]) - Static method in class alluxio.proto.dataserver.Protocol.WriteRequest
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class alluxio.proto.dataserver.Protocol.WriteRequest
 
parseFrom(InputStream) - Static method in class alluxio.proto.dataserver.Protocol.WriteRequest
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.proto.dataserver.Protocol.WriteRequest
 
parseFrom(CodedInputStream) - Static method in class alluxio.proto.dataserver.Protocol.WriteRequest
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class alluxio.proto.dataserver.Protocol.WriteRequest
 
parseFrom(ByteString) - Static method in class alluxio.proto.journal.Block.BlockContainerIdGeneratorEntry
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class alluxio.proto.journal.Block.BlockContainerIdGeneratorEntry
 
parseFrom(byte[]) - Static method in class alluxio.proto.journal.Block.BlockContainerIdGeneratorEntry
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class alluxio.proto.journal.Block.BlockContainerIdGeneratorEntry
 
parseFrom(InputStream) - Static method in class alluxio.proto.journal.Block.BlockContainerIdGeneratorEntry
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.proto.journal.Block.BlockContainerIdGeneratorEntry
 
parseFrom(CodedInputStream) - Static method in class alluxio.proto.journal.Block.BlockContainerIdGeneratorEntry
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class alluxio.proto.journal.Block.BlockContainerIdGeneratorEntry
 
parseFrom(ByteString) - Static method in class alluxio.proto.journal.Block.BlockInfoEntry
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class alluxio.proto.journal.Block.BlockInfoEntry
 
parseFrom(byte[]) - Static method in class alluxio.proto.journal.Block.BlockInfoEntry
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class alluxio.proto.journal.Block.BlockInfoEntry
 
parseFrom(InputStream) - Static method in class alluxio.proto.journal.Block.BlockInfoEntry
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.proto.journal.Block.BlockInfoEntry
 
parseFrom(CodedInputStream) - Static method in class alluxio.proto.journal.Block.BlockInfoEntry
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class alluxio.proto.journal.Block.BlockInfoEntry
 
parseFrom(ByteString) - Static method in class alluxio.proto.journal.Block.DeleteBlockEntry
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class alluxio.proto.journal.Block.DeleteBlockEntry
 
parseFrom(byte[]) - Static method in class alluxio.proto.journal.Block.DeleteBlockEntry
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class alluxio.proto.journal.Block.DeleteBlockEntry
 
parseFrom(InputStream) - Static method in class alluxio.proto.journal.Block.DeleteBlockEntry
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.proto.journal.Block.DeleteBlockEntry
 
parseFrom(CodedInputStream) - Static method in class alluxio.proto.journal.Block.DeleteBlockEntry
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class alluxio.proto.journal.Block.DeleteBlockEntry
 
parseFrom(ByteString) - Static method in class alluxio.proto.journal.File.AddMountPointEntry
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class alluxio.proto.journal.File.AddMountPointEntry
 
parseFrom(byte[]) - Static method in class alluxio.proto.journal.File.AddMountPointEntry
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class alluxio.proto.journal.File.AddMountPointEntry
 
parseFrom(InputStream) - Static method in class alluxio.proto.journal.File.AddMountPointEntry
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.proto.journal.File.AddMountPointEntry
 
parseFrom(CodedInputStream) - Static method in class alluxio.proto.journal.File.AddMountPointEntry
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class alluxio.proto.journal.File.AddMountPointEntry
 
parseFrom(ByteString) - Static method in class alluxio.proto.journal.File.AsyncPersistRequestEntry
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class alluxio.proto.journal.File.AsyncPersistRequestEntry
 
parseFrom(byte[]) - Static method in class alluxio.proto.journal.File.AsyncPersistRequestEntry
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class alluxio.proto.journal.File.AsyncPersistRequestEntry
 
parseFrom(InputStream) - Static method in class alluxio.proto.journal.File.AsyncPersistRequestEntry
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.proto.journal.File.AsyncPersistRequestEntry
 
parseFrom(CodedInputStream) - Static method in class alluxio.proto.journal.File.AsyncPersistRequestEntry
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class alluxio.proto.journal.File.AsyncPersistRequestEntry
 
parseFrom(ByteString) - Static method in class alluxio.proto.journal.File.CompleteFileEntry
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class alluxio.proto.journal.File.CompleteFileEntry
 
parseFrom(byte[]) - Static method in class alluxio.proto.journal.File.CompleteFileEntry
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class alluxio.proto.journal.File.CompleteFileEntry
 
parseFrom(InputStream) - Static method in class alluxio.proto.journal.File.CompleteFileEntry
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.proto.journal.File.CompleteFileEntry
 
parseFrom(CodedInputStream) - Static method in class alluxio.proto.journal.File.CompleteFileEntry
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class alluxio.proto.journal.File.CompleteFileEntry
 
parseFrom(ByteString) - Static method in class alluxio.proto.journal.File.DeleteFileEntry
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class alluxio.proto.journal.File.DeleteFileEntry
 
parseFrom(byte[]) - Static method in class alluxio.proto.journal.File.DeleteFileEntry
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class alluxio.proto.journal.File.DeleteFileEntry
 
parseFrom(InputStream) - Static method in class alluxio.proto.journal.File.DeleteFileEntry
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.proto.journal.File.DeleteFileEntry
 
parseFrom(CodedInputStream) - Static method in class alluxio.proto.journal.File.DeleteFileEntry
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class alluxio.proto.journal.File.DeleteFileEntry
 
parseFrom(ByteString) - Static method in class alluxio.proto.journal.File.DeleteMountPointEntry
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class alluxio.proto.journal.File.DeleteMountPointEntry
 
parseFrom(byte[]) - Static method in class alluxio.proto.journal.File.DeleteMountPointEntry
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class alluxio.proto.journal.File.DeleteMountPointEntry
 
parseFrom(InputStream) - Static method in class alluxio.proto.journal.File.DeleteMountPointEntry
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.proto.journal.File.DeleteMountPointEntry
 
parseFrom(CodedInputStream) - Static method in class alluxio.proto.journal.File.DeleteMountPointEntry
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class alluxio.proto.journal.File.DeleteMountPointEntry
 
parseFrom(ByteString) - Static method in class alluxio.proto.journal.File.InodeDirectoryEntry
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class alluxio.proto.journal.File.InodeDirectoryEntry
 
parseFrom(byte[]) - Static method in class alluxio.proto.journal.File.InodeDirectoryEntry
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class alluxio.proto.journal.File.InodeDirectoryEntry
 
parseFrom(InputStream) - Static method in class alluxio.proto.journal.File.InodeDirectoryEntry
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.proto.journal.File.InodeDirectoryEntry
 
parseFrom(CodedInputStream) - Static method in class alluxio.proto.journal.File.InodeDirectoryEntry
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class alluxio.proto.journal.File.InodeDirectoryEntry
 
parseFrom(ByteString) - Static method in class alluxio.proto.journal.File.InodeDirectoryIdGeneratorEntry
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class alluxio.proto.journal.File.InodeDirectoryIdGeneratorEntry
 
parseFrom(byte[]) - Static method in class alluxio.proto.journal.File.InodeDirectoryIdGeneratorEntry
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class alluxio.proto.journal.File.InodeDirectoryIdGeneratorEntry
 
parseFrom(InputStream) - Static method in class alluxio.proto.journal.File.InodeDirectoryIdGeneratorEntry
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.proto.journal.File.InodeDirectoryIdGeneratorEntry
 
parseFrom(CodedInputStream) - Static method in class alluxio.proto.journal.File.InodeDirectoryIdGeneratorEntry
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class alluxio.proto.journal.File.InodeDirectoryIdGeneratorEntry
 
parseFrom(ByteString) - Static method in class alluxio.proto.journal.File.InodeFileEntry
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class alluxio.proto.journal.File.InodeFileEntry
 
parseFrom(byte[]) - Static method in class alluxio.proto.journal.File.InodeFileEntry
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class alluxio.proto.journal.File.InodeFileEntry
 
parseFrom(InputStream) - Static method in class alluxio.proto.journal.File.InodeFileEntry
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.proto.journal.File.InodeFileEntry
 
parseFrom(CodedInputStream) - Static method in class alluxio.proto.journal.File.InodeFileEntry
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class alluxio.proto.journal.File.InodeFileEntry
 
parseFrom(ByteString) - Static method in class alluxio.proto.journal.File.InodeLastModificationTimeEntry
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class alluxio.proto.journal.File.InodeLastModificationTimeEntry
 
parseFrom(byte[]) - Static method in class alluxio.proto.journal.File.InodeLastModificationTimeEntry
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class alluxio.proto.journal.File.InodeLastModificationTimeEntry
 
parseFrom(InputStream) - Static method in class alluxio.proto.journal.File.InodeLastModificationTimeEntry
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.proto.journal.File.InodeLastModificationTimeEntry
 
parseFrom(CodedInputStream) - Static method in class alluxio.proto.journal.File.InodeLastModificationTimeEntry
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class alluxio.proto.journal.File.InodeLastModificationTimeEntry
 
parseFrom(ByteString) - Static method in class alluxio.proto.journal.File.PersistDirectoryEntry
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class alluxio.proto.journal.File.PersistDirectoryEntry
 
parseFrom(byte[]) - Static method in class alluxio.proto.journal.File.PersistDirectoryEntry
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class alluxio.proto.journal.File.PersistDirectoryEntry
 
parseFrom(InputStream) - Static method in class alluxio.proto.journal.File.PersistDirectoryEntry
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.proto.journal.File.PersistDirectoryEntry
 
parseFrom(CodedInputStream) - Static method in class alluxio.proto.journal.File.PersistDirectoryEntry
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class alluxio.proto.journal.File.PersistDirectoryEntry
 
parseFrom(ByteString) - Static method in class alluxio.proto.journal.File.PersistFileEntry
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class alluxio.proto.journal.File.PersistFileEntry
 
parseFrom(byte[]) - Static method in class alluxio.proto.journal.File.PersistFileEntry
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class alluxio.proto.journal.File.PersistFileEntry
 
parseFrom(InputStream) - Static method in class alluxio.proto.journal.File.PersistFileEntry
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.proto.journal.File.PersistFileEntry
 
parseFrom(CodedInputStream) - Static method in class alluxio.proto.journal.File.PersistFileEntry
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class alluxio.proto.journal.File.PersistFileEntry
 
parseFrom(ByteString) - Static method in class alluxio.proto.journal.File.ReinitializeFileEntry
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class alluxio.proto.journal.File.ReinitializeFileEntry
 
parseFrom(byte[]) - Static method in class alluxio.proto.journal.File.ReinitializeFileEntry
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class alluxio.proto.journal.File.ReinitializeFileEntry
 
parseFrom(InputStream) - Static method in class alluxio.proto.journal.File.ReinitializeFileEntry
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.proto.journal.File.ReinitializeFileEntry
 
parseFrom(CodedInputStream) - Static method in class alluxio.proto.journal.File.ReinitializeFileEntry
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class alluxio.proto.journal.File.ReinitializeFileEntry
 
parseFrom(ByteString) - Static method in class alluxio.proto.journal.File.RenameEntry
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class alluxio.proto.journal.File.RenameEntry
 
parseFrom(byte[]) - Static method in class alluxio.proto.journal.File.RenameEntry
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class alluxio.proto.journal.File.RenameEntry
 
parseFrom(InputStream) - Static method in class alluxio.proto.journal.File.RenameEntry
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.proto.journal.File.RenameEntry
 
parseFrom(CodedInputStream) - Static method in class alluxio.proto.journal.File.RenameEntry
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class alluxio.proto.journal.File.RenameEntry
 
parseFrom(ByteString) - Static method in class alluxio.proto.journal.File.SetAttributeEntry
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class alluxio.proto.journal.File.SetAttributeEntry
 
parseFrom(byte[]) - Static method in class alluxio.proto.journal.File.SetAttributeEntry
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class alluxio.proto.journal.File.SetAttributeEntry
 
parseFrom(InputStream) - Static method in class alluxio.proto.journal.File.SetAttributeEntry
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.proto.journal.File.SetAttributeEntry
 
parseFrom(CodedInputStream) - Static method in class alluxio.proto.journal.File.SetAttributeEntry
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class alluxio.proto.journal.File.SetAttributeEntry
 
parseFrom(ByteString) - Static method in class alluxio.proto.journal.File.StringPairEntry
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class alluxio.proto.journal.File.StringPairEntry
 
parseFrom(byte[]) - Static method in class alluxio.proto.journal.File.StringPairEntry
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class alluxio.proto.journal.File.StringPairEntry
 
parseFrom(InputStream) - Static method in class alluxio.proto.journal.File.StringPairEntry
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.proto.journal.File.StringPairEntry
 
parseFrom(CodedInputStream) - Static method in class alluxio.proto.journal.File.StringPairEntry
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class alluxio.proto.journal.File.StringPairEntry
 
parseFrom(ByteString) - Static method in class alluxio.proto.journal.File.UpdateUfsModeEntry
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class alluxio.proto.journal.File.UpdateUfsModeEntry
 
parseFrom(byte[]) - Static method in class alluxio.proto.journal.File.UpdateUfsModeEntry
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class alluxio.proto.journal.File.UpdateUfsModeEntry
 
parseFrom(InputStream) - Static method in class alluxio.proto.journal.File.UpdateUfsModeEntry
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.proto.journal.File.UpdateUfsModeEntry
 
parseFrom(CodedInputStream) - Static method in class alluxio.proto.journal.File.UpdateUfsModeEntry
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class alluxio.proto.journal.File.UpdateUfsModeEntry
 
parseFrom(ByteString) - Static method in class alluxio.proto.journal.Journal.JournalEntry
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class alluxio.proto.journal.Journal.JournalEntry
 
parseFrom(byte[]) - Static method in class alluxio.proto.journal.Journal.JournalEntry
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class alluxio.proto.journal.Journal.JournalEntry
 
parseFrom(InputStream) - Static method in class alluxio.proto.journal.Journal.JournalEntry
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.proto.journal.Journal.JournalEntry
 
parseFrom(CodedInputStream) - Static method in class alluxio.proto.journal.Journal.JournalEntry
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class alluxio.proto.journal.Journal.JournalEntry
 
parseFrom(ByteString) - Static method in class alluxio.proto.journal.KeyValue.CompletePartitionEntry
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class alluxio.proto.journal.KeyValue.CompletePartitionEntry
 
parseFrom(byte[]) - Static method in class alluxio.proto.journal.KeyValue.CompletePartitionEntry
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class alluxio.proto.journal.KeyValue.CompletePartitionEntry
 
parseFrom(InputStream) - Static method in class alluxio.proto.journal.KeyValue.CompletePartitionEntry
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.proto.journal.KeyValue.CompletePartitionEntry
 
parseFrom(CodedInputStream) - Static method in class alluxio.proto.journal.KeyValue.CompletePartitionEntry
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class alluxio.proto.journal.KeyValue.CompletePartitionEntry
 
parseFrom(ByteString) - Static method in class alluxio.proto.journal.KeyValue.CompleteStoreEntry
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class alluxio.proto.journal.KeyValue.CompleteStoreEntry
 
parseFrom(byte[]) - Static method in class alluxio.proto.journal.KeyValue.CompleteStoreEntry
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class alluxio.proto.journal.KeyValue.CompleteStoreEntry
 
parseFrom(InputStream) - Static method in class alluxio.proto.journal.KeyValue.CompleteStoreEntry
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.proto.journal.KeyValue.CompleteStoreEntry
 
parseFrom(CodedInputStream) - Static method in class alluxio.proto.journal.KeyValue.CompleteStoreEntry
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class alluxio.proto.journal.KeyValue.CompleteStoreEntry
 
parseFrom(ByteString) - Static method in class alluxio.proto.journal.KeyValue.CreateStoreEntry
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class alluxio.proto.journal.KeyValue.CreateStoreEntry
 
parseFrom(byte[]) - Static method in class alluxio.proto.journal.KeyValue.CreateStoreEntry
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class alluxio.proto.journal.KeyValue.CreateStoreEntry
 
parseFrom(InputStream) - Static method in class alluxio.proto.journal.KeyValue.CreateStoreEntry
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.proto.journal.KeyValue.CreateStoreEntry
 
parseFrom(CodedInputStream) - Static method in class alluxio.proto.journal.KeyValue.CreateStoreEntry
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class alluxio.proto.journal.KeyValue.CreateStoreEntry
 
parseFrom(ByteString) - Static method in class alluxio.proto.journal.KeyValue.DeleteStoreEntry
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class alluxio.proto.journal.KeyValue.DeleteStoreEntry
 
parseFrom(byte[]) - Static method in class alluxio.proto.journal.KeyValue.DeleteStoreEntry
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class alluxio.proto.journal.KeyValue.DeleteStoreEntry
 
parseFrom(InputStream) - Static method in class alluxio.proto.journal.KeyValue.DeleteStoreEntry
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.proto.journal.KeyValue.DeleteStoreEntry
 
parseFrom(CodedInputStream) - Static method in class alluxio.proto.journal.KeyValue.DeleteStoreEntry
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class alluxio.proto.journal.KeyValue.DeleteStoreEntry
 
parseFrom(ByteString) - Static method in class alluxio.proto.journal.KeyValue.MergeStoreEntry
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class alluxio.proto.journal.KeyValue.MergeStoreEntry
 
parseFrom(byte[]) - Static method in class alluxio.proto.journal.KeyValue.MergeStoreEntry
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class alluxio.proto.journal.KeyValue.MergeStoreEntry
 
parseFrom(InputStream) - Static method in class alluxio.proto.journal.KeyValue.MergeStoreEntry
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.proto.journal.KeyValue.MergeStoreEntry
 
parseFrom(CodedInputStream) - Static method in class alluxio.proto.journal.KeyValue.MergeStoreEntry
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class alluxio.proto.journal.KeyValue.MergeStoreEntry
 
parseFrom(ByteString) - Static method in class alluxio.proto.journal.KeyValue.RenameStoreEntry
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class alluxio.proto.journal.KeyValue.RenameStoreEntry
 
parseFrom(byte[]) - Static method in class alluxio.proto.journal.KeyValue.RenameStoreEntry
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class alluxio.proto.journal.KeyValue.RenameStoreEntry
 
parseFrom(InputStream) - Static method in class alluxio.proto.journal.KeyValue.RenameStoreEntry
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.proto.journal.KeyValue.RenameStoreEntry
 
parseFrom(CodedInputStream) - Static method in class alluxio.proto.journal.KeyValue.RenameStoreEntry
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class alluxio.proto.journal.KeyValue.RenameStoreEntry
 
parseFrom(ByteString) - Static method in class alluxio.proto.journal.Lineage.DeleteLineageEntry
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class alluxio.proto.journal.Lineage.DeleteLineageEntry
 
parseFrom(byte[]) - Static method in class alluxio.proto.journal.Lineage.DeleteLineageEntry
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class alluxio.proto.journal.Lineage.DeleteLineageEntry
 
parseFrom(InputStream) - Static method in class alluxio.proto.journal.Lineage.DeleteLineageEntry
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.proto.journal.Lineage.DeleteLineageEntry
 
parseFrom(CodedInputStream) - Static method in class alluxio.proto.journal.Lineage.DeleteLineageEntry
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class alluxio.proto.journal.Lineage.DeleteLineageEntry
 
parseFrom(ByteString) - Static method in class alluxio.proto.journal.Lineage.LineageEntry
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class alluxio.proto.journal.Lineage.LineageEntry
 
parseFrom(byte[]) - Static method in class alluxio.proto.journal.Lineage.LineageEntry
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class alluxio.proto.journal.Lineage.LineageEntry
 
parseFrom(InputStream) - Static method in class alluxio.proto.journal.Lineage.LineageEntry
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.proto.journal.Lineage.LineageEntry
 
parseFrom(CodedInputStream) - Static method in class alluxio.proto.journal.Lineage.LineageEntry
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class alluxio.proto.journal.Lineage.LineageEntry
 
parseFrom(ByteString) - Static method in class alluxio.proto.journal.Lineage.LineageIdGeneratorEntry
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class alluxio.proto.journal.Lineage.LineageIdGeneratorEntry
 
parseFrom(byte[]) - Static method in class alluxio.proto.journal.Lineage.LineageIdGeneratorEntry
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class alluxio.proto.journal.Lineage.LineageIdGeneratorEntry
 
parseFrom(InputStream) - Static method in class alluxio.proto.journal.Lineage.LineageIdGeneratorEntry
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.proto.journal.Lineage.LineageIdGeneratorEntry
 
parseFrom(CodedInputStream) - Static method in class alluxio.proto.journal.Lineage.LineageIdGeneratorEntry
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class alluxio.proto.journal.Lineage.LineageIdGeneratorEntry
 
parseFrom(byte[], ProtoMessage) - Static method in class alluxio.util.proto.ProtoMessage
Parses proto message from bytes given a prototype.
parseInetSocketAddress(String) - Static method in class alluxio.util.network.NetworkAddressUtils
Parses InetSocketAddress from a String.
parseMountInfo(String) - Static method in class alluxio.util.ShellUtils
 
parseQueryString(String) - Static method in class alluxio.util.URIUtils
Parses the given query string, and returns a map of the query parameters.
PARSER - Static variable in class alluxio.proto.dataserver.Protocol.AsyncCacheRequest
 
PARSER - Static variable in class alluxio.proto.dataserver.Protocol.CreateUfsFileOptions
 
PARSER - Static variable in class alluxio.proto.dataserver.Protocol.Heartbeat
 
PARSER - Static variable in class alluxio.proto.dataserver.Protocol.LocalBlockCloseRequest
 
PARSER - Static variable in class alluxio.proto.dataserver.Protocol.LocalBlockCompleteRequest
 
PARSER - Static variable in class alluxio.proto.dataserver.Protocol.LocalBlockCreateRequest
 
PARSER - Static variable in class alluxio.proto.dataserver.Protocol.LocalBlockCreateResponse
 
PARSER - Static variable in class alluxio.proto.dataserver.Protocol.LocalBlockOpenRequest
 
PARSER - Static variable in class alluxio.proto.dataserver.Protocol.LocalBlockOpenResponse
 
PARSER - Static variable in class alluxio.proto.dataserver.Protocol.OpenUfsBlockOptions
 
PARSER - Static variable in class alluxio.proto.dataserver.Protocol.ReadRequest
 
PARSER - Static variable in class alluxio.proto.dataserver.Protocol.ReadResponse
 
PARSER - Static variable in class alluxio.proto.dataserver.Protocol.Response
 
PARSER - Static variable in class alluxio.proto.dataserver.Protocol.WriteRequest
 
PARSER - Static variable in class alluxio.proto.journal.Block.BlockContainerIdGeneratorEntry
 
PARSER - Static variable in class alluxio.proto.journal.Block.BlockInfoEntry
 
PARSER - Static variable in class alluxio.proto.journal.Block.DeleteBlockEntry
 
PARSER - Static variable in class alluxio.proto.journal.File.AddMountPointEntry
 
PARSER - Static variable in class alluxio.proto.journal.File.AsyncPersistRequestEntry
 
PARSER - Static variable in class alluxio.proto.journal.File.CompleteFileEntry
 
PARSER - Static variable in class alluxio.proto.journal.File.DeleteFileEntry
 
PARSER - Static variable in class alluxio.proto.journal.File.DeleteMountPointEntry
 
PARSER - Static variable in class alluxio.proto.journal.File.InodeDirectoryEntry
 
PARSER - Static variable in class alluxio.proto.journal.File.InodeDirectoryIdGeneratorEntry
 
PARSER - Static variable in class alluxio.proto.journal.File.InodeFileEntry
 
PARSER - Static variable in class alluxio.proto.journal.File.InodeLastModificationTimeEntry
 
PARSER - Static variable in class alluxio.proto.journal.File.PersistDirectoryEntry
 
PARSER - Static variable in class alluxio.proto.journal.File.PersistFileEntry
 
PARSER - Static variable in class alluxio.proto.journal.File.ReinitializeFileEntry
 
PARSER - Static variable in class alluxio.proto.journal.File.RenameEntry
 
PARSER - Static variable in class alluxio.proto.journal.File.SetAttributeEntry
 
PARSER - Static variable in class alluxio.proto.journal.File.StringPairEntry
 
PARSER - Static variable in class alluxio.proto.journal.File.UpdateUfsModeEntry
 
PARSER - Static variable in class alluxio.proto.journal.Journal.JournalEntry
 
PARSER - Static variable in class alluxio.proto.journal.KeyValue.CompletePartitionEntry
 
PARSER - Static variable in class alluxio.proto.journal.KeyValue.CompleteStoreEntry
 
PARSER - Static variable in class alluxio.proto.journal.KeyValue.CreateStoreEntry
 
PARSER - Static variable in class alluxio.proto.journal.KeyValue.DeleteStoreEntry
 
PARSER - Static variable in class alluxio.proto.journal.KeyValue.MergeStoreEntry
 
PARSER - Static variable in class alluxio.proto.journal.KeyValue.RenameStoreEntry
 
PARSER - Static variable in class alluxio.proto.journal.Lineage.DeleteLineageEntry
 
PARSER - Static variable in class alluxio.proto.journal.Lineage.LineageEntry
 
PARSER - Static variable in class alluxio.proto.journal.Lineage.LineageIdGeneratorEntry
 
parseSpaceSize(String) - Static method in class alluxio.util.FormatUtils
Parses a String size to Bytes.
parseTimeSize(String) - Static method in class alluxio.util.FormatUtils
Parses a String size to Milliseconds.
parseXmlConfiguration(String) - Method in class alluxio.cli.validation.HadoopConfigurationFileParser
Parse an xml configuration file into a map.
Part() - Constructor for class alluxio.proxy.s3.ListPartsResult.Part
Constructs a default ListPartsResult.Part.
PartialLRUEvictor - Class in alluxio.worker.block.evictor
This class is used to evict old blocks in certain StorageDir by LRU.
PartialLRUEvictor(BlockMetadataManagerView, Allocator) - Constructor for class alluxio.worker.block.evictor.PartialLRUEvictor
Creates a new instance of PartialLRUEvictor.
PartitionInfo - Class in alluxio.thrift
 
PartitionInfo() - Constructor for class alluxio.thrift.PartitionInfo
 
PartitionInfo(ByteBuffer, ByteBuffer, long, int) - Constructor for class alluxio.thrift.PartitionInfo
 
PartitionInfo(PartitionInfo) - Constructor for class alluxio.thrift.PartitionInfo
Performs a deep copy on other.
PartitionInfo._Fields - Enum in alluxio.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
PATH_FIELD_NUMBER - Static variable in class alluxio.proto.dataserver.Protocol.LocalBlockCreateResponse
 
PATH_FIELD_NUMBER - Static variable in class alluxio.proto.dataserver.Protocol.LocalBlockOpenResponse
 
PATH_FIELD_NUMBER - Static variable in class alluxio.proto.journal.File.ReinitializeFileEntry
 
PATH_PARAM - Static variable in class alluxio.proxy.PathsRestServiceHandler
 
PATH_SEPARATOR - Static variable in class alluxio.underfs.ObjectUnderFileSystem
Value used to indicate nested structure.
PATH_SEPARATOR_CHAR - Static variable in class alluxio.underfs.ObjectUnderFileSystem
Value used to indicate nested structure.
PATH_STRING_COMPARE - Static variable in class alluxio.web.UIFileInfo
Provides ordering of UIFileInfo based off a string comparison of the absolute paths.
PATHS_DELETED - Static variable in class alluxio.metrics.MasterMetrics
 
PATHS_MOUNTED - Static variable in class alluxio.metrics.MasterMetrics
 
PATHS_RENAMED - Static variable in class alluxio.metrics.MasterMetrics
 
PATHS_TOTAL - Static variable in class alluxio.metrics.MasterMetrics
 
PATHS_UNMOUNTED - Static variable in class alluxio.metrics.MasterMetrics
 
PathsRestServiceHandler - Class in alluxio.proxy
This class is a REST handler for path resources.
PathsRestServiceHandler(ServletContext) - Constructor for class alluxio.proxy.PathsRestServiceHandler
Constructs a new PathsRestServiceHandler.
PathUtils - Class in alluxio.util.io
Utilities related to both Alluxio paths like AlluxioURI and local file paths.
pauseStateLock() - Method in class alluxio.master.MasterContext
 
PayloadReader - Interface in alluxio.client.keyvalue
Interface to access keys and values from the payload buffer.
PayloadWriter - Interface in alluxio.client.keyvalue
Interface to write to the payload buffer.
PB - Static variable in class alluxio.Constants
 
peek(byte[], int, int) - Method in class alluxio.network.thrift.PeekableTransport
Peaks up to len bytes into buffer buf, starting at offset off.
PeekableTransport - Class in alluxio.network.thrift
A transport that one can peek a given number of bytes from the read stream without changing the read position.
PeekableTransport(TTransport) - Constructor for class alluxio.network.thrift.PeekableTransport
 
Performance - Class in alluxio.examples
Example to show the performance of Alluxio.
Performance.AlluxioReadWorker - Class in alluxio.examples
A worker in Alluxio for read operations.
Performance.AlluxioWriterWorker - Class in alluxio.examples
A worker in Alluxio for write operations.
Performance.GeneralWorker - Class in alluxio.examples
A general worker.
Performance.HdfsWorker - Class in alluxio.examples
A worker for HDFS.
Performance.Worker - Class in alluxio.examples
Base class for workers used in this example.
performIntegrationChecks() - Static method in class alluxio.checker.CheckerUtils
 
PERMISSION_DENIED_VALUE - Static variable in enum alluxio.proto.status.Status.PStatus
PERMISSION_DENIED = 7;
PERMISSION_FIELD_NUMBER - Static variable in class alluxio.proto.journal.File.SetAttributeEntry
 
PermissionChecker - Interface in alluxio.master.file
interface to provide permission check logic.
PermissionDeniedException - Exception in alluxio.exception.status
Exception indicating that the caller does not have permission to execute the specified operation.
PermissionDeniedException(String) - Constructor for exception alluxio.exception.status.PermissionDeniedException
 
PermissionDeniedException(Throwable) - Constructor for exception alluxio.exception.status.PermissionDeniedException
 
PermissionDeniedException(String, Throwable) - Constructor for exception alluxio.exception.status.PermissionDeniedException
 
PERSIST_DIRECTORY_FIELD_NUMBER - Static variable in class alluxio.proto.journal.Journal.JournalEntry
 
PersistCommand - Class in alluxio.cli.fs.command
Persists files or directories currently stored only in Alluxio to the UnderFileSystem.
PersistCommand(FileSystem) - Constructor for class alluxio.cli.fs.command.PersistCommand
 
PersistCommandOptions - Class in alluxio.thrift
 
PersistCommandOptions() - Constructor for class alluxio.thrift.PersistCommandOptions
 
PersistCommandOptions(List<PersistFile>) - Constructor for class alluxio.thrift.PersistCommandOptions
 
PersistCommandOptions(PersistCommandOptions) - Constructor for class alluxio.thrift.PersistCommandOptions
Performs a deep copy on other.
PersistCommandOptions._Fields - Enum in alluxio.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
PERSISTED_FIELD_NUMBER - Static variable in class alluxio.proto.journal.File.SetAttributeEntry
 
PersistedFilesInfo(List<Long>, List<String>) - Constructor for class alluxio.worker.file.FileDataManager.PersistedFilesInfo
 
PERSISTENCE_STATE_FIELD_NUMBER - Static variable in class alluxio.proto.journal.File.InodeDirectoryEntry
 
PERSISTENCE_STATE_FIELD_NUMBER - Static variable in class alluxio.proto.journal.File.InodeFileEntry
 
PersistenceState - Enum in alluxio.master.file.meta
The persistence state of a file in the under-storage system.
persistFile(FileSystem, AlluxioURI) - Static method in class alluxio.client.file.FileSystemUtils
Persists the given file to the under file system.
PersistFile - Class in alluxio.thrift
 
PersistFile() - Constructor for class alluxio.thrift.PersistFile
 
PersistFile(long, List<Long>) - Constructor for class alluxio.thrift.PersistFile
 
PersistFile(PersistFile) - Constructor for class alluxio.thrift.PersistFile
Performs a deep copy on other.
persistFile(long, List<Long>) - Method in class alluxio.worker.file.FileDataManager
Persists the blocks of a file into the under file system.
PersistFile._Fields - Enum in alluxio.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
persistOptions(PersistCommandOptions) - Static method in class alluxio.thrift.FileSystemCommandOptions
 
PinCommand - Class in alluxio.cli.fs.command
Pins the given file or folder (recursively pinning all children if a folder).
PinCommand(FileSystem) - Constructor for class alluxio.cli.fs.command.PinCommand
 
pingService(InetSocketAddress, String) - Static method in class alluxio.util.network.NetworkAddressUtils
Test if the input address is serving an Alluxio service.
PinListSync - Class in alluxio.worker.block
PinListSync periodically syncs the set of pinned inodes from master, and saves the new pinned inodes to the BlockWorker.
PinListSync(BlockWorker, FileSystemMasterClient) - Constructor for class alluxio.worker.block.PinListSync
Creates a new instance of PinListSync.
PINNED_FIELD_NUMBER - Static variable in class alluxio.proto.journal.File.InodeDirectoryEntry
 
PINNED_FIELD_NUMBER - Static variable in class alluxio.proto.journal.File.InodeFileEntry
 
PINNED_FIELD_NUMBER - Static variable in class alluxio.proto.journal.File.SetAttributeEntry
 
PlainSaslClientCallbackHandler - Class in alluxio.security.authentication
A client side callback to put application provided username/password into SASL transport.
PlainSaslClientCallbackHandler(String, String) - Constructor for class alluxio.security.authentication.PlainSaslClientCallbackHandler
Constructs a new client side callback.
PlainSaslServer - Class in alluxio.security.authentication
This class provides PLAIN SASL authentication.
PlainSaslServer.Factory - Class in alluxio.security.authentication
This class is used to create an instances of PlainSaslServer.
PlainSaslServerCallbackHandler - Class in alluxio.security.authentication
A callback that is used by the SASL mechanisms to get further information to complete the authentication.
PlainSaslServerCallbackHandler(AuthenticationProvider, Runnable) - Constructor for class alluxio.security.authentication.PlainSaslServerCallbackHandler
Constructs a new callback handler.
PlainSaslServerProvider - Class in alluxio.security.authentication
The Java SunSASL provider supports CRAM-MD5, DIGEST-MD5 and GSSAPI mechanisms on the server side.
PlainSaslServerProvider() - Constructor for class alluxio.security.authentication.PlainSaslServerProvider
Constructs a new provider for the SASL server when using the PLAIN mechanism.
PlainSaslTransportProvider - Class in alluxio.security.authentication
If authentication type is AuthType.SIMPLE or AuthType.CUSTOM, this is the default transport provider which uses SASL transport.
PlainSaslTransportProvider() - Constructor for class alluxio.security.authentication.PlainSaslTransportProvider
Constructor for transport provider with AuthType.SIMPLE or AuthType.CUSTOM.
plan() - Method in class alluxio.master.lineage.recompute.RecomputePlanner
 
pollFilesToPersist(long) - Method in interface alluxio.master.file.async.AsyncPersistHandler
Polls the files for persistence on the given worker.
pollFilesToPersist(long) - Method in class alluxio.master.file.async.DefaultAsyncPersistHandler
Polls the files to send to the given worker for persistence.
PollingMasterInquireClient - Class in alluxio.master
PollingMasterInquireClient finds the address of the primary master by polling a list of master addresses to see if their RPC servers are serving.
PollingMasterInquireClient(List<InetSocketAddress>, Supplier<RetryPolicy>) - Constructor for class alluxio.master.PollingMasterInquireClient
 
PollingMasterInquireClient.MultiMasterConnectDetails - Class in alluxio.master
Details used to connect to the leader Alluxio master when there are multiple potential leaders.
Pool<T> - Interface in alluxio.resource
Interface representing a pool of resources to be temporarily used and returned.
pop() - Method in class alluxio.util.executor.ControllableQueue
 
populateCounterValues(Map<String, Metric>, Map<String, Counter>, HttpServletRequest) - Method in class alluxio.web.WebInterfaceAbstractMetricsServlet
Populates operation metrics for displaying in the UI.
PortAvailabilityValidationTask - Class in alluxio.cli.validation
Task for validating whether a specific port is available.
PortAvailabilityValidationTask(NetworkAddressUtils.ServiceType, String) - Constructor for class alluxio.cli.validation.PortAvailabilityValidationTask
Creates a new instance of PortAvailabilityValidationTask.
PortCoordination - Class in alluxio.multi.process
Class for coordinating between test suites so that they don't conflict in ports.
PortCoordination() - Constructor for class alluxio.multi.process.PortCoordination
 
PortCoordination.ReservedPort - Class in alluxio.multi.process
A port that has been reserved for the purposes of a single test.
PORTS_PER_MASTER - Static variable in class alluxio.multi.process.MultiProcessCluster
 
PORTS_PER_WORKER - Static variable in class alluxio.multi.process.MultiProcessCluster
 
pos() - Method in class alluxio.client.block.stream.LocalFilePacketReader
 
pos() - Method in class alluxio.client.block.stream.LocalFilePacketWriter
 
pos() - Method in class alluxio.client.block.stream.NettyPacketReader
 
pos() - Method in class alluxio.client.block.stream.NettyPacketWriter
 
pos() - Method in interface alluxio.client.block.stream.PacketReader
 
pos() - Method in interface alluxio.client.block.stream.PacketWriter
 
Positioned - Interface in alluxio
An interface for an object which tracks and can report its current position (for example a stream).
positionedRead(long, byte[], int, int) - Method in class alluxio.client.block.stream.BlockInStream
 
positionedRead(long, byte[], int, int) - Method in class alluxio.client.file.FileInStream
 
positionedRead(long, byte[], int, int) - Method in interface alluxio.client.PositionedReadable
Reads up to the specified number of bytes, from a given position within a file, and return the number of bytes read.
PositionedReadable - Interface in alluxio.client
Stream that permits positional reading.
post(String, Integer, HttpUtils.IProcessInputStream) - Static method in class alluxio.util.network.HttpUtils
Uses the post method to send a url with arguments by http, this method can call RESTful Api.
post(String, Integer) - Static method in class alluxio.util.network.HttpUtils
Uses the post method to send a url with arguments by http, this method can call RESTful Api.
PRECONDITION_FAILED - Static variable in class alluxio.proxy.s3.S3ErrorCode.Name
 
PRECONDITION_FAILED - Static variable in class alluxio.proxy.s3.S3ErrorCode
 
PreconditionMessage - Enum in alluxio.exception
Precondition messages used across Alluxio.
PrefixList - Class in alluxio.collections
Prefix list is used to do file filtering.
PrefixList(List<String>) - Constructor for class alluxio.collections.PrefixList
Prefix list is used to do file filtering.
PrefixList(String, String) - Constructor for class alluxio.collections.PrefixList
Prefix list is used to do file filtering.
prepareFilePath(AlluxioURI, String, FileSystem, UnderFileSystem) - Static method in class alluxio.worker.file.UnderFileSystemUtils
Creates parent directories for path with correct permissions if required.
PrimarySelector - Interface in alluxio.master
Interface for a class which can determine whether the local master is the primary.
PrimarySelector.Factory - Class in alluxio.master
Factory for creating primary selectors.
PrimarySelector.State - Enum in alluxio.master
The state for the primary selector.
PrimarySelectorClient - Class in alluxio.master
Masters use this client to elect a leader.
PrimarySelectorClient(String, String, String) - Constructor for class alluxio.master.PrimarySelectorClient
Constructs a new PrimarySelectorClient.
PrimarySelectorClient.ZookeeperConnectionErrorPolicy - Enum in alluxio.master
Defines supported connection error policies for leader election.
printCommandInfo(Command, PrintWriter) - Static method in class alluxio.cli.fs.command.HelpCommand
Prints the info about a command to the given print writer.
printHelp(String) - Static method in class alluxio.cli.GetConf
Prints the help message.
printHelp(String) - Static method in class alluxio.cli.GetConfKey
Prints the help message.
printHelp(String) - Static method in class alluxio.cli.LogLevel
Prints the help message.
printHelp(String) - Static method in class alluxio.cli.ValidateEnv
Prints the help message.
printMountInfo(Map<String, MountPointInfo>) - Static method in class alluxio.cli.fsadmin.report.UfsCommand
Prints mount information for a mount table.
printNodesResults(Map<CheckerUtils.Status, List<String>>, PrintWriter) - Static method in class alluxio.checker.CheckerUtils
Collects and saves the Status of checked nodes.
printPassInfo(boolean) - Static method in class alluxio.cli.CliUtils
Prints information of the test result.
printUsage() - Method in class alluxio.cli.AbstractShell
Prints usage for all commands.
process(List<Long>) - Method in interface alluxio.master.file.BlockDeletionContext.BlockDeletionListener
Processes block deletion.
process(TProtocol, TProtocol) - Method in class alluxio.master.file.FileSystemMasterClientServiceProcessor
 
process(AlluxioURI, List<Inode<?>>) - Method in class alluxio.master.file.meta.AsyncUfsAbsentPathCache
 
process(AlluxioURI, List<Inode<?>>) - Method in class alluxio.master.file.meta.NoopUfsAbsentPathCache
 
process(AlluxioURI, List<Inode<?>>) - Method in interface alluxio.master.file.meta.UfsAbsentPathCache
Processes the given path for the cache.
Process - Interface in alluxio
Interface representing an Alluxio process.
process(InputStream) - Method in interface alluxio.util.network.HttpUtils.IProcessInputStream
 
PROCESS_TYPE - Static variable in class alluxio.util.CommonUtils
Represents the type of Alluxio process running in this JVM.
PROCESS_TYPE_OPTION - Static variable in class alluxio.AlluxioRemoteLogFilter
Deprecated.
Option name to configure this AlluxioRemoteLogFilter in log4j.properties.
ProcessCheckRunnable(String) - Constructor for class alluxio.master.MasterHealthCheckClient.ProcessCheckRunnable
Creates a new instance of ProcessCheckRunnable.
processExisting(AlluxioURI) - Method in class alluxio.master.file.meta.AsyncUfsAbsentPathCache
 
processExisting(AlluxioURI) - Method in class alluxio.master.file.meta.NoopUfsAbsentPathCache
 
processExisting(AlluxioURI) - Method in interface alluxio.master.file.meta.UfsAbsentPathCache
Processes the given path that already exists.
processJournalEntry(Journal.JournalEntry) - Method in class alluxio.master.block.DefaultBlockMaster
 
processJournalEntry(Journal.JournalEntry) - Method in class alluxio.master.file.DefaultFileSystemMaster
 
processJournalEntry(Journal.JournalEntry) - Method in interface alluxio.master.journal.JournalEntryStateMachine
Applies a journal entry to the state machine.
processJournalEntry(Journal.JournalEntry) - Method in class alluxio.master.keyvalue.DefaultKeyValueMaster
 
processJournalEntry(Journal.JournalEntry) - Method in class alluxio.master.lineage.DefaultLineageMaster
 
processJournalEntry(Journal.JournalEntry) - Method in class alluxio.master.meta.DefaultMetaMaster
 
processJournalEntry(Journal.JournalEntry) - Method in class alluxio.master.metrics.DefaultMetricsMaster
 
processJournalEntry(Journal.JournalEntry) - Method in class alluxio.master.NoopMaster
 
Processor(I) - Constructor for class alluxio.thrift.AlluxioService.Processor
 
Processor(I, Map<String, ProcessFunction<I, ? extends TBase>>) - Constructor for class alluxio.thrift.AlluxioService.Processor
 
Processor(I) - Constructor for class alluxio.thrift.BlockMasterClientService.Processor
 
Processor(I, Map<String, ProcessFunction<I, ? extends TBase>>) - Constructor for class alluxio.thrift.BlockMasterClientService.Processor
 
Processor(I) - Constructor for class alluxio.thrift.BlockMasterWorkerService.Processor
 
Processor(I, Map<String, ProcessFunction<I, ? extends TBase>>) - Constructor for class alluxio.thrift.BlockMasterWorkerService.Processor
 
Processor(I) - Constructor for class alluxio.thrift.BlockWorkerClientService.Processor
 
Processor(I, Map<String, ProcessFunction<I, ? extends TBase>>) - Constructor for class alluxio.thrift.BlockWorkerClientService.Processor
 
Processor(I) - Constructor for class alluxio.thrift.FileSystemMasterClientService.Processor
 
Processor(I, Map<String, ProcessFunction<I, ? extends TBase>>) - Constructor for class alluxio.thrift.FileSystemMasterClientService.Processor
 
Processor(I) - Constructor for class alluxio.thrift.FileSystemMasterWorkerService.Processor
 
Processor(I, Map<String, ProcessFunction<I, ? extends TBase>>) - Constructor for class alluxio.thrift.FileSystemMasterWorkerService.Processor
 
Processor(I) - Constructor for class alluxio.thrift.FileSystemWorkerClientService.Processor
 
Processor(I, Map<String, ProcessFunction<I, ? extends TBase>>) - Constructor for class alluxio.thrift.FileSystemWorkerClientService.Processor
 
Processor(I) - Constructor for class alluxio.thrift.KeyValueMasterClientService.Processor
 
Processor(I, Map<String, ProcessFunction<I, ? extends TBase>>) - Constructor for class alluxio.thrift.KeyValueMasterClientService.Processor
 
Processor(I) - Constructor for class alluxio.thrift.KeyValueWorkerClientService.Processor
 
Processor(I, Map<String, ProcessFunction<I, ? extends TBase>>) - Constructor for class alluxio.thrift.KeyValueWorkerClientService.Processor
 
Processor(I) - Constructor for class alluxio.thrift.LineageMasterClientService.Processor
 
Processor(I, Map<String, ProcessFunction<I, ? extends TBase>>) - Constructor for class alluxio.thrift.LineageMasterClientService.Processor
 
Processor(I) - Constructor for class alluxio.thrift.MetaMasterClientService.Processor
 
Processor(I, Map<String, ProcessFunction<I, ? extends TBase>>) - Constructor for class alluxio.thrift.MetaMasterClientService.Processor
 
Processor(I) - Constructor for class alluxio.thrift.MetaMasterMasterService.Processor
 
Processor(I, Map<String, ProcessFunction<I, ? extends TBase>>) - Constructor for class alluxio.thrift.MetaMasterMasterService.Processor
 
Processor(I) - Constructor for class alluxio.thrift.MetricsMasterClientService.Processor
 
Processor(I, Map<String, ProcessFunction<I, ? extends TBase>>) - Constructor for class alluxio.thrift.MetricsMasterClientService.Processor
 
PROCESSOR_BIT - Static variable in class alluxio.util.OSUtils
The processor bit.
ProcessUtils - Class in alluxio
Utility methods for Alluxio Processes.
ProjectConstants - Class in alluxio
Project constants from compilation time by maven.
PrometheusMetricsServlet - Class in alluxio.metrics.sink
A sink that exposes metrics data in prometheus format by HTTP.
PrometheusMetricsServlet(MetricRegistry) - Constructor for class alluxio.metrics.sink.PrometheusMetricsServlet
Creates a new PrometheusMetricsServlet with a MetricRegistry.
PROMOTE_FIELD_NUMBER - Static variable in class alluxio.proto.dataserver.Protocol.LocalBlockOpenRequest
 
PROMOTE_FIELD_NUMBER - Static variable in class alluxio.proto.dataserver.Protocol.ReadRequest
 
promoteBlock(long, PromoteBlockTOptions, AsyncMethodCallback) - Method in class alluxio.thrift.BlockWorkerClientService.AsyncClient
 
promoteBlock(long, PromoteBlockTOptions, AsyncMethodCallback) - Method in interface alluxio.thrift.BlockWorkerClientService.AsyncIface
 
promoteBlock() - Constructor for class alluxio.thrift.BlockWorkerClientService.AsyncProcessor.promoteBlock
 
promoteBlock(long, PromoteBlockTOptions) - Method in class alluxio.thrift.BlockWorkerClientService.Client
 
promoteBlock(long, PromoteBlockTOptions) - Method in interface alluxio.thrift.BlockWorkerClientService.Iface
Used to promote block on under storage layer to top storage layer when there are more than one storage layers in Alluxio's space.
promoteBlock() - Constructor for class alluxio.thrift.BlockWorkerClientService.Processor.promoteBlock
 
promoteBlock(long, PromoteBlockTOptions) - Method in class alluxio.worker.block.BlockWorkerClientServiceHandler
 
promoteBlock_args() - Constructor for class alluxio.thrift.BlockWorkerClientService.promoteBlock_args
 
promoteBlock_args(long, PromoteBlockTOptions) - Constructor for class alluxio.thrift.BlockWorkerClientService.promoteBlock_args
 
promoteBlock_args(BlockWorkerClientService.promoteBlock_args) - Constructor for class alluxio.thrift.BlockWorkerClientService.promoteBlock_args
Performs a deep copy on other.
promoteBlock_call(long, PromoteBlockTOptions, AsyncMethodCallback, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class alluxio.thrift.BlockWorkerClientService.AsyncClient.promoteBlock_call
 
promoteBlock_result() - Constructor for class alluxio.thrift.BlockWorkerClientService.promoteBlock_result
 
promoteBlock_result(PromoteBlockTResponse, AlluxioTException) - Constructor for class alluxio.thrift.BlockWorkerClientService.promoteBlock_result
 
promoteBlock_result(BlockWorkerClientService.promoteBlock_result) - Constructor for class alluxio.thrift.BlockWorkerClientService.promoteBlock_result
Performs a deep copy on other.
PromoteBlockTOptions - Class in alluxio.thrift
 
PromoteBlockTOptions() - Constructor for class alluxio.thrift.PromoteBlockTOptions
 
PromoteBlockTOptions(PromoteBlockTOptions) - Constructor for class alluxio.thrift.PromoteBlockTOptions
Performs a deep copy on other.
PromoteBlockTOptions._Fields - Enum in alluxio.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
PromoteBlockTResponse - Class in alluxio.thrift
 
PromoteBlockTResponse() - Constructor for class alluxio.thrift.PromoteBlockTResponse
 
PromoteBlockTResponse(boolean) - Constructor for class alluxio.thrift.PromoteBlockTResponse
 
PromoteBlockTResponse(PromoteBlockTResponse) - Constructor for class alluxio.thrift.PromoteBlockTResponse
Performs a deep copy on other.
PromoteBlockTResponse._Fields - Enum in alluxio.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
PROPERTIES_FIELD_NUMBER - Static variable in class alluxio.proto.journal.File.AddMountPointEntry
 
PropertyKey - Class in alluxio
Configuration property keys.
PropertyKey.Builder - Class in alluxio
Builder to create PropertyKey instances.
PropertyKey.ConsistencyCheckLevel - Enum in alluxio
The consistency check level to apply to a certain property key.
PropertyKey.DisplayType - Enum in alluxio
Indicates how the property value should be displayed.
PropertyKey.Name - Class in alluxio
A nested class to hold named string constants for their corresponding properties.
PropertyKey.Template - Enum in alluxio
A set of templates to generate the names of parameterized properties given different parameters.
ProtoBufJournalFormatter - Class in alluxio.master.journalv0
Reads and writes protocol buffer journal entries.
ProtoBufJournalFormatter() - Constructor for class alluxio.master.journalv0.ProtoBufJournalFormatter
Constructs a new ProtoBufJournalFormatter.
ProtobufUtils - Class in alluxio.master
Utility methods for conversion between wire types and protobuf types.
Protocol - Class in alluxio.proto.dataserver
 
Protocol.AsyncCacheRequest - Class in alluxio.proto.dataserver
Protobuf type alluxio.proto.dataserver.AsyncCacheRequest
Protocol.AsyncCacheRequest.Builder - Class in alluxio.proto.dataserver
Protobuf type alluxio.proto.dataserver.AsyncCacheRequest
Protocol.AsyncCacheRequestOrBuilder - Interface in alluxio.proto.dataserver
 
Protocol.CreateUfsFileOptions - Class in alluxio.proto.dataserver
Protobuf type alluxio.proto.dataserver.CreateUfsFileOptions
Protocol.CreateUfsFileOptions.Builder - Class in alluxio.proto.dataserver
Protobuf type alluxio.proto.dataserver.CreateUfsFileOptions
Protocol.CreateUfsFileOptionsOrBuilder - Interface in alluxio.proto.dataserver
 
Protocol.Heartbeat - Class in alluxio.proto.dataserver
Protobuf type alluxio.proto.dataserver.Heartbeat
Protocol.Heartbeat.Builder - Class in alluxio.proto.dataserver
Protobuf type alluxio.proto.dataserver.Heartbeat
Protocol.HeartbeatOrBuilder - Interface in alluxio.proto.dataserver
 
Protocol.LocalBlockCloseRequest - Class in alluxio.proto.dataserver
Protobuf type alluxio.proto.dataserver.LocalBlockCloseRequest
Protocol.LocalBlockCloseRequest.Builder - Class in alluxio.proto.dataserver
Protobuf type alluxio.proto.dataserver.LocalBlockCloseRequest
Protocol.LocalBlockCloseRequestOrBuilder - Interface in alluxio.proto.dataserver
 
Protocol.LocalBlockCompleteRequest - Class in alluxio.proto.dataserver
Protobuf type alluxio.proto.dataserver.LocalBlockCompleteRequest
Protocol.LocalBlockCompleteRequest.Builder - Class in alluxio.proto.dataserver
Protobuf type alluxio.proto.dataserver.LocalBlockCompleteRequest
Protocol.LocalBlockCompleteRequestOrBuilder - Interface in alluxio.proto.dataserver
 
Protocol.LocalBlockCreateRequest - Class in alluxio.proto.dataserver
Protobuf type alluxio.proto.dataserver.LocalBlockCreateRequest
Protocol.LocalBlockCreateRequest.Builder - Class in alluxio.proto.dataserver
Protobuf type alluxio.proto.dataserver.LocalBlockCreateRequest
Protocol.LocalBlockCreateRequestOrBuilder - Interface in alluxio.proto.dataserver
 
Protocol.LocalBlockCreateResponse - Class in alluxio.proto.dataserver
Protobuf type alluxio.proto.dataserver.LocalBlockCreateResponse
Protocol.LocalBlockCreateResponse.Builder - Class in alluxio.proto.dataserver
Protobuf type alluxio.proto.dataserver.LocalBlockCreateResponse
Protocol.LocalBlockCreateResponseOrBuilder - Interface in alluxio.proto.dataserver
 
Protocol.LocalBlockOpenRequest - Class in alluxio.proto.dataserver
Protobuf type alluxio.proto.dataserver.LocalBlockOpenRequest
Protocol.LocalBlockOpenRequest.Builder - Class in alluxio.proto.dataserver
Protobuf type alluxio.proto.dataserver.LocalBlockOpenRequest
Protocol.LocalBlockOpenRequestOrBuilder - Interface in alluxio.proto.dataserver
 
Protocol.LocalBlockOpenResponse - Class in alluxio.proto.dataserver
Protobuf type alluxio.proto.dataserver.LocalBlockOpenResponse
Protocol.LocalBlockOpenResponse.Builder - Class in alluxio.proto.dataserver
Protobuf type alluxio.proto.dataserver.LocalBlockOpenResponse
Protocol.LocalBlockOpenResponseOrBuilder - Interface in alluxio.proto.dataserver
 
Protocol.OpenUfsBlockOptions - Class in alluxio.proto.dataserver
Protobuf type alluxio.proto.dataserver.OpenUfsBlockOptions
Protocol.OpenUfsBlockOptions.Builder - Class in alluxio.proto.dataserver
Protobuf type alluxio.proto.dataserver.OpenUfsBlockOptions
Protocol.OpenUfsBlockOptionsOrBuilder - Interface in alluxio.proto.dataserver
 
Protocol.ReadRequest - Class in alluxio.proto.dataserver
Protobuf type alluxio.proto.dataserver.ReadRequest
Protocol.ReadRequest.Builder - Class in alluxio.proto.dataserver
Protobuf type alluxio.proto.dataserver.ReadRequest
Protocol.ReadRequestOrBuilder - Interface in alluxio.proto.dataserver
 
Protocol.ReadResponse - Class in alluxio.proto.dataserver
Protobuf type alluxio.proto.dataserver.ReadResponse
Protocol.ReadResponse.Builder - Class in alluxio.proto.dataserver
Protobuf type alluxio.proto.dataserver.ReadResponse
Protocol.ReadResponse.Type - Enum in alluxio.proto.dataserver
Protobuf enum alluxio.proto.dataserver.ReadResponse.Type
Protocol.ReadResponseOrBuilder - Interface in alluxio.proto.dataserver
 
Protocol.RequestType - Enum in alluxio.proto.dataserver
Protobuf enum alluxio.proto.dataserver.RequestType
Protocol.Response - Class in alluxio.proto.dataserver
Protobuf type alluxio.proto.dataserver.Response
Protocol.Response.Builder - Class in alluxio.proto.dataserver
Protobuf type alluxio.proto.dataserver.Response
Protocol.ResponseOrBuilder - Interface in alluxio.proto.dataserver
 
Protocol.WriteRequest - Class in alluxio.proto.dataserver
Protobuf type alluxio.proto.dataserver.WriteRequest
Protocol.WriteRequest.Builder - Class in alluxio.proto.dataserver
Protobuf type alluxio.proto.dataserver.WriteRequest
Protocol.WriteRequestOrBuilder - Interface in alluxio.proto.dataserver
 
ProtoMessage - Class in alluxio.util.proto
A simple wrapper around the MessageLite class in Protobuf for a few messages defined and generated in Alluxio.
ProtoMessage(Protocol.ReadRequest) - Constructor for class alluxio.util.proto.ProtoMessage
 
ProtoMessage(Protocol.WriteRequest) - Constructor for class alluxio.util.proto.ProtoMessage
 
ProtoMessage(Protocol.Response) - Constructor for class alluxio.util.proto.ProtoMessage
 
ProtoMessage(Protocol.ReadResponse) - Constructor for class alluxio.util.proto.ProtoMessage
 
ProtoMessage(Protocol.LocalBlockOpenRequest) - Constructor for class alluxio.util.proto.ProtoMessage
 
ProtoMessage(Protocol.LocalBlockOpenResponse) - Constructor for class alluxio.util.proto.ProtoMessage
 
ProtoMessage(Protocol.LocalBlockCloseRequest) - Constructor for class alluxio.util.proto.ProtoMessage
 
ProtoMessage(Protocol.LocalBlockCreateRequest) - Constructor for class alluxio.util.proto.ProtoMessage
 
ProtoMessage(Protocol.LocalBlockCreateResponse) - Constructor for class alluxio.util.proto.ProtoMessage
 
ProtoMessage(Protocol.LocalBlockCompleteRequest) - Constructor for class alluxio.util.proto.ProtoMessage
 
ProtoMessage(Protocol.AsyncCacheRequest) - Constructor for class alluxio.util.proto.ProtoMessage
 
ProtoMessage(Protocol.Heartbeat) - Constructor for class alluxio.util.proto.ProtoMessage
 
ProtoUtils - Class in alluxio.util.proto
Protobuf related utils.
PROXY_S3_DELETE_TYPE - Static variable in class alluxio.PropertyKey.Name
 
PROXY_S3_DELETE_TYPE - Static variable in class alluxio.PropertyKey
 
PROXY_S3_MULTIPART_TEMPORARY_DIR_SUFFIX - Static variable in class alluxio.PropertyKey.Name
 
PROXY_S3_MULTIPART_TEMPORARY_DIR_SUFFIX - Static variable in class alluxio.PropertyKey
 
PROXY_S3_WRITE_TYPE - Static variable in class alluxio.PropertyKey.Name
 
PROXY_S3_WRITE_TYPE - Static variable in class alluxio.PropertyKey
 
PROXY_STREAM_CACHE_TIMEOUT_MS - Static variable in class alluxio.PropertyKey.Name
 
PROXY_STREAM_CACHE_TIMEOUT_MS - Static variable in class alluxio.PropertyKey
 
PROXY_WEB_BIND_HOST - Static variable in class alluxio.PropertyKey.Name
 
PROXY_WEB_BIND_HOST - Static variable in class alluxio.PropertyKey
 
PROXY_WEB_HOSTNAME - Static variable in class alluxio.PropertyKey.Name
 
PROXY_WEB_HOSTNAME - Static variable in class alluxio.PropertyKey
 
PROXY_WEB_PORT - Static variable in class alluxio.PropertyKey.Name
 
PROXY_WEB_PORT - Static variable in class alluxio.PropertyKey
 
ProxyHealthCheckClient - Class in alluxio.proxy
ProxyHealthCheckClient check if the proxy server is serving requests.
ProxyHealthCheckClient(InetSocketAddress, Supplier<RetryPolicy>) - Constructor for class alluxio.proxy.ProxyHealthCheckClient
Creates a proxy health check client.
ProxyProcess - Interface in alluxio.proxy
A proxy in the Alluxio system.
ProxyProcess.Factory - Class in alluxio.proxy
Factory for creating ProxyProcess.
ProxyWebServer - Class in alluxio.web
The Alluxio proxy web server.
ProxyWebServer(String, InetSocketAddress, ProxyProcess) - Constructor for class alluxio.web.ProxyWebServer
Creates a new instance of ProxyWebServer.
PublicApi - Annotation Type in alluxio.annotation
A public API annotation for annotating classes and interfaces that are externally facing.
put(byte[], byte[], PayloadWriter) - Method in interface alluxio.client.keyvalue.Index
Puts a key into the index and stores key and value data into payload storage.
put(byte[], byte[]) - Method in interface alluxio.client.keyvalue.KeyValuePartitionWriter
Adds a key and the associated value to this writer.
put(byte[], byte[]) - Method in interface alluxio.client.keyvalue.KeyValueStoreWriter
Adds a key and its associated value to this store.
put(ByteBuffer, ByteBuffer) - Method in interface alluxio.client.keyvalue.KeyValueStoreWriter
Adds a key and its associated value to this store.
put(byte[], byte[], PayloadWriter) - Method in class alluxio.client.keyvalue.LinearProbingIndex
 
put(PropertyKey, String, Source) - Method in class alluxio.conf.AlluxioProperties
Puts the key value pair specified by users.
put(FileInStream) - Method in class alluxio.StreamCache
 
put(FileOutStream) - Method in class alluxio.StreamCache
 
put(Access, String) - Static method in class alluxio.underfs.swift.http.SwiftDirectClient
Swift HTTP PUT request.
putClientMetrics(String, String, List<Metric>) - Method in class alluxio.master.metrics.MetricsStore
Put the metrics from a client with a hostname and a client id.
putIntByteBuffer(ByteBuffer, int) - Static method in class alluxio.util.io.BufferUtils
Puts a byte (the first byte of an integer) into a ByteBuffer.
putTag(Fingerprint.Tag, String) - Method in class alluxio.underfs.Fingerprint
Updates a specific tag in the fingerprint.
putToAddedBlocksOnTiers(String, List<Long>) - Method in class alluxio.thrift.BlockMasterWorkerService.blockHeartbeat_args
 
putToCapacityBytesOnTiers(String, long) - Method in class alluxio.thrift.BlockMasterInfo
 
putToCapacityBytesOnTiers(String, long) - Method in class alluxio.thrift.WorkerInfo
 
putToCurrentBlocksOnTiers(String, List<Long>) - Method in class alluxio.thrift.BlockMasterWorkerService.registerWorker_args
 
putToErrors(Scope, List<InconsistentProperty>) - Method in class alluxio.thrift.ConfigCheckReport
 
putToMetricsMap(String, MetricValue) - Method in class alluxio.thrift.GetMetricsTResponse
 
putToMountTable(String, MountPointInfo) - Method in class alluxio.thrift.GetMountTableTResponse
 
putToProperties(String, String) - Method in class alluxio.thrift.MountPointInfo
 
putToProperties(String, String) - Method in class alluxio.thrift.MountTOptions
 
putToTags(String, String) - Method in class alluxio.thrift.Metric
 
putToTotalBytesOnTiers(String, long) - Method in class alluxio.thrift.BlockMasterWorkerService.registerWorker_args
 
putToUsedBytesOnTiers(String, long) - Method in class alluxio.thrift.BlockMasterInfo
 
putToUsedBytesOnTiers(String, long) - Method in class alluxio.thrift.BlockMasterWorkerService.blockHeartbeat_args
 
putToUsedBytesOnTiers(String, long) - Method in class alluxio.thrift.BlockMasterWorkerService.registerWorker_args
 
putToUsedBytesOnTiers(String, long) - Method in class alluxio.thrift.WorkerInfo
 
putToValues(OptionalString, List<String>) - Method in class alluxio.thrift.InconsistentProperty
 
putToWarns(Scope, List<InconsistentProperty>) - Method in class alluxio.thrift.ConfigCheckReport
 
putWorkerMetrics(String, List<Metric>) - Method in class alluxio.master.metrics.MetricsStore
Put the metrics from a worker with a hostname.

Q

QUERY_KEY_VALUE_SEPARATOR - Static variable in class alluxio.util.URIUtils
 
QUERY_RAW_CONFIGURATION - Static variable in class alluxio.master.meta.AlluxioMasterRestServiceHandler
 
QUERY_RAW_CONFIGURATION - Static variable in class alluxio.proxy.AlluxioProxyRestServiceHandler
 
QUERY_RAW_CONFIGURATION - Static variable in class alluxio.worker.AlluxioWorkerRestServiceHandler
 
QUERY_SEPARATOR - Static variable in class alluxio.util.URIUtils
 
quoteETag(String) - Static method in class alluxio.proxy.s3.S3RestUtils
 

R

RamDiskMountPrivilegeValidationTask - Class in alluxio.cli.validation
Task for validating whether worker has enough privilege to mount RAM disk.
RamDiskMountPrivilegeValidationTask() - Constructor for class alluxio.cli.validation.RamDiskMountPrivilegeValidationTask
Creates a new instance of RamDiskMountPrivilegeValidationTask for validating mount privilege.
randomAlphaNumString(int) - Static method in class alluxio.util.CommonUtils
Generates a random alphanumeric string of the given length.
randomBytes(int) - Static method in class alluxio.util.CommonUtils
Generates a random byte array of the given length.
read() - Method in class alluxio.client.block.stream.BlockInStream
 
read(byte[]) - Method in class alluxio.client.block.stream.BlockInStream
 
read(byte[], int, int) - Method in class alluxio.client.block.stream.BlockInStream
 
read() - Method in class alluxio.client.file.FileInStream
 
read(byte[]) - Method in class alluxio.client.file.FileInStream
 
read(byte[], int, int) - Method in class alluxio.client.file.FileInStream
 
read() - Method in class alluxio.hadoop.HdfsFileInputStream
 
read(byte[]) - Method in class alluxio.hadoop.HdfsFileInputStream
 
read(byte[], int, int) - Method in class alluxio.hadoop.HdfsFileInputStream
 
read(long, byte[], int, int) - Method in class alluxio.hadoop.HdfsFileInputStream
 
read() - Method in interface alluxio.master.journal.JournalReader
Reads an entry from the journal.
read() - Method in class alluxio.master.journal.noop.NoopJournalReader
 
read() - Method in class alluxio.master.journal.ufs.UfsJournalReader
 
read() - Method in interface alluxio.master.journalv0.JournalInputStream
Reads the next journal entry.
read(byte[], int, int) - Method in class alluxio.network.thrift.BootstrapClientTransport
 
read(byte[], int, int) - Method in class alluxio.network.thrift.BootstrapServerTransport
 
read(byte[], int, int) - Method in class alluxio.network.thrift.PeekableTransport
 
READ - Static variable in class alluxio.proxy.StreamsRestServiceHandler
 
read(Integer) - Method in class alluxio.proxy.StreamsRestServiceHandler
 
read(TProtocol) - Method in class alluxio.thrift.AccessBlockTOptions
 
read(TProtocol) - Method in class alluxio.thrift.AccessBlockTResponse
 
read(TProtocol) - Method in class alluxio.thrift.AlluxioService.getServiceVersion_args
 
read(TProtocol) - Method in class alluxio.thrift.AlluxioService.getServiceVersion_result
 
read(TProtocol) - Method in exception alluxio.thrift.AlluxioTException
 
read(TProtocol) - Method in class alluxio.thrift.BackupTOptions
 
read(TProtocol) - Method in class alluxio.thrift.BackupTResponse
 
read(TProtocol) - Method in class alluxio.thrift.BlockHeartbeatTOptions
 
read(TProtocol) - Method in class alluxio.thrift.BlockHeartbeatTResponse
 
read(TProtocol) - Method in class alluxio.thrift.BlockInfo
 
read(TProtocol) - Method in class alluxio.thrift.BlockLocation
 
read(TProtocol) - Method in class alluxio.thrift.BlockMasterClientService.getBlockInfo_args
 
read(TProtocol) - Method in class alluxio.thrift.BlockMasterClientService.getBlockInfo_result
 
read(TProtocol) - Method in class alluxio.thrift.BlockMasterClientService.getBlockMasterInfo_args
 
read(TProtocol) - Method in class alluxio.thrift.BlockMasterClientService.getBlockMasterInfo_result
 
read(TProtocol) - Method in class alluxio.thrift.BlockMasterClientService.getCapacityBytes_args
 
read(TProtocol) - Method in class alluxio.thrift.BlockMasterClientService.getCapacityBytes_result
 
read(TProtocol) - Method in class alluxio.thrift.BlockMasterClientService.getUsedBytes_args
 
read(TProtocol) - Method in class alluxio.thrift.BlockMasterClientService.getUsedBytes_result
 
read(TProtocol) - Method in class alluxio.thrift.BlockMasterClientService.getWorkerInfoList_args
 
read(TProtocol) - Method in class alluxio.thrift.BlockMasterClientService.getWorkerInfoList_result
 
read(TProtocol) - Method in class alluxio.thrift.BlockMasterClientService.getWorkerReport_args
 
read(TProtocol) - Method in class alluxio.thrift.BlockMasterClientService.getWorkerReport_result
 
read(TProtocol) - Method in class alluxio.thrift.BlockMasterInfo
 
read(TProtocol) - Method in class alluxio.thrift.BlockMasterWorkerService.blockHeartbeat_args
 
read(TProtocol) - Method in class alluxio.thrift.BlockMasterWorkerService.blockHeartbeat_result
 
read(TProtocol) - Method in class alluxio.thrift.BlockMasterWorkerService.commitBlock_args
 
read(TProtocol) - Method in class alluxio.thrift.BlockMasterWorkerService.commitBlock_result
 
read(TProtocol) - Method in class alluxio.thrift.BlockMasterWorkerService.getWorkerId_args
 
read(TProtocol) - Method in class alluxio.thrift.BlockMasterWorkerService.getWorkerId_result
 
read(TProtocol) - Method in class alluxio.thrift.BlockMasterWorkerService.registerWorker_args
 
read(TProtocol) - Method in class alluxio.thrift.BlockMasterWorkerService.registerWorker_result
 
read(TProtocol) - Method in class alluxio.thrift.BlockWorkerClientService.accessBlock_args
 
read(TProtocol) - Method in class alluxio.thrift.BlockWorkerClientService.accessBlock_result
 
read(TProtocol) - Method in class alluxio.thrift.BlockWorkerClientService.cacheBlock_args
 
read(TProtocol) - Method in class alluxio.thrift.BlockWorkerClientService.cacheBlock_result
 
read(TProtocol) - Method in class alluxio.thrift.BlockWorkerClientService.cancelBlock_args
 
read(TProtocol) - Method in class alluxio.thrift.BlockWorkerClientService.cancelBlock_result
 
read(TProtocol) - Method in class alluxio.thrift.BlockWorkerClientService.lockBlock_args
 
read(TProtocol) - Method in class alluxio.thrift.BlockWorkerClientService.lockBlock_result
 
read(TProtocol) - Method in class alluxio.thrift.BlockWorkerClientService.promoteBlock_args
 
read(TProtocol) - Method in class alluxio.thrift.BlockWorkerClientService.promoteBlock_result
 
read(TProtocol) - Method in class alluxio.thrift.BlockWorkerClientService.removeBlock_args
 
read(TProtocol) - Method in class alluxio.thrift.BlockWorkerClientService.removeBlock_result
 
read(TProtocol) - Method in class alluxio.thrift.BlockWorkerClientService.requestBlockLocation_args
 
read(TProtocol) - Method in class alluxio.thrift.BlockWorkerClientService.requestBlockLocation_result
 
read(TProtocol) - Method in class alluxio.thrift.BlockWorkerClientService.requestSpace_args
 
read(TProtocol) - Method in class alluxio.thrift.BlockWorkerClientService.requestSpace_result
 
read(TProtocol) - Method in class alluxio.thrift.BlockWorkerClientService.sessionBlockHeartbeat_args
 
read(TProtocol) - Method in class alluxio.thrift.BlockWorkerClientService.sessionBlockHeartbeat_result
 
read(TProtocol) - Method in class alluxio.thrift.BlockWorkerClientService.unlockBlock_args
 
read(TProtocol) - Method in class alluxio.thrift.BlockWorkerClientService.unlockBlock_result
 
read(TProtocol) - Method in class alluxio.thrift.CacheBlockTOptions
 
read(TProtocol) - Method in class alluxio.thrift.CacheBlockTResponse
 
read(TProtocol) - Method in class alluxio.thrift.CancelBlockTOptions
 
read(TProtocol) - Method in class alluxio.thrift.CancelBlockTResponse
 
read(TProtocol) - Method in class alluxio.thrift.CancelUfsFileTOptions
 
read(TProtocol) - Method in class alluxio.thrift.CancelUfsFileTResponse
 
read(TProtocol) - Method in class alluxio.thrift.CheckConsistencyTOptions
 
read(TProtocol) - Method in class alluxio.thrift.CheckConsistencyTResponse
 
read(TProtocol) - Method in class alluxio.thrift.CloseUfsFileTOptions
 
read(TProtocol) - Method in class alluxio.thrift.CloseUfsFileTResponse
 
read(TProtocol) - Method in class alluxio.thrift.Command
 
read(TProtocol) - Method in class alluxio.thrift.CommandLineJobInfo
 
read(TProtocol) - Method in class alluxio.thrift.CommitBlockTOptions
 
read(TProtocol) - Method in class alluxio.thrift.CommitBlockTResponse
 
read(TProtocol) - Method in class alluxio.thrift.CompleteFileTOptions
 
read(TProtocol) - Method in class alluxio.thrift.CompleteFileTResponse
 
read(TProtocol) - Method in class alluxio.thrift.CompletePartitionTOptions
 
read(TProtocol) - Method in class alluxio.thrift.CompletePartitionTResponse
 
read(TProtocol) - Method in class alluxio.thrift.CompleteStoreTOptions
 
read(TProtocol) - Method in class alluxio.thrift.CompleteStoreTResponse
 
read(TProtocol) - Method in class alluxio.thrift.CompleteUfsFileTOptions
 
read(TProtocol) - Method in class alluxio.thrift.CompleteUfsFileTReponse
 
read(TProtocol) - Method in class alluxio.thrift.ConfigCheckReport
 
read(TProtocol) - Method in class alluxio.thrift.ConfigProperty
 
read(TProtocol) - Method in class alluxio.thrift.CreateDirectoryTOptions
 
read(TProtocol) - Method in class alluxio.thrift.CreateDirectoryTResponse
 
read(TProtocol) - Method in class alluxio.thrift.CreateFileTOptions
 
read(TProtocol) - Method in class alluxio.thrift.CreateFileTResponse
 
read(TProtocol) - Method in class alluxio.thrift.CreateLineageTOptions
 
read(TProtocol) - Method in class alluxio.thrift.CreateLineageTResponse
 
read(TProtocol) - Method in class alluxio.thrift.CreateStoreTOptions
 
read(TProtocol) - Method in class alluxio.thrift.CreateStoreTResponse
 
read(TProtocol) - Method in class alluxio.thrift.CreateUfsFileTOptions
 
read(TProtocol) - Method in class alluxio.thrift.CreateUfsFileTResponse
 
read(TProtocol) - Method in class alluxio.thrift.DeleteLineageTOptions
 
read(TProtocol) - Method in class alluxio.thrift.DeleteLineageTResponse
 
read(TProtocol) - Method in class alluxio.thrift.DeleteStoreTOptions
 
read(TProtocol) - Method in class alluxio.thrift.DeleteStoreTResponse
 
read(TProtocol) - Method in class alluxio.thrift.DeleteTOptions
 
read(TProtocol) - Method in class alluxio.thrift.DeleteTResponse
 
read(TProtocol) - Method in class alluxio.thrift.DependencyInfo
 
read(TProtocol) - Method in class alluxio.thrift.FileBlockInfo
 
read(TProtocol) - Method in class alluxio.thrift.FileInfo
 
read(TProtocol) - Method in class alluxio.thrift.FileSystemCommand
 
read(TProtocol) - Method in class alluxio.thrift.FileSystemHeartbeatTOptions
 
read(TProtocol) - Method in class alluxio.thrift.FileSystemHeartbeatTResponse
 
read(TProtocol) - Method in class alluxio.thrift.FileSystemMasterClientService.checkConsistency_args
 
read(TProtocol) - Method in class alluxio.thrift.FileSystemMasterClientService.checkConsistency_result
 
read(TProtocol) - Method in class alluxio.thrift.FileSystemMasterClientService.completeFile_args
 
read(TProtocol) - Method in class alluxio.thrift.FileSystemMasterClientService.completeFile_result
 
read(TProtocol) - Method in class alluxio.thrift.FileSystemMasterClientService.createDirectory_args
 
read(TProtocol) - Method in class alluxio.thrift.FileSystemMasterClientService.createDirectory_result
 
read(TProtocol) - Method in class alluxio.thrift.FileSystemMasterClientService.createFile_args
 
read(TProtocol) - Method in class alluxio.thrift.FileSystemMasterClientService.createFile_result
 
read(TProtocol) - Method in class alluxio.thrift.FileSystemMasterClientService.free_args
 
read(TProtocol) - Method in class alluxio.thrift.FileSystemMasterClientService.free_result
 
read(TProtocol) - Method in class alluxio.thrift.FileSystemMasterClientService.getFilePath_args
 
read(TProtocol) - Method in class alluxio.thrift.FileSystemMasterClientService.getFilePath_result
 
read(TProtocol) - Method in class alluxio.thrift.FileSystemMasterClientService.getMountTable_args
 
read(TProtocol) - Method in class alluxio.thrift.FileSystemMasterClientService.getMountTable_result
 
read(TProtocol) - Method in class alluxio.thrift.FileSystemMasterClientService.getNewBlockIdForFile_args
 
read(TProtocol) - Method in class alluxio.thrift.FileSystemMasterClientService.getNewBlockIdForFile_result
 
read(TProtocol) - Method in class alluxio.thrift.FileSystemMasterClientService.getStatus_args
 
read(TProtocol) - Method in class alluxio.thrift.FileSystemMasterClientService.getStatus_result
 
read(TProtocol) - Method in class alluxio.thrift.FileSystemMasterClientService.listStatus_args
 
read(TProtocol) - Method in class alluxio.thrift.FileSystemMasterClientService.listStatus_result
 
read(TProtocol) - Method in class alluxio.thrift.FileSystemMasterClientService.loadMetadata_args
 
read(TProtocol) - Method in class alluxio.thrift.FileSystemMasterClientService.loadMetadata_result
 
read(TProtocol) - Method in class alluxio.thrift.FileSystemMasterClientService.mount_args
 
read(TProtocol) - Method in class alluxio.thrift.FileSystemMasterClientService.mount_result
 
read(TProtocol) - Method in class alluxio.thrift.FileSystemMasterClientService.remove_args
 
read(TProtocol) - Method in class alluxio.thrift.FileSystemMasterClientService.remove_result
 
read(TProtocol) - Method in class alluxio.thrift.FileSystemMasterClientService.rename_args
 
read(TProtocol) - Method in class alluxio.thrift.FileSystemMasterClientService.rename_result
 
read(TProtocol) - Method in class alluxio.thrift.FileSystemMasterClientService.scheduleAsyncPersistence_args
 
read(TProtocol) - Method in class alluxio.thrift.FileSystemMasterClientService.scheduleAsyncPersistence_result
 
read(TProtocol) - Method in class alluxio.thrift.FileSystemMasterClientService.setAttribute_args
 
read(TProtocol) - Method in class alluxio.thrift.FileSystemMasterClientService.setAttribute_result
 
read(TProtocol) - Method in class alluxio.thrift.FileSystemMasterClientService.unmount_args
 
read(TProtocol) - Method in class alluxio.thrift.FileSystemMasterClientService.unmount_result
 
read(TProtocol) - Method in class alluxio.thrift.FileSystemMasterClientService.updateUfsMode_args
 
read(TProtocol) - Method in class alluxio.thrift.FileSystemMasterClientService.updateUfsMode_result
 
read(TProtocol) - Method in class alluxio.thrift.FileSystemMasterCommonTOptions
 
read(TProtocol) - Method in class alluxio.thrift.FileSystemMasterWorkerService.fileSystemHeartbeat_args
 
read(TProtocol) - Method in class alluxio.thrift.FileSystemMasterWorkerService.fileSystemHeartbeat_result
 
read(TProtocol) - Method in class alluxio.thrift.FileSystemMasterWorkerService.getFileInfo_args
 
read(TProtocol) - Method in class alluxio.thrift.FileSystemMasterWorkerService.getFileInfo_result
 
read(TProtocol) - Method in class alluxio.thrift.FileSystemMasterWorkerService.getPinnedFileIds_args
 
read(TProtocol) - Method in class alluxio.thrift.FileSystemMasterWorkerService.getPinnedFileIds_result
 
read(TProtocol) - Method in class alluxio.thrift.FileSystemMasterWorkerService.getUfsInfo_args
 
read(TProtocol) - Method in class alluxio.thrift.FileSystemMasterWorkerService.getUfsInfo_result
 
read(TProtocol) - Method in class alluxio.thrift.FileSystemWorkerClientService.cancelUfsFile_args
 
read(TProtocol) - Method in class alluxio.thrift.FileSystemWorkerClientService.cancelUfsFile_result
 
read(TProtocol) - Method in class alluxio.thrift.FileSystemWorkerClientService.closeUfsFile_args
 
read(TProtocol) - Method in class alluxio.thrift.FileSystemWorkerClientService.closeUfsFile_result
 
read(TProtocol) - Method in class alluxio.thrift.FileSystemWorkerClientService.completeUfsFile_args
 
read(TProtocol) - Method in class alluxio.thrift.FileSystemWorkerClientService.completeUfsFile_result
 
read(TProtocol) - Method in class alluxio.thrift.FileSystemWorkerClientService.createUfsFile_args
 
read(TProtocol) - Method in class alluxio.thrift.FileSystemWorkerClientService.createUfsFile_result
 
read(TProtocol) - Method in class alluxio.thrift.FileSystemWorkerClientService.openUfsFile_args
 
read(TProtocol) - Method in class alluxio.thrift.FileSystemWorkerClientService.openUfsFile_result
 
read(TProtocol) - Method in class alluxio.thrift.FileSystemWorkerClientService.sessionFileSystemHeartbeat_args
 
read(TProtocol) - Method in class alluxio.thrift.FileSystemWorkerClientService.sessionFileSystemHeartbeat_result
 
read(TProtocol) - Method in class alluxio.thrift.FreeTOptions
 
read(TProtocol) - Method in class alluxio.thrift.FreeTResponse
 
read(TProtocol) - Method in class alluxio.thrift.GetBlockInfoTOptions
 
read(TProtocol) - Method in class alluxio.thrift.GetBlockInfoTResponse
 
read(TProtocol) - Method in class alluxio.thrift.GetBlockMasterInfoTOptions
 
read(TProtocol) - Method in class alluxio.thrift.GetBlockMasterInfoTResponse
 
read(TProtocol) - Method in class alluxio.thrift.GetCapacityBytesTOptions
 
read(TProtocol) - Method in class alluxio.thrift.GetCapacityBytesTResponse
 
read(TProtocol) - Method in class alluxio.thrift.GetConfigReportTOptions
 
read(TProtocol) - Method in class alluxio.thrift.GetConfigReportTResponse
 
read(TProtocol) - Method in class alluxio.thrift.GetConfigurationTOptions
 
read(TProtocol) - Method in class alluxio.thrift.GetConfigurationTResponse
 
read(TProtocol) - Method in class alluxio.thrift.GetFileInfoTOptions
 
read(TProtocol) - Method in class alluxio.thrift.GetFileInfoTResponse
 
read(TProtocol) - Method in class alluxio.thrift.GetFilePathTOptions
 
read(TProtocol) - Method in class alluxio.thrift.GetFilePathTResponse
 
read(TProtocol) - Method in class alluxio.thrift.GetLineageInfoListTOptions
 
read(TProtocol) - Method in class alluxio.thrift.GetLineageInfoListTResponse
 
read(TProtocol) - Method in class alluxio.thrift.GetMasterIdTOptions
 
read(TProtocol) - Method in class alluxio.thrift.GetMasterIdTResponse
 
read(TProtocol) - Method in class alluxio.thrift.GetMasterInfoTOptions
 
read(TProtocol) - Method in class alluxio.thrift.GetMasterInfoTResponse
 
read(TProtocol) - Method in class alluxio.thrift.GetMetricsTOptions
 
read(TProtocol) - Method in class alluxio.thrift.GetMetricsTResponse
 
read(TProtocol) - Method in class alluxio.thrift.GetMountTableTResponse
 
read(TProtocol) - Method in class alluxio.thrift.GetNewBlockIdForFileTOptions
 
read(TProtocol) - Method in class alluxio.thrift.GetNewBlockIdForFileTResponse
 
read(TProtocol) - Method in class alluxio.thrift.GetNextKeysTOptions
 
read(TProtocol) - Method in class alluxio.thrift.GetNextKeysTResponse
 
read(TProtocol) - Method in class alluxio.thrift.GetPartitionInfoTOptions
 
read(TProtocol) - Method in class alluxio.thrift.GetPartitionInfoTResponse
 
read(TProtocol) - Method in class alluxio.thrift.GetPinnedFileIdsTOptions
 
read(TProtocol) - Method in class alluxio.thrift.GetPinnedFileIdsTResponse
 
read(TProtocol) - Method in class alluxio.thrift.GetServiceVersionTOptions
 
read(TProtocol) - Method in class alluxio.thrift.GetServiceVersionTResponse
 
read(TProtocol) - Method in class alluxio.thrift.GetSizeTOptions
 
read(TProtocol) - Method in class alluxio.thrift.GetSizeTResponse
 
read(TProtocol) - Method in class alluxio.thrift.GetStatusTOptions
 
read(TProtocol) - Method in class alluxio.thrift.GetStatusTResponse
 
read(TProtocol) - Method in class alluxio.thrift.GetTOptions
 
read(TProtocol) - Method in class alluxio.thrift.GetTResponse
 
read(TProtocol) - Method in class alluxio.thrift.GetUfsInfoTOptions
 
read(TProtocol) - Method in class alluxio.thrift.GetUfsInfoTResponse
 
read(TProtocol) - Method in class alluxio.thrift.GetUsedBytesTOptions
 
read(TProtocol) - Method in class alluxio.thrift.GetUsedBytesTResponse
 
read(TProtocol) - Method in class alluxio.thrift.GetWorkerIdTOptions
 
read(TProtocol) - Method in class alluxio.thrift.GetWorkerIdTResponse
 
read(TProtocol) - Method in class alluxio.thrift.GetWorkerInfoListTOptions
 
read(TProtocol) - Method in class alluxio.thrift.GetWorkerInfoListTResponse
 
read(TProtocol) - Method in class alluxio.thrift.GetWorkerReportTOptions
 
read(TProtocol) - Method in class alluxio.thrift.InconsistentProperty
 
read(TProtocol) - Method in class alluxio.thrift.JobConfInfo
 
read(TProtocol) - Method in class alluxio.thrift.KeyValueMasterClientService.completePartition_args
 
read(TProtocol) - Method in class alluxio.thrift.KeyValueMasterClientService.completePartition_result
 
read(TProtocol) - Method in class alluxio.thrift.KeyValueMasterClientService.completeStore_args
 
read(TProtocol) - Method in class alluxio.thrift.KeyValueMasterClientService.completeStore_result
 
read(TProtocol) - Method in class alluxio.thrift.KeyValueMasterClientService.createStore_args
 
read(TProtocol) - Method in class alluxio.thrift.KeyValueMasterClientService.createStore_result
 
read(TProtocol) - Method in class alluxio.thrift.KeyValueMasterClientService.deleteStore_args
 
read(TProtocol) - Method in class alluxio.thrift.KeyValueMasterClientService.deleteStore_result
 
read(TProtocol) - Method in class alluxio.thrift.KeyValueMasterClientService.getPartitionInfo_args
 
read(TProtocol) - Method in class alluxio.thrift.KeyValueMasterClientService.getPartitionInfo_result
 
read(TProtocol) - Method in class alluxio.thrift.KeyValueMasterClientService.mergeStore_args
 
read(TProtocol) - Method in class alluxio.thrift.KeyValueMasterClientService.mergeStore_result
 
read(TProtocol) - Method in class alluxio.thrift.KeyValueMasterClientService.renameStore_args
 
read(TProtocol) - Method in class alluxio.thrift.KeyValueMasterClientService.renameStore_result
 
read(TProtocol) - Method in class alluxio.thrift.KeyValueWorkerClientService.get_args
 
read(TProtocol) - Method in class alluxio.thrift.KeyValueWorkerClientService.get_result
 
read(TProtocol) - Method in class alluxio.thrift.KeyValueWorkerClientService.getNextKeys_args
 
read(TProtocol) - Method in class alluxio.thrift.KeyValueWorkerClientService.getNextKeys_result
 
read(TProtocol) - Method in class alluxio.thrift.KeyValueWorkerClientService.getSize_args
 
read(TProtocol) - Method in class alluxio.thrift.KeyValueWorkerClientService.getSize_result
 
read(TProtocol) - Method in class alluxio.thrift.LineageInfo
 
read(TProtocol) - Method in class alluxio.thrift.LineageMasterClientService.createLineage_args
 
read(TProtocol) - Method in class alluxio.thrift.LineageMasterClientService.createLineage_result
 
read(TProtocol) - Method in class alluxio.thrift.LineageMasterClientService.deleteLineage_args
 
read(TProtocol) - Method in class alluxio.thrift.LineageMasterClientService.deleteLineage_result
 
read(TProtocol) - Method in class alluxio.thrift.LineageMasterClientService.getLineageInfoList_args
 
read(TProtocol) - Method in class alluxio.thrift.LineageMasterClientService.getLineageInfoList_result
 
read(TProtocol) - Method in class alluxio.thrift.LineageMasterClientService.reinitializeFile_args
 
read(TProtocol) - Method in class alluxio.thrift.LineageMasterClientService.reinitializeFile_result
 
read(TProtocol) - Method in class alluxio.thrift.LineageMasterClientService.reportLostFile_args
 
read(TProtocol) - Method in class alluxio.thrift.LineageMasterClientService.reportLostFile_result
 
read(TProtocol) - Method in class alluxio.thrift.ListStatusTOptions
 
read(TProtocol) - Method in class alluxio.thrift.ListStatusTResponse
 
read(TProtocol) - Method in class alluxio.thrift.LoadMetadataTOptions
 
read(TProtocol) - Method in class alluxio.thrift.LoadMetadataTResponse
 
read(TProtocol) - Method in class alluxio.thrift.LocalityTier
 
read(TProtocol) - Method in class alluxio.thrift.LockBlockTOptions
 
read(TProtocol) - Method in class alluxio.thrift.LockBlockTResponse
 
read(TProtocol) - Method in class alluxio.thrift.MasterHeartbeatTOptions
 
read(TProtocol) - Method in class alluxio.thrift.MasterHeartbeatTResponse
 
read(TProtocol) - Method in class alluxio.thrift.MasterInfo
 
read(TProtocol) - Method in class alluxio.thrift.MasterNetAddress
 
read(TProtocol) - Method in class alluxio.thrift.MergeStoreTOptions
 
read(TProtocol) - Method in class alluxio.thrift.MergeStoreTResponse
 
read(TProtocol) - Method in class alluxio.thrift.MetaMasterClientService.backup_args
 
read(TProtocol) - Method in class alluxio.thrift.MetaMasterClientService.backup_result
 
read(TProtocol) - Method in class alluxio.thrift.MetaMasterClientService.getConfigReport_args
 
read(TProtocol) - Method in class alluxio.thrift.MetaMasterClientService.getConfigReport_result
 
read(TProtocol) - Method in class alluxio.thrift.MetaMasterClientService.getConfiguration_args
 
read(TProtocol) - Method in class alluxio.thrift.MetaMasterClientService.getConfiguration_result
 
read(TProtocol) - Method in class alluxio.thrift.MetaMasterClientService.getMasterInfo_args
 
read(TProtocol) - Method in class alluxio.thrift.MetaMasterClientService.getMasterInfo_result
 
read(TProtocol) - Method in class alluxio.thrift.MetaMasterClientService.getMetrics_args
 
read(TProtocol) - Method in class alluxio.thrift.MetaMasterClientService.getMetrics_result
 
read(TProtocol) - Method in class alluxio.thrift.MetaMasterMasterService.getMasterId_args
 
read(TProtocol) - Method in class alluxio.thrift.MetaMasterMasterService.getMasterId_result
 
read(TProtocol) - Method in class alluxio.thrift.MetaMasterMasterService.masterHeartbeat_args
 
read(TProtocol) - Method in class alluxio.thrift.MetaMasterMasterService.masterHeartbeat_result
 
read(TProtocol) - Method in class alluxio.thrift.MetaMasterMasterService.registerMaster_args
 
read(TProtocol) - Method in class alluxio.thrift.MetaMasterMasterService.registerMaster_result
 
read(TProtocol) - Method in class alluxio.thrift.Metric
 
read(TProtocol) - Method in class alluxio.thrift.MetricsHeartbeatTOptions
 
read(TProtocol) - Method in class alluxio.thrift.MetricsHeartbeatTResponse
 
read(TProtocol) - Method in class alluxio.thrift.MetricsMasterClientService.metricsHeartbeat_args
 
read(TProtocol) - Method in class alluxio.thrift.MetricsMasterClientService.metricsHeartbeat_result
 
read(TProtocol) - Method in class alluxio.thrift.MetricValue
 
read(TProtocol) - Method in class alluxio.thrift.MountPointInfo
 
read(TProtocol) - Method in class alluxio.thrift.MountTOptions
 
read(TProtocol) - Method in class alluxio.thrift.MountTResponse
 
read(TProtocol) - Method in class alluxio.thrift.OpenUfsFileTOptions
 
read(TProtocol) - Method in class alluxio.thrift.OpenUfsFileTResponse
 
read(TProtocol) - Method in class alluxio.thrift.OptionalString
 
read(TProtocol) - Method in class alluxio.thrift.PartitionInfo
 
read(TProtocol) - Method in class alluxio.thrift.PersistCommandOptions
 
read(TProtocol) - Method in class alluxio.thrift.PersistFile
 
read(TProtocol) - Method in class alluxio.thrift.PromoteBlockTOptions
 
read(TProtocol) - Method in class alluxio.thrift.PromoteBlockTResponse
 
read(TProtocol) - Method in class alluxio.thrift.RegisterMasterTOptions
 
read(TProtocol) - Method in class alluxio.thrift.RegisterMasterTResponse
 
read(TProtocol) - Method in class alluxio.thrift.RegisterWorkerTOptions
 
read(TProtocol) - Method in class alluxio.thrift.RegisterWorkerTResponse
 
read(TProtocol) - Method in class alluxio.thrift.ReinitializeFileTOptions
 
read(TProtocol) - Method in class alluxio.thrift.ReinitializeFileTResponse
 
read(TProtocol) - Method in class alluxio.thrift.RemoveBlockTOptions
 
read(TProtocol) - Method in class alluxio.thrift.RemoveBlockTResponse
 
read(TProtocol) - Method in class alluxio.thrift.RenameStoreTOptions
 
read(TProtocol) - Method in class alluxio.thrift.RenameStoreTResponse
 
read(TProtocol) - Method in class alluxio.thrift.RenameTOptions
 
read(TProtocol) - Method in class alluxio.thrift.RenameTResponse
 
read(TProtocol) - Method in class alluxio.thrift.ReportLostFileTOptions
 
read(TProtocol) - Method in class alluxio.thrift.ReportLostFileTResponse
 
read(TProtocol) - Method in class alluxio.thrift.RequestBlockLocationTOptions
 
read(TProtocol) - Method in class alluxio.thrift.RequestBlockLocationTResponse
 
read(TProtocol) - Method in class alluxio.thrift.RequestSpaceTOptions
 
read(TProtocol) - Method in class alluxio.thrift.RequestSpaceTResponse
 
read(TProtocol) - Method in class alluxio.thrift.ScheduleAsyncPersistenceTOptions
 
read(TProtocol) - Method in class alluxio.thrift.ScheduleAsyncPersistenceTResponse
 
read(TProtocol) - Method in class alluxio.thrift.SessionBlockHeartbeatTOptions
 
read(TProtocol) - Method in class alluxio.thrift.SessionBlockHeartbeatTResponse
 
read(TProtocol) - Method in class alluxio.thrift.SessionFileSystemHeartbeatTOptions
 
read(TProtocol) - Method in class alluxio.thrift.SessionFileSystemHeartbeatTResponse
 
read(TProtocol) - Method in class alluxio.thrift.SetAttributeTOptions
 
read(TProtocol) - Method in class alluxio.thrift.SetAttributeTResponse
 
read(TProtocol) - Method in class alluxio.thrift.SyncMetadataTOptions
 
read(TProtocol) - Method in class alluxio.thrift.SyncMetadataTResponse
 
read(TProtocol) - Method in class alluxio.thrift.TieredIdentity
 
read(TProtocol) - Method in class alluxio.thrift.UfsInfo
 
read(TProtocol) - Method in class alluxio.thrift.UnlockBlockTOptions
 
read(TProtocol) - Method in class alluxio.thrift.UnlockBlockTResponse
 
read(TProtocol) - Method in class alluxio.thrift.UnmountTOptions
 
read(TProtocol) - Method in class alluxio.thrift.UnmountTResponse
 
read(TProtocol) - Method in class alluxio.thrift.UpdateUfsModeTOptions
 
read(TProtocol) - Method in class alluxio.thrift.UpdateUfsModeTResponse
 
read(TProtocol) - Method in class alluxio.thrift.WorkerInfo
 
read(TProtocol) - Method in class alluxio.thrift.WorkerNetAddress
 
read() - Method in class alluxio.underfs.gcs.GCSInputStream
 
read(byte[], int, int) - Method in class alluxio.underfs.gcs.GCSInputStream
 
read() - Method in class alluxio.underfs.MultiRangeObjectInputStream
 
read(byte[]) - Method in class alluxio.underfs.MultiRangeObjectInputStream
 
read(byte[], int, int) - Method in class alluxio.underfs.MultiRangeObjectInputStream
 
read() - Method in class alluxio.underfs.s3a.S3AInputStream
 
read(byte[]) - Method in class alluxio.underfs.s3a.S3AInputStream
 
read(byte[], int, int) - Method in class alluxio.underfs.s3a.S3AInputStream
 
read(long, long) - Method in interface alluxio.worker.block.io.BlockReader
Reads data from the block.
read(long, long) - Method in class alluxio.worker.block.io.LocalFileBlockReader
 
read(long, long) - Method in class alluxio.worker.block.RemoteBlockReader
 
read(long, long) - Method in class alluxio.worker.block.UnderFileSystemBlockReader
 
READ_ONLY_VALUE - Static variable in enum alluxio.proto.journal.File.UfsMode
READ_ONLY = 1;
READ_WRITE_VALUE - Static variable in enum alluxio.proto.journal.File.UfsMode
READ_WRITE = 2;
readableBytes() - Method in interface alluxio.network.protocol.databuffer.DataBuffer
 
readableBytes() - Method in class alluxio.network.protocol.databuffer.DataByteArrayChannel
 
readableBytes() - Method in class alluxio.network.protocol.databuffer.DataByteBuffer
 
readableBytes() - Method in class alluxio.network.protocol.databuffer.DataFileChannel
 
readableBytes() - Method in class alluxio.network.protocol.databuffer.DataNettyBuffer
 
readableBytes() - Method in class alluxio.network.protocol.databuffer.DataNettyBufferV2
 
readBlock(long, long, long) - Method in interface alluxio.worker.block.BlockWorker
Gets the path to the block file in local storage.
readBlock(long, long, long) - Method in class alluxio.worker.block.DefaultBlockWorker
 
readBlockRemote(long, long, long) - Method in interface alluxio.worker.block.BlockWorker
Gets the block reader for the block.
readBlockRemote(long, long, long) - Method in class alluxio.worker.block.DefaultBlockWorker
 
readByte(byte[], int) - Static method in class alluxio.util.io.ByteIOUtils
Reads a specific byte value from the input byte array at the given offset.
readByte(ByteBuffer, int) - Static method in class alluxio.util.io.ByteIOUtils
Reads a specific byte value from the input byte buffer at the given offset.
readBytes(byte[], int, int) - Method in interface alluxio.network.protocol.databuffer.DataBuffer
Transfers this buffer's data to the specified destination starting at the current readerIndex and increases the readerIndex by the number of the transferred bytes (= length).
readBytes(byte[], int, int) - Method in class alluxio.network.protocol.databuffer.DataByteArrayChannel
 
readBytes(byte[], int, int) - Method in class alluxio.network.protocol.databuffer.DataByteBuffer
 
readBytes(byte[], int, int) - Method in class alluxio.network.protocol.databuffer.DataFileChannel
 
readBytes(byte[], int, int) - Method in class alluxio.network.protocol.databuffer.DataNettyBuffer
 
readBytes(byte[], int, int) - Method in class alluxio.network.protocol.databuffer.DataNettyBufferV2
 
readEntry() - Method in class alluxio.master.journal.JournalEntryStreamReader
Reads a journal entry from the input stream.
readFully(long, byte[]) - Method in class alluxio.hadoop.HdfsFileInputStream
 
readFully(long, byte[], int, int) - Method in class alluxio.hadoop.HdfsFileInputStream
 
readInt(byte[], int) - Static method in class alluxio.util.io.ByteIOUtils
Reads a specific integer byte value (4 bytes) from the input byte array at the given offset.
readInt(ByteBuffer, int) - Static method in class alluxio.util.io.ByteIOUtils
Reads a specific integer byte value (4 bytes) from the input byte buffer at the given offset.
readLock() - Method in class alluxio.worker.block.ClientRWLock
 
readLong(byte[], int) - Static method in class alluxio.util.io.ByteIOUtils
Reads a specific long byte value (8 bytes) from the input byte array at the given offset.
readNodeList(String) - Static method in class alluxio.cli.validation.Utils
Reads a list of nodes from given file name ignoring comments and empty lines.
READONLY_FIELD_NUMBER - Static variable in class alluxio.proto.journal.File.AddMountPointEntry
 
readPacket() - Method in class alluxio.client.block.stream.LocalFilePacketReader
 
readPacket() - Method in class alluxio.client.block.stream.NettyPacketReader
 
readPacket() - Method in interface alluxio.client.block.stream.PacketReader
Reads a packet.
readPartition() - Method in class alluxio.examples.Performance.AlluxioReadWorker
Reads a partition.
readRawVarint32(int, InputStream) - Static method in class alluxio.util.proto.ProtoUtils
A wrapper of CodedInputStream.readRawVarint32(InputStream).
ReadRequestContext<T extends alluxio.worker.netty.ReadRequest> - Class in alluxio.worker.netty
Represents the context of a read request received from netty channel.
ReadRequestContext(T) - Constructor for class alluxio.worker.netty.ReadRequestContext
 
readShort(byte[], int) - Static method in class alluxio.util.io.ByteIOUtils
Reads a specific short byte value (2 bytes) from the input byte array at the given offset.
ReadType - Enum in alluxio.client
Convenience modes for commonly used read types.
readUfsBlock(long, long, long) - Method in interface alluxio.worker.block.BlockWorker
Gets a block reader to read a UFS block.
readUfsBlock(long, long, long) - Method in class alluxio.worker.block.DefaultBlockWorker
 
RecomputeExecutor - Class in alluxio.master.lineage.recompute
A periodical executor that detects lost files and launches recompute jobs.
RecomputeExecutor(RecomputePlanner, FileSystemMaster) - Constructor for class alluxio.master.lineage.recompute.RecomputeExecutor
Creates a new instance of RecomputeExecutor.
RecomputePlan - Class in alluxio.master.lineage.recompute
A plan for recomputing the lost files.
RecomputePlan(List<Lineage>) - Constructor for class alluxio.master.lineage.recompute.RecomputePlan
Creates a new instance of RecomputePlan.
RecomputePlanner - Class in alluxio.master.lineage.recompute
Plans the recompute strategy.
RecomputePlanner(LineageStore, FileSystemMaster) - Constructor for class alluxio.master.lineage.recompute.RecomputePlanner
Creates a new instance of RecomputePlanner.
recover() - Method in interface alluxio.master.journalv0.JournalWriter
Recovers the checkpoint in case the master crashed while updating it previously.
recover() - Method in class alluxio.master.journalv0.ufs.UfsCheckpointManager
Recovers the checkpoint in case the master crashed while updating it.
recover() - Method in class alluxio.master.journalv0.ufs.UfsJournalWriter
 
RECURSIVE_FIELD_NUMBER - Static variable in class alluxio.proto.journal.File.DeleteFileEntry
 
recv_accessBlock() - Method in class alluxio.thrift.BlockWorkerClientService.Client
 
recv_backup() - Method in class alluxio.thrift.MetaMasterClientService.Client
 
recv_blockHeartbeat() - Method in class alluxio.thrift.BlockMasterWorkerService.Client
 
recv_cacheBlock() - Method in class alluxio.thrift.BlockWorkerClientService.Client
 
recv_cancelBlock() - Method in class alluxio.thrift.BlockWorkerClientService.Client
 
recv_cancelUfsFile() - Method in class alluxio.thrift.FileSystemWorkerClientService.Client
 
recv_checkConsistency() - Method in class alluxio.thrift.FileSystemMasterClientService.Client
 
recv_closeUfsFile() - Method in class alluxio.thrift.FileSystemWorkerClientService.Client
 
recv_commitBlock() - Method in class alluxio.thrift.BlockMasterWorkerService.Client
 
recv_completeFile() - Method in class alluxio.thrift.FileSystemMasterClientService.Client
 
recv_completePartition() - Method in class alluxio.thrift.KeyValueMasterClientService.Client
 
recv_completeStore() - Method in class alluxio.thrift.KeyValueMasterClientService.Client
 
recv_completeUfsFile() - Method in class alluxio.thrift.FileSystemWorkerClientService.Client
 
recv_createDirectory() - Method in class alluxio.thrift.FileSystemMasterClientService.Client
 
recv_createFile() - Method in class alluxio.thrift.FileSystemMasterClientService.Client
 
recv_createLineage() - Method in class alluxio.thrift.LineageMasterClientService.Client
 
recv_createStore() - Method in class alluxio.thrift.KeyValueMasterClientService.Client
 
recv_createUfsFile() - Method in class alluxio.thrift.FileSystemWorkerClientService.Client
 
recv_deleteLineage() - Method in class alluxio.thrift.LineageMasterClientService.Client
 
recv_deleteStore() - Method in class alluxio.thrift.KeyValueMasterClientService.Client
 
recv_fileSystemHeartbeat() - Method in class alluxio.thrift.FileSystemMasterWorkerService.Client
 
recv_free() - Method in class alluxio.thrift.FileSystemMasterClientService.Client
 
recv_get() - Method in class alluxio.thrift.KeyValueWorkerClientService.Client
 
recv_getBlockInfo() - Method in class alluxio.thrift.BlockMasterClientService.Client
 
recv_getBlockMasterInfo() - Method in class alluxio.thrift.BlockMasterClientService.Client
 
recv_getCapacityBytes() - Method in class alluxio.thrift.BlockMasterClientService.Client
 
recv_getConfigReport() - Method in class alluxio.thrift.MetaMasterClientService.Client
 
recv_getConfiguration() - Method in class alluxio.thrift.MetaMasterClientService.Client
 
recv_getFileInfo() - Method in class alluxio.thrift.FileSystemMasterWorkerService.Client
 
recv_getFilePath() - Method in class alluxio.thrift.FileSystemMasterClientService.Client
 
recv_getLineageInfoList() - Method in class alluxio.thrift.LineageMasterClientService.Client
 
recv_getMasterId() - Method in class alluxio.thrift.MetaMasterMasterService.Client
 
recv_getMasterInfo() - Method in class alluxio.thrift.MetaMasterClientService.Client
 
recv_getMetrics() - Method in class alluxio.thrift.MetaMasterClientService.Client
 
recv_getMountTable() - Method in class alluxio.thrift.FileSystemMasterClientService.Client
 
recv_getNewBlockIdForFile() - Method in class alluxio.thrift.FileSystemMasterClientService.Client
 
recv_getNextKeys() - Method in class alluxio.thrift.KeyValueWorkerClientService.Client
 
recv_getPartitionInfo() - Method in class alluxio.thrift.KeyValueMasterClientService.Client
 
recv_getPinnedFileIds() - Method in class alluxio.thrift.FileSystemMasterWorkerService.Client
 
recv_getServiceVersion() - Method in class alluxio.thrift.AlluxioService.Client
 
recv_getSize() - Method in class alluxio.thrift.KeyValueWorkerClientService.Client
 
recv_getStatus() - Method in class alluxio.thrift.FileSystemMasterClientService.Client
 
recv_getUfsInfo() - Method in class alluxio.thrift.FileSystemMasterWorkerService.Client
 
recv_getUsedBytes() - Method in class alluxio.thrift.BlockMasterClientService.Client
 
recv_getWorkerId() - Method in class alluxio.thrift.BlockMasterWorkerService.Client
 
recv_getWorkerInfoList() - Method in class alluxio.thrift.BlockMasterClientService.Client
 
recv_getWorkerReport() - Method in class alluxio.thrift.BlockMasterClientService.Client
 
recv_listStatus() - Method in class alluxio.thrift.FileSystemMasterClientService.Client
 
recv_loadMetadata() - Method in class alluxio.thrift.FileSystemMasterClientService.Client
 
recv_lockBlock() - Method in class alluxio.thrift.BlockWorkerClientService.Client
 
recv_masterHeartbeat() - Method in class alluxio.thrift.MetaMasterMasterService.Client
 
recv_mergeStore() - Method in class alluxio.thrift.KeyValueMasterClientService.Client
 
recv_metricsHeartbeat() - Method in class alluxio.thrift.MetricsMasterClientService.Client
 
recv_mount() - Method in class alluxio.thrift.FileSystemMasterClientService.Client
 
recv_openUfsFile() - Method in class alluxio.thrift.FileSystemWorkerClientService.Client
 
recv_promoteBlock() - Method in class alluxio.thrift.BlockWorkerClientService.Client
 
recv_registerMaster() - Method in class alluxio.thrift.MetaMasterMasterService.Client
 
recv_registerWorker() - Method in class alluxio.thrift.BlockMasterWorkerService.Client
 
recv_reinitializeFile() - Method in class alluxio.thrift.LineageMasterClientService.Client
 
recv_remove() - Method in class alluxio.thrift.FileSystemMasterClientService.Client
 
recv_removeBlock() - Method in class alluxio.thrift.BlockWorkerClientService.Client
 
recv_rename() - Method in class alluxio.thrift.FileSystemMasterClientService.Client
 
recv_renameStore() - Method in class alluxio.thrift.KeyValueMasterClientService.Client
 
recv_reportLostFile() - Method in class alluxio.thrift.LineageMasterClientService.Client
 
recv_requestBlockLocation() - Method in class alluxio.thrift.BlockWorkerClientService.Client
 
recv_requestSpace() - Method in class alluxio.thrift.BlockWorkerClientService.Client
 
recv_scheduleAsyncPersistence() - Method in class alluxio.thrift.FileSystemMasterClientService.Client
 
recv_sessionBlockHeartbeat() - Method in class alluxio.thrift.BlockWorkerClientService.Client
 
recv_sessionFileSystemHeartbeat() - Method in class alluxio.thrift.FileSystemWorkerClientService.Client
 
recv_setAttribute() - Method in class alluxio.thrift.FileSystemMasterClientService.Client
 
recv_unlockBlock() - Method in class alluxio.thrift.BlockWorkerClientService.Client
 
recv_unmount() - Method in class alluxio.thrift.FileSystemMasterClientService.Client
 
recv_updateUfsMode() - Method in class alluxio.thrift.FileSystemMasterClientService.Client
 
reduce(Text, Iterable<Text>, Reducer<Text, Text, Text, Text>.Context) - Method in class alluxio.checker.MapReduceIntegrationChecker.CheckerReducer
Merges the IP addresses of same Status.
reduce(BytesWritable, Iterable<BytesWritable>, Reducer<BytesWritable, BytesWritable, BytesWritable, BytesWritable>.Context) - Method in class alluxio.examples.keyvalue.hadoop.CloneStoreMapReduce.CloneStoreReducer
 
regenerateReport() - Method in class alluxio.master.meta.checkconf.ServerConfigurationChecker
Checks the server-side configurations and records the check results.
register(T) - Method in class alluxio.extensions.ExtensionFactoryRegistry
Registers a new factory.
register(StorageTierAssoc, List<String>, Map<String, Long>, Map<String, Long>, Set<Long>) - Method in class alluxio.master.block.meta.MasterWorkerInfo
Marks the worker as registered, while updating all of its metadata.
register(long, List<ConfigProperty>) - Method in class alluxio.master.meta.RetryHandlingMetaMasterMasterClient
Registers with the leader master.
register(PropertyKey) - Static method in class alluxio.PropertyKey
Registers the given key to the global key map.
register(UnderFileSystemFactory) - Static method in class alluxio.underfs.UnderFileSystemFactoryRegistry
Registers a new factory.
register(long, List<String>, Map<String, Long>, Map<String, Long>, Map<String, List<Long>>, List<ConfigProperty>) - Method in class alluxio.worker.block.BlockMasterClient
The method the worker should execute to register with the block master.
registerAllExtensions(ExtensionRegistry) - Static method in class alluxio.proto.dataserver.Protocol
 
registerAllExtensions(ExtensionRegistry) - Static method in class alluxio.proto.journal.Block
 
registerAllExtensions(ExtensionRegistry) - Static method in class alluxio.proto.journal.File
 
registerAllExtensions(ExtensionRegistry) - Static method in class alluxio.proto.journal.Journal
 
registerAllExtensions(ExtensionRegistry) - Static method in class alluxio.proto.journal.KeyValue
 
registerAllExtensions(ExtensionRegistry) - Static method in class alluxio.proto.journal.Lineage
 
registerAllExtensions(ExtensionRegistry) - Static method in class alluxio.proto.status.Status
 
registerBlockForDeletion(long) - Method in interface alluxio.master.file.BlockDeletionContext
 
registerBlockForDeletion(long) - Method in class alluxio.master.file.DefaultBlockDeletionContext
 
registerBlockForDeletion(long) - Method in class alluxio.master.file.NoopBlockDeletionContext
 
registerBlocksForDeletion(Collection<Long>) - Method in interface alluxio.master.file.BlockDeletionContext
 
registerBlocksForDeletion(Collection<Long>) - Method in class alluxio.master.file.DefaultBlockDeletionContext
 
registerBlockStoreEventListener(BlockStoreEventListener) - Method in interface alluxio.worker.block.BlockStore
Registers a BlockStoreEventListener to this block store.
registerBlockStoreEventListener(BlockStoreEventListener) - Method in class alluxio.worker.block.TieredBlockStore
 
registerChangeListener(Runnable) - Method in class alluxio.master.meta.checkconf.ServerConfigurationStore
Registers callback functions to use when this store has any changes.
registerGaugeIfAbsent(String, Gauge<T>) - Static method in class alluxio.metrics.MetricsSystem
Registers a gauge if it has not been registered.
registerGauges(BlockMaster) - Static method in class alluxio.master.block.DefaultBlockMaster.Metrics
Registers metric gauges.
registerGauges(FileSystemMaster, UfsManager) - Static method in class alluxio.master.file.DefaultFileSystemMaster.Metrics
Register some file system master related gauges.
registerGauges(BlockWorker) - Static method in class alluxio.worker.block.DefaultBlockWorker.Metrics
Registers metric gauges.
registerLostWorkerFoundListener(Consumer<Address>) - Method in interface alluxio.master.block.BlockMaster
Registers callback functions to use when lost workers become alive.
registerLostWorkerFoundListener(Consumer<Address>) - Method in class alluxio.master.block.DefaultBlockMaster
 
registerMaster(long, RegisterMasterTOptions) - Method in class alluxio.master.meta.MetaMasterMasterServiceHandler
 
registerMaster(long, RegisterMasterTOptions, AsyncMethodCallback) - Method in class alluxio.thrift.MetaMasterMasterService.AsyncClient
 
registerMaster(long, RegisterMasterTOptions, AsyncMethodCallback) - Method in interface alluxio.thrift.MetaMasterMasterService.AsyncIface
 
registerMaster() - Constructor for class alluxio.thrift.MetaMasterMasterService.AsyncProcessor.registerMaster
 
registerMaster(long, RegisterMasterTOptions) - Method in class alluxio.thrift.MetaMasterMasterService.Client
 
registerMaster(long, RegisterMasterTOptions) - Method in interface alluxio.thrift.MetaMasterMasterService.Iface
Registers a master.
registerMaster() - Constructor for class alluxio.thrift.MetaMasterMasterService.Processor.registerMaster
 
registerMaster_args() - Constructor for class alluxio.thrift.MetaMasterMasterService.registerMaster_args
 
registerMaster_args(long, RegisterMasterTOptions) - Constructor for class alluxio.thrift.MetaMasterMasterService.registerMaster_args
 
registerMaster_args(MetaMasterMasterService.registerMaster_args) - Constructor for class alluxio.thrift.MetaMasterMasterService.registerMaster_args
Performs a deep copy on other.
registerMaster_call(long, RegisterMasterTOptions, AsyncMethodCallback, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class alluxio.thrift.MetaMasterMasterService.AsyncClient.registerMaster_call
 
registerMaster_result() - Constructor for class alluxio.thrift.MetaMasterMasterService.registerMaster_result
 
registerMaster_result(RegisterMasterTResponse, AlluxioTException) - Constructor for class alluxio.thrift.MetaMasterMasterService.registerMaster_result
 
registerMaster_result(MetaMasterMasterService.registerMaster_result) - Constructor for class alluxio.thrift.MetaMasterMasterService.registerMaster_result
Performs a deep copy on other.
RegisterMasterTOptions - Class in alluxio.thrift
 
RegisterMasterTOptions() - Constructor for class alluxio.thrift.RegisterMasterTOptions
 
RegisterMasterTOptions(List<ConfigProperty>) - Constructor for class alluxio.thrift.RegisterMasterTOptions
 
RegisterMasterTOptions(RegisterMasterTOptions) - Constructor for class alluxio.thrift.RegisterMasterTOptions
Performs a deep copy on other.
RegisterMasterTOptions._Fields - Enum in alluxio.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
RegisterMasterTResponse - Class in alluxio.thrift
 
RegisterMasterTResponse() - Constructor for class alluxio.thrift.RegisterMasterTResponse
 
RegisterMasterTResponse(RegisterMasterTResponse) - Constructor for class alluxio.thrift.RegisterMasterTResponse
Performs a deep copy on other.
RegisterMasterTResponse._Fields - Enum in alluxio.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
registerNewConf(Address, List<ConfigProperty>) - Method in class alluxio.master.meta.checkconf.ServerConfigurationStore
Registers new configuration information.
registerNewWorkerConfListener(BiConsumer<Address, List<ConfigProperty>>) - Method in interface alluxio.master.block.BlockMaster
Registers callback functions to use when workers register with configuration.
registerNewWorkerConfListener(BiConsumer<Address, List<ConfigProperty>>) - Method in class alluxio.master.block.DefaultBlockMaster
 
registerWorker(long, List<String>, Map<String, Long>, Map<String, Long>, Map<String, List<Long>>, RegisterWorkerTOptions) - Method in class alluxio.master.block.BlockMasterWorkerServiceHandler
 
registerWorker(long, List<String>, Map<String, Long>, Map<String, Long>, Map<String, List<Long>>, RegisterWorkerTOptions, AsyncMethodCallback) - Method in class alluxio.thrift.BlockMasterWorkerService.AsyncClient
 
registerWorker(long, List<String>, Map<String, Long>, Map<String, Long>, Map<String, List<Long>>, RegisterWorkerTOptions, AsyncMethodCallback) - Method in interface alluxio.thrift.BlockMasterWorkerService.AsyncIface
 
registerWorker() - Constructor for class alluxio.thrift.BlockMasterWorkerService.AsyncProcessor.registerWorker
 
registerWorker(long, List<String>, Map<String, Long>, Map<String, Long>, Map<String, List<Long>>, RegisterWorkerTOptions) - Method in class alluxio.thrift.BlockMasterWorkerService.Client
 
registerWorker(long, List<String>, Map<String, Long>, Map<String, Long>, Map<String, List<Long>>, RegisterWorkerTOptions) - Method in interface alluxio.thrift.BlockMasterWorkerService.Iface
Registers a worker.
registerWorker() - Constructor for class alluxio.thrift.BlockMasterWorkerService.Processor.registerWorker
 
registerWorker_args() - Constructor for class alluxio.thrift.BlockMasterWorkerService.registerWorker_args
 
registerWorker_args(long, List<String>, Map<String, Long>, Map<String, Long>, Map<String, List<Long>>, RegisterWorkerTOptions) - Constructor for class alluxio.thrift.BlockMasterWorkerService.registerWorker_args
 
registerWorker_args(BlockMasterWorkerService.registerWorker_args) - Constructor for class alluxio.thrift.BlockMasterWorkerService.registerWorker_args
Performs a deep copy on other.
registerWorker_call(long, List<String>, Map<String, Long>, Map<String, Long>, Map<String, List<Long>>, RegisterWorkerTOptions, AsyncMethodCallback, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class alluxio.thrift.BlockMasterWorkerService.AsyncClient.registerWorker_call
 
registerWorker_result() - Constructor for class alluxio.thrift.BlockMasterWorkerService.registerWorker_result
 
registerWorker_result(RegisterWorkerTResponse, AlluxioTException) - Constructor for class alluxio.thrift.BlockMasterWorkerService.registerWorker_result
 
registerWorker_result(BlockMasterWorkerService.registerWorker_result) - Constructor for class alluxio.thrift.BlockMasterWorkerService.registerWorker_result
Performs a deep copy on other.
registerWorkerLostListener(Consumer<Address>) - Method in interface alluxio.master.block.BlockMaster
Registers callback functions to use when detecting lost workers.
registerWorkerLostListener(Consumer<Address>) - Method in class alluxio.master.block.DefaultBlockMaster
 
RegisterWorkerTOptions - Class in alluxio.thrift
 
RegisterWorkerTOptions() - Constructor for class alluxio.thrift.RegisterWorkerTOptions
 
RegisterWorkerTOptions(RegisterWorkerTOptions) - Constructor for class alluxio.thrift.RegisterWorkerTOptions
Performs a deep copy on other.
RegisterWorkerTOptions._Fields - Enum in alluxio.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
RegisterWorkerTResponse - Class in alluxio.thrift
 
RegisterWorkerTResponse() - Constructor for class alluxio.thrift.RegisterWorkerTResponse
 
RegisterWorkerTResponse(RegisterWorkerTResponse) - Constructor for class alluxio.thrift.RegisterWorkerTResponse
Performs a deep copy on other.
RegisterWorkerTResponse._Fields - Enum in alluxio.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
Registry<T extends Server<U>,U> - Class in alluxio
Class for registering individual Servers that run within an Alluxio process.
Registry() - Constructor for class alluxio.Registry
Creates a new instance of Registry.
REINITIALIZE_FILE - Static variable in class alluxio.master.lineage.LineageMasterClientRestServiceHandler
Deprecated.
 
REINITIALIZE_FILE_FIELD_NUMBER - Static variable in class alluxio.proto.journal.Journal.JournalEntry
 
reinitializeFile(String, long, long, TtlAction) - Method in class alluxio.client.lineage.LineageMasterClient
Reinitializates a given file.
reinitializeFile(AlluxioURI, long, long, TtlAction) - Method in class alluxio.master.file.DefaultFileSystemMaster
 
reinitializeFile(AlluxioURI, long, long, TtlAction) - Method in interface alluxio.master.file.FileSystemMaster
Reinitializes the blocks of an existing open file.
reinitializeFile(LockedInodePath, long, long, TtlAction) - Method in class alluxio.master.file.meta.InodeTree
Reinitializes the block size and TTL of an existing open file.
reinitializeFile(String, long, long, TtlAction) - Method in class alluxio.master.lineage.DefaultLineageMaster
 
reinitializeFile(String, long, long, TtlAction) - Method in interface alluxio.master.lineage.LineageMaster
Reinitializes the file when the file is lost or not completed.
reinitializeFile(String, Long, Long, TtlAction) - Method in class alluxio.master.lineage.LineageMasterClientRestServiceHandler
Deprecated.
 
reinitializeFile(String, long, long, TTtlAction, ReinitializeFileTOptions) - Method in class alluxio.master.lineage.LineageMasterClientServiceHandler
 
reinitializeFile(String, long, long, TTtlAction, ReinitializeFileTOptions, AsyncMethodCallback) - Method in class alluxio.thrift.LineageMasterClientService.AsyncClient
 
reinitializeFile(String, long, long, TTtlAction, ReinitializeFileTOptions, AsyncMethodCallback) - Method in interface alluxio.thrift.LineageMasterClientService.AsyncIface
 
reinitializeFile() - Constructor for class alluxio.thrift.LineageMasterClientService.AsyncProcessor.reinitializeFile
 
reinitializeFile(String, long, long, TTtlAction, ReinitializeFileTOptions) - Method in class alluxio.thrift.LineageMasterClientService.Client
 
reinitializeFile(String, long, long, TTtlAction, ReinitializeFileTOptions) - Method in interface alluxio.thrift.LineageMasterClientService.Iface
Reinitializes a file.
reinitializeFile() - Constructor for class alluxio.thrift.LineageMasterClientService.Processor.reinitializeFile
 
reinitializeFile_args() - Constructor for class alluxio.thrift.LineageMasterClientService.reinitializeFile_args
 
reinitializeFile_args(String, long, long, TTtlAction, ReinitializeFileTOptions) - Constructor for class alluxio.thrift.LineageMasterClientService.reinitializeFile_args
 
reinitializeFile_args(LineageMasterClientService.reinitializeFile_args) - Constructor for class alluxio.thrift.LineageMasterClientService.reinitializeFile_args
Performs a deep copy on other.
reinitializeFile_call(String, long, long, TTtlAction, ReinitializeFileTOptions, AsyncMethodCallback, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class alluxio.thrift.LineageMasterClientService.AsyncClient.reinitializeFile_call
 
reinitializeFile_result() - Constructor for class alluxio.thrift.LineageMasterClientService.reinitializeFile_result
 
reinitializeFile_result(ReinitializeFileTResponse, AlluxioTException) - Constructor for class alluxio.thrift.LineageMasterClientService.reinitializeFile_result
 
reinitializeFile_result(LineageMasterClientService.reinitializeFile_result) - Constructor for class alluxio.thrift.LineageMasterClientService.reinitializeFile_result
Performs a deep copy on other.
ReinitializeFileTOptions - Class in alluxio.thrift
 
ReinitializeFileTOptions() - Constructor for class alluxio.thrift.ReinitializeFileTOptions
 
ReinitializeFileTOptions(ReinitializeFileTOptions) - Constructor for class alluxio.thrift.ReinitializeFileTOptions
Performs a deep copy on other.
ReinitializeFileTOptions._Fields - Enum in alluxio.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
ReinitializeFileTResponse - Class in alluxio.thrift
 
ReinitializeFileTResponse() - Constructor for class alluxio.thrift.ReinitializeFileTResponse
 
ReinitializeFileTResponse(long) - Constructor for class alluxio.thrift.ReinitializeFileTResponse
 
ReinitializeFileTResponse(ReinitializeFileTResponse) - Constructor for class alluxio.thrift.ReinitializeFileTResponse
Performs a deep copy on other.
ReinitializeFileTResponse._Fields - Enum in alluxio.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
release() - Method in interface alluxio.network.protocol.databuffer.DataBuffer
Releases the underlying buffer of this DataBuffer if no longer needed.
release() - Method in class alluxio.network.protocol.databuffer.DataByteArrayChannel
 
release() - Method in class alluxio.network.protocol.databuffer.DataByteBuffer
 
release() - Method in class alluxio.network.protocol.databuffer.DataFileChannel
 
release() - Method in class alluxio.network.protocol.databuffer.DataNettyBuffer
Releases the Netty ByteBuf.
release() - Method in class alluxio.network.protocol.databuffer.DataNettyBufferV2
Release the Netty ByteBuf.
release(T) - Method in class alluxio.resource.DynamicResourcePool
Releases the resource to the pool.
release(T) - Method in interface alluxio.resource.Pool
Releases the resource to the pool.
release(T) - Method in class alluxio.resource.ResourcePool
Releases an object of type T, this must be called after the thread is done using a resource obtained by acquire.
release(InputStream) - Method in class alluxio.worker.block.UfsInputStreamManager
Releases an input stream.
releaseAccess(long, long) - Method in class alluxio.worker.block.UnderFileSystemBlockStore
Releases the access token of this block by removing this (sessionId, blockId) pair from the store.
releaseMasterClient(FileSystemMasterClient) - Method in class alluxio.client.file.FileSystemContext
Releases a file system master client into the file system master client pool.
releaseMasterClient(LineageMasterClient) - Method in enum alluxio.client.lineage.LineageContext
Releases a lineage master client into the lineage master client pool.
releaseNettyChannel(WorkerNetAddress, Channel) - Method in class alluxio.client.file.FileSystemContext
Releases a netty channel to the channel pools.
remaining() - Method in class alluxio.client.block.stream.BlockInStream
 
remaining() - Method in class alluxio.client.block.stream.BlockOutStream
 
remaining() - Method in interface alluxio.client.BoundedStream
 
remaining() - Method in class alluxio.client.file.FileInStream
 
REMOTE_LOG_MDC_PROCESS_TYPE_KEY - Static variable in class alluxio.AlluxioRemoteLogFilter
Name (Key) of the MDC info.
RemoteBlockReader - Class in alluxio.worker.block
Reads a block from a remote worker node.
RemoteBlockReader(long, long, InetSocketAddress, Protocol.OpenUfsBlockOptions) - Constructor for class alluxio.worker.block.RemoteBlockReader
Constructs a remote block reader.
remove(Object) - Method in class alluxio.collections.ConcurrentHashSet
 
remove(T) - Method in interface alluxio.collections.FieldIndex
Removes the object o from the index.
remove(Object) - Method in class alluxio.collections.IndexedSet
Removes an object from the set.
remove(T) - Method in class alluxio.collections.NonUniqueFieldIndex
 
remove(T) - Method in class alluxio.collections.UniqueFieldIndex
 
remove(PropertyKey) - Method in class alluxio.conf.AlluxioProperties
Remove the value set for key.
REMOVE - Static variable in class alluxio.master.file.FileSystemMasterClientRestServiceHandler
Deprecated.
 
remove(String, boolean) - Method in class alluxio.master.file.FileSystemMasterClientRestServiceHandler
Deprecated.
 
remove(String, boolean, DeleteTOptions) - Method in class alluxio.master.file.FileSystemMasterClientServiceHandler
 
remove(Inode<?>) - Method in class alluxio.master.file.meta.TtlBucketList
Removes a inode from the bucket containing it if the inode is in one of the buckets, otherwise, do nothing.
remove() - Static method in class alluxio.security.authentication.AuthenticatedClientUser
Removes the User from the ThreadLocal variable.
remove(String, boolean, DeleteTOptions, AsyncMethodCallback) - Method in class alluxio.thrift.FileSystemMasterClientService.AsyncClient
 
remove(String, boolean, DeleteTOptions, AsyncMethodCallback) - Method in interface alluxio.thrift.FileSystemMasterClientService.AsyncIface
 
remove() - Constructor for class alluxio.thrift.FileSystemMasterClientService.AsyncProcessor.remove
 
remove(String, boolean, DeleteTOptions) - Method in class alluxio.thrift.FileSystemMasterClientService.Client
 
remove(String, boolean, DeleteTOptions) - Method in interface alluxio.thrift.FileSystemMasterClientService.Iface
Deletes a file or a directory and returns whether the remove operation succeeded.
remove() - Constructor for class alluxio.thrift.FileSystemMasterClientService.Processor.remove
 
remove(T) - Method in class alluxio.util.executor.ControllableQueue
Removes an element.
remove_args() - Constructor for class alluxio.thrift.FileSystemMasterClientService.remove_args
 
remove_args(String, boolean, DeleteTOptions) - Constructor for class alluxio.thrift.FileSystemMasterClientService.remove_args
 
remove_args(FileSystemMasterClientService.remove_args) - Constructor for class alluxio.thrift.FileSystemMasterClientService.remove_args
Performs a deep copy on other.
remove_call(String, boolean, DeleteTOptions, AsyncMethodCallback, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class alluxio.thrift.FileSystemMasterClientService.AsyncClient.remove_call
 
remove_result() - Constructor for class alluxio.thrift.FileSystemMasterClientService.remove_result
 
remove_result(DeleteTResponse, AlluxioTException) - Constructor for class alluxio.thrift.FileSystemMasterClientService.remove_result
 
remove_result(FileSystemMasterClientService.remove_result) - Constructor for class alluxio.thrift.FileSystemMasterClientService.remove_result
Performs a deep copy on other.
removeAll(Collection<?>) - Method in class alluxio.collections.ConcurrentHashSet
 
removeBlock(long) - Method in class alluxio.master.block.meta.MasterWorkerInfo
Removes a block from the worker.
removeBlock(long, RemoveBlockTOptions, AsyncMethodCallback) - Method in class alluxio.thrift.BlockWorkerClientService.AsyncClient
 
removeBlock(long, RemoveBlockTOptions, AsyncMethodCallback) - Method in interface alluxio.thrift.BlockWorkerClientService.AsyncIface
 
removeBlock() - Constructor for class alluxio.thrift.BlockWorkerClientService.AsyncProcessor.removeBlock
 
removeBlock(long, RemoveBlockTOptions) - Method in class alluxio.thrift.BlockWorkerClientService.Client
 
removeBlock(long, RemoveBlockTOptions) - Method in interface alluxio.thrift.BlockWorkerClientService.Iface
Used to remove a block from an Alluxio worker.
removeBlock() - Constructor for class alluxio.thrift.BlockWorkerClientService.Processor.removeBlock
 
removeBlock(long, long) - Method in interface alluxio.worker.block.BlockStore
Removes an existing block.
removeBlock(long, long, BlockStoreLocation) - Method in interface alluxio.worker.block.BlockStore
Removes an existing block.
removeBlock(long, long) - Method in interface alluxio.worker.block.BlockWorker
Frees a block from Alluxio managed space.
removeBlock(long, RemoveBlockTOptions) - Method in class alluxio.worker.block.BlockWorkerClientServiceHandler
 
removeBlock(long, long) - Method in class alluxio.worker.block.DefaultBlockWorker
 
removeBlock(long, long) - Method in class alluxio.worker.block.TieredBlockStore
 
removeBlock(long, long, BlockStoreLocation) - Method in class alluxio.worker.block.TieredBlockStore
 
removeBlock_args() - Constructor for class alluxio.thrift.BlockWorkerClientService.removeBlock_args
 
removeBlock_args(long, RemoveBlockTOptions) - Constructor for class alluxio.thrift.BlockWorkerClientService.removeBlock_args
 
removeBlock_args(BlockWorkerClientService.removeBlock_args) - Constructor for class alluxio.thrift.BlockWorkerClientService.removeBlock_args
Performs a deep copy on other.
removeBlock_call(long, RemoveBlockTOptions, AsyncMethodCallback, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class alluxio.thrift.BlockWorkerClientService.AsyncClient.removeBlock_call
 
removeBlock_result() - Constructor for class alluxio.thrift.BlockWorkerClientService.removeBlock_result
 
removeBlock_result(RemoveBlockTResponse, AlluxioTException) - Constructor for class alluxio.thrift.BlockWorkerClientService.removeBlock_result
 
removeBlock_result(BlockWorkerClientService.removeBlock_result) - Constructor for class alluxio.thrift.BlockWorkerClientService.removeBlock_result
Performs a deep copy on other.
removeBlockMeta(BlockMeta) - Method in class alluxio.worker.block.BlockMetadataManager
Removes the metadata of a specific block.
removeBlockMeta(BlockMeta) - Method in class alluxio.worker.block.meta.StorageDir
Removes a block from this storage dir.
removeBlocks(List<Long>, boolean) - Method in interface alluxio.master.block.BlockMaster
Removes blocks from workers.
removeBlocks(List<Long>, boolean) - Method in class alluxio.master.block.DefaultBlockMaster
 
RemoveBlockTOptions - Class in alluxio.thrift
 
RemoveBlockTOptions() - Constructor for class alluxio.thrift.RemoveBlockTOptions
 
RemoveBlockTOptions(RemoveBlockTOptions) - Constructor for class alluxio.thrift.RemoveBlockTOptions
Performs a deep copy on other.
RemoveBlockTOptions._Fields - Enum in alluxio.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
RemoveBlockTResponse - Class in alluxio.thrift
 
RemoveBlockTResponse() - Constructor for class alluxio.thrift.RemoveBlockTResponse
 
RemoveBlockTResponse(RemoveBlockTResponse) - Constructor for class alluxio.thrift.RemoveBlockTResponse
Performs a deep copy on other.
RemoveBlockTResponse._Fields - Enum in alluxio.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
removeBuckets(Set<TtlBucket>) - Method in class alluxio.master.file.meta.TtlBucketList
Removes all buckets in the set.
removeByField(IndexDefinition<T>, Object) - Method in class alluxio.collections.IndexedSet
Removes the subset of objects with the specified index field value.
removeChild(DirectedAcyclicGraphNode<T>) - Method in class alluxio.collections.DirectedAcyclicGraphNode
Removes a child node from the node.
removeChild(Inode<?>) - Method in class alluxio.master.file.meta.InodeDirectory
Removes the given inode from the directory.
removeChild(String) - Method in class alluxio.master.file.meta.InodeDirectory
Removes the given child by its name from the directory.
removeInode(Inode<?>) - Method in class alluxio.master.file.meta.TtlBucket
Removes a inode from the bucket.
removeMount(long) - Method in class alluxio.underfs.AbstractUfsManager
 
removeMount(long) - Method in class alluxio.underfs.MasterUfsManager
 
removeMount(long) - Method in interface alluxio.underfs.UfsManager
Removes the association from a mount id to a UFS instance.
removeProperties(int) - Method in class alluxio.proto.journal.File.AddMountPointEntry.Builder
repeated .alluxio.proto.journal.StringPairEntry properties = 4;
removeSession(long) - Method in class alluxio.Sessions
Removes the given session from the session pool.
removeTempBlockMeta(TempBlockMeta) - Method in class alluxio.worker.block.meta.StorageDir
Removes a temp block from this storage dir.
removeTimer(ScheduledTimer) - Static method in class alluxio.heartbeat.HeartbeatScheduler
Removes a timer from the scheduler.
removeWorker(long) - Method in class alluxio.master.block.meta.MasterBlockInfo
Removes the worker from the locations of this block.
rename(AlluxioURI, AlluxioURI) - Method in class alluxio.client.file.BaseFileSystem
 
rename(AlluxioURI, AlluxioURI, RenameOptions) - Method in class alluxio.client.file.BaseFileSystem
 
rename(AlluxioURI, AlluxioURI) - Method in interface alluxio.client.file.FileSystem
Convenience method for FileSystem.rename(AlluxioURI, AlluxioURI, RenameOptions) with default options.
rename(AlluxioURI, AlluxioURI, RenameOptions) - Method in interface alluxio.client.file.FileSystem
Renames an existing Alluxio path to another Alluxio path in Alluxio.
rename(AlluxioURI, AlluxioURI) - Method in interface alluxio.client.file.FileSystemMasterClient
Renames a file or a directory.
rename(AlluxioURI, AlluxioURI, RenameOptions) - Method in interface alluxio.client.file.FileSystemMasterClient
Renames a file or a directory.
rename(AlluxioURI, AlluxioURI) - Method in class alluxio.client.file.RetryHandlingFileSystemMasterClient
 
rename(AlluxioURI, AlluxioURI, RenameOptions) - Method in class alluxio.client.file.RetryHandlingFileSystemMasterClient
 
rename(AlluxioURI, AlluxioURI, RenameOptions) - Method in class alluxio.master.file.DefaultFileSystemMaster
 
rename(AlluxioURI, AlluxioURI, RenameOptions) - Method in interface alluxio.master.file.FileSystemMaster
Renames a file to a destination.
RENAME - Static variable in class alluxio.master.file.FileSystemMasterClientRestServiceHandler
Deprecated.
 
rename(String, String) - Method in class alluxio.master.file.FileSystemMasterClientRestServiceHandler
Deprecated.
 
rename(String, String, RenameTOptions) - Method in class alluxio.master.file.FileSystemMasterClientServiceHandler
 
RENAME - Static variable in class alluxio.proxy.PathsRestServiceHandler
 
rename(String, String, RenameOptions) - Method in class alluxio.proxy.PathsRestServiceHandler
 
rename(String, String, RenameTOptions, AsyncMethodCallback) - Method in class alluxio.thrift.FileSystemMasterClientService.AsyncClient
 
rename(String, String, RenameTOptions, AsyncMethodCallback) - Method in interface alluxio.thrift.FileSystemMasterClientService.AsyncIface
 
rename() - Constructor for class alluxio.thrift.FileSystemMasterClientService.AsyncProcessor.rename
 
rename(String, String, RenameTOptions) - Method in class alluxio.thrift.FileSystemMasterClientService.Client
 
rename(String, String, RenameTOptions) - Method in interface alluxio.thrift.FileSystemMasterClientService.Iface
Renames a file or a directory.
rename() - Constructor for class alluxio.thrift.FileSystemMasterClientService.Processor.rename
 
rename_args() - Constructor for class alluxio.thrift.FileSystemMasterClientService.rename_args
 
rename_args(String, String, RenameTOptions) - Constructor for class alluxio.thrift.FileSystemMasterClientService.rename_args
 
rename_args(FileSystemMasterClientService.rename_args) - Constructor for class alluxio.thrift.FileSystemMasterClientService.rename_args
Performs a deep copy on other.
rename_call(String, String, RenameTOptions, AsyncMethodCallback, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class alluxio.thrift.FileSystemMasterClientService.AsyncClient.rename_call
 
RENAME_FIELD_NUMBER - Static variable in class alluxio.proto.journal.Journal.JournalEntry
 
RENAME_PATH_OPS - Static variable in class alluxio.metrics.MasterMetrics
 
rename_result() - Constructor for class alluxio.thrift.FileSystemMasterClientService.rename_result
 
rename_result(RenameTResponse, AlluxioTException) - Constructor for class alluxio.thrift.FileSystemMasterClientService.rename_result
 
rename_result(FileSystemMasterClientService.rename_result) - Constructor for class alluxio.thrift.FileSystemMasterClientService.rename_result
Performs a deep copy on other.
RENAME_STORE_FIELD_NUMBER - Static variable in class alluxio.proto.journal.Journal.JournalEntry
 
renameDirectory(String, String) - Method in class alluxio.underfs.hdfs.HdfsUnderFileSystem
 
renameDirectory(String, String) - Method in class alluxio.underfs.local.LocalUnderFileSystem
 
renameDirectory(String, String) - Method in class alluxio.underfs.ObjectUnderFileSystem
 
renameDirectory(String, String) - Method in interface alluxio.underfs.UnderFileSystem
Renames a directory from src to dst in under file system.
renameDirectory(String, String) - Method in class alluxio.underfs.UnderFileSystemWithLogging
 
renameFile(String, String) - Method in class alluxio.underfs.hdfs.HdfsUnderFileSystem
 
renameFile(String, String) - Method in class alluxio.underfs.local.LocalUnderFileSystem
 
renameFile(String, String) - Method in class alluxio.underfs.ObjectUnderFileSystem
 
renameFile(String, String) - Method in interface alluxio.underfs.UnderFileSystem
Renames a file from src to dst in under file system.
renameFile(String, String) - Method in class alluxio.underfs.UnderFileSystemWithLogging
 
RenameOptions - Class in alluxio.client.file.options
Method options for renaming a file or a directory.
RenameOptions - Class in alluxio.master.file.options
Method options for completing a file.
RenameOptions(RenameTOptions) - Constructor for class alluxio.master.file.options.RenameOptions
 
renameStore(AlluxioURI, AlluxioURI) - Method in class alluxio.client.keyvalue.BaseKeyValueSystem
 
renameStore(AlluxioURI, AlluxioURI) - Method in class alluxio.client.keyvalue.KeyValueMasterClient
Renames a completed key-value store.
renameStore(AlluxioURI, AlluxioURI) - Method in interface alluxio.client.keyvalue.KeyValueSystem
Rename a completed key-value store.
renameStore(AlluxioURI, AlluxioURI) - Method in class alluxio.master.keyvalue.DefaultKeyValueMaster
 
renameStore(AlluxioURI, AlluxioURI) - Method in interface alluxio.master.keyvalue.KeyValueMaster
Renames one completed key-value store.
renameStore(String, String, RenameStoreTOptions) - Method in class alluxio.master.keyvalue.KeyValueMasterClientServiceHandler
 
renameStore(String, String, RenameStoreTOptions, AsyncMethodCallback) - Method in class alluxio.thrift.KeyValueMasterClientService.AsyncClient
 
renameStore(String, String, RenameStoreTOptions, AsyncMethodCallback) - Method in interface alluxio.thrift.KeyValueMasterClientService.AsyncIface
 
renameStore() - Constructor for class alluxio.thrift.KeyValueMasterClientService.AsyncProcessor.renameStore
 
renameStore(String, String, RenameStoreTOptions) - Method in class alluxio.thrift.KeyValueMasterClientService.Client
 
renameStore(String, String, RenameStoreTOptions) - Method in interface alluxio.thrift.KeyValueMasterClientService.Iface
Renames a completed key-value store.
renameStore() - Constructor for class alluxio.thrift.KeyValueMasterClientService.Processor.renameStore
 
renameStore_args() - Constructor for class alluxio.thrift.KeyValueMasterClientService.renameStore_args
 
renameStore_args(String, String, RenameStoreTOptions) - Constructor for class alluxio.thrift.KeyValueMasterClientService.renameStore_args
 
renameStore_args(KeyValueMasterClientService.renameStore_args) - Constructor for class alluxio.thrift.KeyValueMasterClientService.renameStore_args
Performs a deep copy on other.
renameStore_call(String, String, RenameStoreTOptions, AsyncMethodCallback, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class alluxio.thrift.KeyValueMasterClientService.AsyncClient.renameStore_call
 
renameStore_result() - Constructor for class alluxio.thrift.KeyValueMasterClientService.renameStore_result
 
renameStore_result(RenameStoreTResponse, AlluxioTException) - Constructor for class alluxio.thrift.KeyValueMasterClientService.renameStore_result
 
renameStore_result(KeyValueMasterClientService.renameStore_result) - Constructor for class alluxio.thrift.KeyValueMasterClientService.renameStore_result
Performs a deep copy on other.
RenameStoreTOptions - Class in alluxio.thrift
 
RenameStoreTOptions() - Constructor for class alluxio.thrift.RenameStoreTOptions
 
RenameStoreTOptions(RenameStoreTOptions) - Constructor for class alluxio.thrift.RenameStoreTOptions
Performs a deep copy on other.
RenameStoreTOptions._Fields - Enum in alluxio.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
RenameStoreTResponse - Class in alluxio.thrift
 
RenameStoreTResponse() - Constructor for class alluxio.thrift.RenameStoreTResponse
 
RenameStoreTResponse(RenameStoreTResponse) - Constructor for class alluxio.thrift.RenameStoreTResponse
Performs a deep copy on other.
RenameStoreTResponse._Fields - Enum in alluxio.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
RenameTOptions - Class in alluxio.thrift
 
RenameTOptions() - Constructor for class alluxio.thrift.RenameTOptions
 
RenameTOptions(RenameTOptions) - Constructor for class alluxio.thrift.RenameTOptions
Performs a deep copy on other.
RenameTOptions._Fields - Enum in alluxio.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
RenameTResponse - Class in alluxio.thrift
 
RenameTResponse() - Constructor for class alluxio.thrift.RenameTResponse
 
RenameTResponse(RenameTResponse) - Constructor for class alluxio.thrift.RenameTResponse
Performs a deep copy on other.
RenameTResponse._Fields - Enum in alluxio.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
replaceHostName(AlluxioURI) - Static method in class alluxio.util.network.NetworkAddressUtils
Replaces and resolves the hostname in a given address or path string.
report() - Method in class alluxio.metrics.sink.ConsoleSink
 
report() - Method in class alluxio.metrics.sink.CsvSink
 
report() - Method in class alluxio.metrics.sink.GraphiteSink
 
report() - Method in class alluxio.metrics.sink.JmxSink
 
report() - Method in class alluxio.metrics.sink.MetricsServlet
 
report() - Method in class alluxio.metrics.sink.PrometheusMetricsServlet
 
report() - Method in interface alluxio.metrics.sink.Sink
Reports the current values of all metrics.
REPORT_LOST_FILE - Static variable in class alluxio.master.lineage.LineageMasterClientRestServiceHandler
Deprecated.
 
ReportCommand - Class in alluxio.cli.fs.command
Reports to the master that a file is lost.
ReportCommand(FileSystem) - Constructor for class alluxio.cli.fs.command.ReportCommand
 
ReportCommand - Class in alluxio.cli.fsadmin.command
Reports Alluxio running cluster information.
ReportCommand(Context) - Constructor for class alluxio.cli.fsadmin.command.ReportCommand
 
reportLostBlocks(List<Long>) - Method in interface alluxio.master.block.BlockMaster
Reports the ids of the blocks lost on workers.
reportLostBlocks(List<Long>) - Method in class alluxio.master.block.DefaultBlockMaster
 
reportLostFile(AlluxioURI) - Method in class alluxio.client.lineage.LineageFileSystem
Reports a file as lost.
reportLostFile(String) - Method in class alluxio.client.lineage.LineageMasterClient
Reports a file as lost.
reportLostFile(long) - Method in class alluxio.master.file.DefaultFileSystemMaster
 
reportLostFile(long) - Method in interface alluxio.master.file.FileSystemMaster
Reports a file as lost.
reportLostFile(String) - Method in class alluxio.master.lineage.DefaultLineageMaster
 
reportLostFile(String) - Method in interface alluxio.master.lineage.LineageMaster
Reports a file as lost.
reportLostFile(String) - Method in class alluxio.master.lineage.LineageMasterClientRestServiceHandler
Deprecated.
 
reportLostFile(String, ReportLostFileTOptions) - Method in class alluxio.master.lineage.LineageMasterClientServiceHandler
 
reportLostFile(String, ReportLostFileTOptions, AsyncMethodCallback) - Method in class alluxio.thrift.LineageMasterClientService.AsyncClient
 
reportLostFile(String, ReportLostFileTOptions, AsyncMethodCallback) - Method in interface alluxio.thrift.LineageMasterClientService.AsyncIface
 
reportLostFile() - Constructor for class alluxio.thrift.LineageMasterClientService.AsyncProcessor.reportLostFile
 
reportLostFile(String, ReportLostFileTOptions) - Method in class alluxio.thrift.LineageMasterClientService.Client
 
reportLostFile(String, ReportLostFileTOptions) - Method in interface alluxio.thrift.LineageMasterClientService.Iface
Reports file as lost.
reportLostFile() - Constructor for class alluxio.thrift.LineageMasterClientService.Processor.reportLostFile
 
reportLostFile_args() - Constructor for class alluxio.thrift.LineageMasterClientService.reportLostFile_args
 
reportLostFile_args(String, ReportLostFileTOptions) - Constructor for class alluxio.thrift.LineageMasterClientService.reportLostFile_args
 
reportLostFile_args(LineageMasterClientService.reportLostFile_args) - Constructor for class alluxio.thrift.LineageMasterClientService.reportLostFile_args
Performs a deep copy on other.
reportLostFile_call(String, ReportLostFileTOptions, AsyncMethodCallback, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class alluxio.thrift.LineageMasterClientService.AsyncClient.reportLostFile_call
 
reportLostFile_result() - Constructor for class alluxio.thrift.LineageMasterClientService.reportLostFile_result
 
reportLostFile_result(ReportLostFileTResponse, AlluxioTException) - Constructor for class alluxio.thrift.LineageMasterClientService.reportLostFile_result
 
reportLostFile_result(LineageMasterClientService.reportLostFile_result) - Constructor for class alluxio.thrift.LineageMasterClientService.reportLostFile_result
Performs a deep copy on other.
ReportLostFileTOptions - Class in alluxio.thrift
 
ReportLostFileTOptions() - Constructor for class alluxio.thrift.ReportLostFileTOptions
 
ReportLostFileTOptions(ReportLostFileTOptions) - Constructor for class alluxio.thrift.ReportLostFileTOptions
Performs a deep copy on other.
ReportLostFileTOptions._Fields - Enum in alluxio.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
ReportLostFileTResponse - Class in alluxio.thrift
 
ReportLostFileTResponse() - Constructor for class alluxio.thrift.ReportLostFileTResponse
 
ReportLostFileTResponse(ReportLostFileTResponse) - Constructor for class alluxio.thrift.ReportLostFileTResponse
Performs a deep copy on other.
ReportLostFileTResponse._Fields - Enum in alluxio.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
requestBlockLocation(long, long, long, int, RequestBlockLocationTOptions, AsyncMethodCallback) - Method in class alluxio.thrift.BlockWorkerClientService.AsyncClient
 
requestBlockLocation(long, long, long, int, RequestBlockLocationTOptions, AsyncMethodCallback) - Method in interface alluxio.thrift.BlockWorkerClientService.AsyncIface
 
requestBlockLocation() - Constructor for class alluxio.thrift.BlockWorkerClientService.AsyncProcessor.requestBlockLocation
 
requestBlockLocation(long, long, long, int, RequestBlockLocationTOptions) - Method in class alluxio.thrift.BlockWorkerClientService.Client
 
requestBlockLocation(long, long, long, int, RequestBlockLocationTOptions) - Method in interface alluxio.thrift.BlockWorkerClientService.Iface
Used to allocate location and space for a new coming block, worker will choose the appropriate storage directory which fits the initial block size by some allocation strategy, and the temporary file path of the block file will be returned.
requestBlockLocation() - Constructor for class alluxio.thrift.BlockWorkerClientService.Processor.requestBlockLocation
 
requestBlockLocation(long, long, long, int, RequestBlockLocationTOptions) - Method in class alluxio.worker.block.BlockWorkerClientServiceHandler
 
requestBlockLocation_args() - Constructor for class alluxio.thrift.BlockWorkerClientService.requestBlockLocation_args
 
requestBlockLocation_args(long, long, long, int, RequestBlockLocationTOptions) - Constructor for class alluxio.thrift.BlockWorkerClientService.requestBlockLocation_args
 
requestBlockLocation_args(BlockWorkerClientService.requestBlockLocation_args) - Constructor for class alluxio.thrift.BlockWorkerClientService.requestBlockLocation_args
Performs a deep copy on other.
requestBlockLocation_call(long, long, long, int, RequestBlockLocationTOptions, AsyncMethodCallback, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class alluxio.thrift.BlockWorkerClientService.AsyncClient.requestBlockLocation_call
 
requestBlockLocation_result() - Constructor for class alluxio.thrift.BlockWorkerClientService.requestBlockLocation_result
 
requestBlockLocation_result(RequestBlockLocationTResponse, AlluxioTException) - Constructor for class alluxio.thrift.BlockWorkerClientService.requestBlockLocation_result
 
requestBlockLocation_result(BlockWorkerClientService.requestBlockLocation_result) - Constructor for class alluxio.thrift.BlockWorkerClientService.requestBlockLocation_result
Performs a deep copy on other.
RequestBlockLocationTOptions - Class in alluxio.thrift
 
RequestBlockLocationTOptions() - Constructor for class alluxio.thrift.RequestBlockLocationTOptions
 
RequestBlockLocationTOptions(RequestBlockLocationTOptions) - Constructor for class alluxio.thrift.RequestBlockLocationTOptions
Performs a deep copy on other.
RequestBlockLocationTOptions._Fields - Enum in alluxio.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
RequestBlockLocationTResponse - Class in alluxio.thrift
 
RequestBlockLocationTResponse() - Constructor for class alluxio.thrift.RequestBlockLocationTResponse
 
RequestBlockLocationTResponse(String) - Constructor for class alluxio.thrift.RequestBlockLocationTResponse
 
RequestBlockLocationTResponse(RequestBlockLocationTResponse) - Constructor for class alluxio.thrift.RequestBlockLocationTResponse
Performs a deep copy on other.
RequestBlockLocationTResponse._Fields - Enum in alluxio.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
requestSpace(long, long, long, RequestSpaceTOptions, AsyncMethodCallback) - Method in class alluxio.thrift.BlockWorkerClientService.AsyncClient
 
requestSpace(long, long, long, RequestSpaceTOptions, AsyncMethodCallback) - Method in interface alluxio.thrift.BlockWorkerClientService.AsyncIface
 
requestSpace() - Constructor for class alluxio.thrift.BlockWorkerClientService.AsyncProcessor.requestSpace
 
requestSpace(long, long, long, RequestSpaceTOptions) - Method in class alluxio.thrift.BlockWorkerClientService.Client
 
requestSpace(long, long, long, RequestSpaceTOptions) - Method in interface alluxio.thrift.BlockWorkerClientService.Iface
Used to request space for some block file.
requestSpace() - Constructor for class alluxio.thrift.BlockWorkerClientService.Processor.requestSpace
 
requestSpace(long, long, long) - Method in interface alluxio.worker.block.BlockStore
Requests to increase the size of a temp block.
requestSpace(long, long, long) - Method in interface alluxio.worker.block.BlockWorker
Request an amount of space for a block in its storage directory.
requestSpace(long, long, long, RequestSpaceTOptions) - Method in class alluxio.worker.block.BlockWorkerClientServiceHandler
 
requestSpace(long, long, long) - Method in class alluxio.worker.block.DefaultBlockWorker
 
requestSpace(long, long, long) - Method in class alluxio.worker.block.TieredBlockStore
 
requestSpace_args() - Constructor for class alluxio.thrift.BlockWorkerClientService.requestSpace_args
 
requestSpace_args(long, long, long, RequestSpaceTOptions) - Constructor for class alluxio.thrift.BlockWorkerClientService.requestSpace_args
 
requestSpace_args(BlockWorkerClientService.requestSpace_args) - Constructor for class alluxio.thrift.BlockWorkerClientService.requestSpace_args
Performs a deep copy on other.
requestSpace_call(long, long, long, RequestSpaceTOptions, AsyncMethodCallback, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class alluxio.thrift.BlockWorkerClientService.AsyncClient.requestSpace_call
 
requestSpace_result() - Constructor for class alluxio.thrift.BlockWorkerClientService.requestSpace_result
 
requestSpace_result(RequestSpaceTResponse, AlluxioTException) - Constructor for class alluxio.thrift.BlockWorkerClientService.requestSpace_result
 
requestSpace_result(BlockWorkerClientService.requestSpace_result) - Constructor for class alluxio.thrift.BlockWorkerClientService.requestSpace_result
Performs a deep copy on other.
RequestSpaceTOptions - Class in alluxio.thrift
 
RequestSpaceTOptions() - Constructor for class alluxio.thrift.RequestSpaceTOptions
 
RequestSpaceTOptions(RequestSpaceTOptions) - Constructor for class alluxio.thrift.RequestSpaceTOptions
Performs a deep copy on other.
RequestSpaceTOptions._Fields - Enum in alluxio.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
RequestSpaceTResponse - Class in alluxio.thrift
 
RequestSpaceTResponse() - Constructor for class alluxio.thrift.RequestSpaceTResponse
 
RequestSpaceTResponse(boolean) - Constructor for class alluxio.thrift.RequestSpaceTResponse
 
RequestSpaceTResponse(RequestSpaceTResponse) - Constructor for class alluxio.thrift.RequestSpaceTResponse
Performs a deep copy on other.
RequestSpaceTResponse._Fields - Enum in alluxio.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
reset(InstancedConfiguration) - Method in class alluxio.client.file.FileSystemContext
Resets the context.
reset() - Method in enum alluxio.client.lineage.LineageContext
Re-initializes the LineageContext.
reset() - Static method in class alluxio.Configuration
Resets Configuration back to the default one.
reset() - Method in class alluxio.extensions.ExtensionFactoryRegistry
Resets the registry to its default state
reset() - Method in class alluxio.master.AbstractLocalAlluxioCluster
Resets the cluster to original state.
reset() - Method in class alluxio.master.file.meta.InodeFile
Resets the file inode.
reset() - Method in class alluxio.master.file.meta.InodeTree
Resets the inode tree.
reset() - Method in class alluxio.master.meta.checkconf.ServerConfigurationStore
Resets the default ServerConfigurationStore.
reset() - Method in class alluxio.retry.CountingRetry
Reset the count of retries.
reset() - Static method in class alluxio.underfs.UnderFileSystemFactoryRegistry
Resets the registry to its default state
reset() - Method in class alluxio.util.JvmPauseMonitor
Resets value of mJvmMonitorThread.
resetAllCounters() - Static method in class alluxio.metrics.MetricsSystem
Resets all the counters to 0 for testing.
resetClientPools() - Method in class alluxio.master.AbstractLocalAlluxioCluster
Resets the client pools to the original state.
resetFile(long) - Method in class alluxio.master.file.DefaultFileSystemMaster
 
resetFile(long) - Method in interface alluxio.master.file.FileSystemMaster
Resets a file.
resetState() - Method in class alluxio.master.block.DefaultBlockMaster
 
resetState() - Method in class alluxio.master.file.DefaultFileSystemMaster
 
resetState() - Method in interface alluxio.master.journal.JournalEntryStateMachine
Resets the journaled internal state of the state machine.
resetState() - Method in class alluxio.master.keyvalue.DefaultKeyValueMaster
 
resetState() - Method in class alluxio.master.lineage.DefaultLineageMaster
 
resetState() - Method in class alluxio.master.meta.DefaultMetaMaster
 
resetState() - Method in class alluxio.master.metrics.DefaultMetricsMaster
 
resetState() - Method in class alluxio.master.NoopMaster
 
resizeTempBlockMeta(TempBlockMeta, long) - Method in class alluxio.worker.block.BlockMetadataManager
Modifies the size of a temp block.
resizeTempBlockMeta(TempBlockMeta, long) - Method in class alluxio.worker.block.meta.StorageDir
Changes the size of a temp block.
resolve(AlluxioURI) - Method in class alluxio.master.file.meta.MountTable
Resolves the given Alluxio path.
resolveHostName(String) - Static method in class alluxio.util.network.NetworkAddressUtils
Resolves a given hostname by a canonical hostname.
resolveIpAddress(String) - Static method in class alluxio.util.network.NetworkAddressUtils
Resolves a given hostname IP address.
resolveUri(AlluxioURI, String) - Method in class alluxio.underfs.BaseUnderFileSystem
 
resolveUri(AlluxioURI, String) - Method in interface alluxio.underfs.UnderFileSystem
Returns an AlluxioURI representation for the UnderFileSystem given a base UFS URI, and the Alluxio path from the base.
resolveUri(AlluxioURI, String) - Method in class alluxio.underfs.UnderFileSystemWithLogging
 
RESOURCE_EXHAUSTED_VALUE - Static variable in enum alluxio.proto.status.Status.PStatus
RESOURCE_EXHAUSTED = 8;
ResourceExhaustedException - Exception in alluxio.exception.status
Exception indicating that some resource has been exhausted, perhaps a per-user quota, or perhaps the entire file system is out of space.
ResourceExhaustedException(String) - Constructor for exception alluxio.exception.status.ResourceExhaustedException
 
ResourceExhaustedException(Throwable) - Constructor for exception alluxio.exception.status.ResourceExhaustedException
 
ResourceExhaustedException(String, Throwable) - Constructor for exception alluxio.exception.status.ResourceExhaustedException
 
ResourceInternal(R) - Constructor for class alluxio.resource.DynamicResourcePool.ResourceInternal
ResourcePool<T> - Class in alluxio.resource
Class representing a pool of resources to be temporarily used and returned.
ResourcePool(int) - Constructor for class alluxio.resource.ResourcePool
Creates a ResourcePool instance with the specified capacity.
ResourcePool(int, ConcurrentLinkedQueue<T>) - Constructor for class alluxio.resource.ResourcePool
Internal constructor that can provide an object to be used for the internal queue.
REST_API_PREFIX - Static variable in class alluxio.Constants
 
restartMasters() - Method in class alluxio.master.AbstractLocalAlluxioCluster
Restarts the master(s).
restartZk() - Method in class alluxio.master.MultiMasterLocalAlluxioCluster
Restarts the cluster's Zookeeper service.
restartZk() - Method in class alluxio.multi.process.MultiProcessCluster
Restarts the Zookeeper cluster.
RestUtils - Class in alluxio
Utilities for handling REST calls.
RestUtils.ErrorResponse - Class in alluxio
Error response when RestUtils.RestCallable.call() throws an exception.
RestUtils.RestCallable<T> - Interface in alluxio
An interface representing a callable.
retainAll(Collection<?>) - Method in class alluxio.collections.ConcurrentHashSet
 
retry(String, RetryUtils.RunnableThrowsIOException, RetryPolicy) - Static method in class alluxio.retry.RetryUtils
Retries the given method until it doesn't throw an IO exception or the retry policy expires.
RetryHandlingBlockMasterClient - Class in alluxio.client.block
A wrapper for the thrift client to interact with the block master, used by alluxio clients.
RetryHandlingBlockMasterClient(MasterClientConfig) - Constructor for class alluxio.client.block.RetryHandlingBlockMasterClient
Creates a new block master client.
RetryHandlingFileSystemMasterClient - Class in alluxio.client.file
A wrapper for the thrift client to interact with the file system master, used by alluxio clients.
RetryHandlingFileSystemMasterClient(MasterClientConfig) - Constructor for class alluxio.client.file.RetryHandlingFileSystemMasterClient
Creates a new RetryHandlingFileSystemMasterClient instance.
RetryHandlingMetaMasterClient - Class in alluxio.client
A wrapper for the thrift client to interact with the meta master.
RetryHandlingMetaMasterClient(MasterClientConfig) - Constructor for class alluxio.client.RetryHandlingMetaMasterClient
Creates a new meta master client.
RetryHandlingMetaMasterMasterClient - Class in alluxio.master.meta
A wrapper for the thrift client to interact with the primary meta master, used by Alluxio standby masters.
RetryHandlingMetaMasterMasterClient(MasterClientConfig) - Constructor for class alluxio.master.meta.RetryHandlingMetaMasterMasterClient
RetryPolicy - Interface in alluxio.retry
Policy for determining whether retries should be performed, and potentially waiting for some time before the next retry attempt.
retryRPC(AbstractClient.RpcCallable<V>) - Method in class alluxio.AbstractClient
Tries to execute an RPC defined as a AbstractClient.RpcCallable.
retryRPC(AbstractClient.RpcCallable<V>, String) - Method in class alluxio.AbstractClient
Tries to execute an RPC defined as a AbstractClient.RpcCallable.
RetryUtils - Class in alluxio.retry
Utilities for performing retries.
RetryUtils.RunnableThrowsIOException - Interface in alluxio.retry
Interface for methods which return nothing and may throw IOException.
RmCommand - Class in alluxio.cli.fs.command
Removes the file specified by argv.
RmCommand(FileSystem) - Constructor for class alluxio.cli.fs.command.RmCommand
 
ROOT - Static variable in class alluxio.master.file.meta.MountTable
 
ROOT_MOUNT_ID - Static variable in class alluxio.util.IdUtils
 
RoundRobinAllocator - Class in alluxio.worker.block.allocator
A round-robin allocator that allocates a block in the storage dir.
RoundRobinAllocator(BlockMetadataManagerView) - Constructor for class alluxio.worker.block.allocator.RoundRobinAllocator
Creates a new instance of RoundRobinAllocator.
RoundRobinPolicy - Class in alluxio.client.file.policy
A policy that chooses the worker for the next block in a round-robin manner and skips workers that do not have enough space.
RoundRobinPolicy() - Constructor for class alluxio.client.file.policy.RoundRobinPolicy
Constructs a new RoundRobinPolicy.
RpcContext - Class in alluxio.master.file
Context passed through the span of a file system master RPC to manage actions that need to be taken when the body of the RPC is finished.
RpcContext(BlockDeletionContext, JournalContext) - Constructor for class alluxio.master.file.RpcContext
Creates an RpcContext.
RPCHandler(Promise<ProtoMessage>) - Constructor for class alluxio.network.netty.NettyRPC.RPCHandler
Creates an instance of NettyRPC.RPCHandler.
RPCMessage - Class in alluxio.network.protocol
This is the main base class for all RPC messages to the DataServer.
RPCMessage() - Constructor for class alluxio.network.protocol.RPCMessage
 
RPCMessage.Type - Enum in alluxio.network.protocol
The possible types of RPC messages.
RPCMessageDecoder - Class in alluxio.network.protocol
Simple Netty decoder which converts the input ByteBuf into an RPCMessage.
RPCMessageDecoder() - Constructor for class alluxio.network.protocol.RPCMessageDecoder
Constructs a new RPCMessageDecoder.
RPCMessageEncoder - Class in alluxio.network.protocol
Simple Netty encoder for RPCMessages.
RPCMessageEncoder() - Constructor for class alluxio.network.protocol.RPCMessageEncoder
Constructs a new RPCMessageEncoder.
RPCProtoMessage - Class in alluxio.network.protocol
This is the main base class for all protocol buffer based RPC messages to the DataServer.
RPCProtoMessage(ProtoMessage, DataBuffer) - Constructor for class alluxio.network.protocol.RPCProtoMessage
Creates an instance of RPCProtoMessage.
RPCProtoMessage(ProtoMessage) - Constructor for class alluxio.network.protocol.RPCProtoMessage
Creates an instance of RPCProtoMessage without data part.
RPCProtoMessage(byte[], ProtoMessage, DataBuffer) - Constructor for class alluxio.network.protocol.RPCProtoMessage
Creates an instance of RPCProtoMessage from a serialized proto message.
RpcUtils - Class in alluxio
Utilities for handling server RPC calls.
RpcUtils.NettyRpcCallable<T> - Interface in alluxio
An interface representing a netty RPC callable.
RpcUtils.RpcCallable<T> - Interface in alluxio
An interface representing a callable which can only throw Alluxio exceptions.
RpcUtils.RpcCallableThrowsIOException<T> - Interface in alluxio
An interface representing a callable which can only throw Alluxio or IO exceptions.
run(String...) - Method in class alluxio.cli.AbstractShell
Handles the specified shell command request, displaying usage if the command format is invalid.
run(CommandLine) - Method in interface alluxio.cli.Command
Runs the command.
run(CommandLine) - Method in class alluxio.cli.extensions.command.InstallCommand
 
run(CommandLine) - Method in class alluxio.cli.extensions.command.LsCommand
 
run(CommandLine) - Method in class alluxio.cli.extensions.command.UninstallCommand
 
run(CommandLine) - Method in class alluxio.cli.fs.command.CatCommand
 
run(CommandLine) - Method in class alluxio.cli.fs.command.CheckConsistencyCommand
 
run(CommandLine) - Method in class alluxio.cli.fs.command.ChecksumCommand
 
run(CommandLine) - Method in class alluxio.cli.fs.command.ChgrpCommand
 
run(CommandLine) - Method in class alluxio.cli.fs.command.ChmodCommand
 
run(CommandLine) - Method in class alluxio.cli.fs.command.ChownCommand
 
run(CommandLine) - Method in class alluxio.cli.fs.command.CopyFromLocalCommand
 
run(CommandLine) - Method in class alluxio.cli.fs.command.CopyToLocalCommand
 
run(CommandLine) - Method in class alluxio.cli.fs.command.CountCommand
 
run(CommandLine) - Method in class alluxio.cli.fs.command.CpCommand
 
run(CommandLine) - Method in class alluxio.cli.fs.command.CreateLineageCommand
 
run(CommandLine) - Method in class alluxio.cli.fs.command.DeleteLineageCommand
 
run(CommandLine) - Method in class alluxio.cli.fs.command.DuCommand
 
run(CommandLine) - Method in class alluxio.cli.fs.command.FileInfoCommand
Deprecated.
 
run(CommandLine) - Method in class alluxio.cli.fs.command.FreeCommand
 
run(CommandLine) - Method in class alluxio.cli.fs.command.GetCapacityBytesCommand
 
run(CommandLine) - Method in class alluxio.cli.fs.command.GetUsedBytesCommand
 
run(CommandLine) - Method in class alluxio.cli.fs.command.HeadCommand
 
run(CommandLine) - Method in class alluxio.cli.fs.command.HelpCommand
 
run(CommandLine) - Method in class alluxio.cli.fs.command.LeaderCommand
 
run(CommandLine) - Method in class alluxio.cli.fs.command.ListLineagesCommand
 
run(CommandLine) - Method in class alluxio.cli.fs.command.LoadCommand
 
run(CommandLine) - Method in class alluxio.cli.fs.command.LoadMetadataCommand
Deprecated.
 
run(CommandLine) - Method in class alluxio.cli.fs.command.LocationCommand
 
run(CommandLine) - Method in class alluxio.cli.fs.command.LsCommand
 
run(CommandLine) - Method in class alluxio.cli.fs.command.MasterInfoCommand
 
run(CommandLine) - Method in class alluxio.cli.fs.command.MkdirCommand
 
run(CommandLine) - Method in class alluxio.cli.fs.command.MountCommand
 
run(CommandLine) - Method in class alluxio.cli.fs.command.MvCommand
 
run(CommandLine) - Method in class alluxio.cli.fs.command.PersistCommand
 
run(CommandLine) - Method in class alluxio.cli.fs.command.PinCommand
 
run(CommandLine) - Method in class alluxio.cli.fs.command.ReportCommand
 
run(CommandLine) - Method in class alluxio.cli.fs.command.RmCommand
 
run(CommandLine) - Method in class alluxio.cli.fs.command.SetTtlCommand
 
run(CommandLine) - Method in class alluxio.cli.fs.command.StatCommand
 
run(CommandLine) - Method in class alluxio.cli.fs.command.TailCommand
 
run(CommandLine) - Method in class alluxio.cli.fs.command.TestCommand
 
run(CommandLine) - Method in class alluxio.cli.fs.command.TouchCommand
 
run(CommandLine) - Method in class alluxio.cli.fs.command.UnmountCommand
 
run(CommandLine) - Method in class alluxio.cli.fs.command.UnpinCommand
 
run(CommandLine) - Method in class alluxio.cli.fs.command.UnsetTtlCommand
 
run(CommandLine) - Method in class alluxio.cli.fsadmin.command.BackupCommand
 
run(CommandLine) - Method in class alluxio.cli.fsadmin.command.DoctorCommand
 
run(CommandLine) - Method in class alluxio.cli.fsadmin.command.GetBlockInfoCommand
 
run(CommandLine) - Method in class alluxio.cli.fsadmin.command.ReportCommand
 
run(CommandLine) - Method in class alluxio.cli.fsadmin.command.UfsCommand
 
run() - Method in class alluxio.cli.fsadmin.doctor.ConfigurationCommand
Runs doctor configuration command.
run(CommandLine) - Method in class alluxio.cli.fsadmin.report.CapacityCommand
Runs report capacity command.
run() - Method in class alluxio.cli.fsadmin.report.MetricsCommand
Runs report metrics command.
run() - Method in class alluxio.cli.fsadmin.report.SummaryCommand
Runs report summary command.
run() - Method in class alluxio.cli.fsadmin.report.UfsCommand
Runs report ufs command.
run(String[]) - Method in class alluxio.cli.RunOperation
 
run() - Method in class alluxio.examples.Performance.AlluxioReadWorker
 
run() - Method in class alluxio.examples.Performance.AlluxioWriterWorker
 
run() - Method in class alluxio.examples.Performance.GeneralWorker
 
run() - Method in class alluxio.examples.Performance.HdfsWorker
 
run() - Method in class alluxio.heartbeat.HeartbeatThread
 
run() - Method in class alluxio.job.CommandLineJob
 
run() - Method in class alluxio.job.Job
Runs the job.
run() - Method in class alluxio.logserver.AlluxioLog4jSocketNode
 
run() - Method in class alluxio.master.journal.ufs.UfsJournalCheckpointThread
 
run() - Method in class alluxio.master.MasterHealthCheckClient.MasterServingCheckRunnable
 
run() - Method in class alluxio.master.MasterHealthCheckClient.ProcessCheckRunnable
 
run(Process) - Static method in class alluxio.ProcessUtils
Runs the given Process.
run() - Method in interface alluxio.retry.RetryUtils.RunnableThrowsIOException
Runs the runnable.
run() - Method in class alluxio.worker.SessionCleaner
Main loop for the cleanup, continuously looks for zombie sessions.
runExample(Callable<Boolean>) - Static method in class alluxio.cli.CliUtils
Runs an example.
runNextPendingCommand() - Method in class alluxio.util.executor.ControllableScheduler
Runs the next command scheduled to be executed immediately.
running() - Static method in class alluxio.master.file.StartupConsistencyCheck
 
RunOperation - Class in alluxio.cli
Class for running an operation multiple times.
RunOperation() - Constructor for class alluxio.cli.RunOperation
Constructs a new RunOperation object.
runPlainPath(AlluxioURI, CommandLine) - Method in class alluxio.cli.fs.command.AbstractFileSystemCommand
Run the command for a particular URI that does not contain wildcard in its path.
runPlainPath(AlluxioURI, CommandLine) - Method in class alluxio.cli.fs.command.CatCommand
 
runPlainPath(AlluxioURI, CommandLine) - Method in class alluxio.cli.fs.command.CheckConsistencyCommand
 
runPlainPath(AlluxioURI, CommandLine) - Method in class alluxio.cli.fs.command.ChecksumCommand
 
runPlainPath(AlluxioURI, CommandLine) - Method in class alluxio.cli.fs.command.ChgrpCommand
 
runPlainPath(AlluxioURI, CommandLine) - Method in class alluxio.cli.fs.command.ChmodCommand
 
runPlainPath(AlluxioURI, CommandLine) - Method in class alluxio.cli.fs.command.ChownCommand
 
runPlainPath(AlluxioURI, CommandLine) - Method in class alluxio.cli.fs.command.DuCommand
 
runPlainPath(AlluxioURI, CommandLine) - Method in class alluxio.cli.fs.command.FreeCommand
 
runPlainPath(AlluxioURI, CommandLine) - Method in class alluxio.cli.fs.command.HeadCommand
 
runPlainPath(AlluxioURI, CommandLine) - Method in class alluxio.cli.fs.command.LoadCommand
 
runPlainPath(AlluxioURI, CommandLine) - Method in class alluxio.cli.fs.command.LocationCommand
 
runPlainPath(AlluxioURI, CommandLine) - Method in class alluxio.cli.fs.command.LsCommand
 
runPlainPath(AlluxioURI, CommandLine) - Method in class alluxio.cli.fs.command.PersistCommand
 
runPlainPath(AlluxioURI, CommandLine) - Method in class alluxio.cli.fs.command.PinCommand
 
runPlainPath(AlluxioURI, CommandLine) - Method in class alluxio.cli.fs.command.ReportCommand
 
runPlainPath(AlluxioURI, CommandLine) - Method in class alluxio.cli.fs.command.RmCommand
 
runPlainPath(AlluxioURI, CommandLine) - Method in class alluxio.cli.fs.command.SetTtlCommand
 
runPlainPath(AlluxioURI, CommandLine) - Method in class alluxio.cli.fs.command.StatCommand
 
runPlainPath(AlluxioURI, CommandLine) - Method in class alluxio.cli.fs.command.TailCommand
 
runPlainPath(AlluxioURI, CommandLine) - Method in class alluxio.cli.fs.command.TouchCommand
 
runPlainPath(AlluxioURI, CommandLine) - Method in class alluxio.cli.fs.command.UnmountCommand
 
runPlainPath(AlluxioURI, CommandLine) - Method in class alluxio.cli.fs.command.UnpinCommand
 
runPlainPath(AlluxioURI, CommandLine) - Method in class alluxio.cli.fs.command.UnsetTtlCommand
 
RUNTIME - Static variable in class alluxio.conf.Source
 
RuntimeConstants - Class in alluxio
System constants that are determined during runtime.
runWildCardCmd(AlluxioURI, CommandLine) - Method in class alluxio.cli.fs.command.AbstractFileSystemCommand
Run the command for a particular URI that may contain wildcard in its path.

S

S3_CONTENT_LENGTH_HEADER - Static variable in class alluxio.proxy.s3.S3Constants
 
S3_DATE_FORMAT_REGEXP - Static variable in class alluxio.proxy.s3.S3Constants
 
S3_DEFAULT_MAX_KEYS - Static variable in class alluxio.proxy.s3.S3Constants
 
S3_DELETE_IN_ALLUXIO_AND_UFS - Static variable in class alluxio.Constants
 
S3_DELETE_IN_ALLUXIO_ONLY - Static variable in class alluxio.Constants
 
S3_EMPTY_ETAG - Static variable in class alluxio.proxy.s3.S3Constants
 
S3_MULTIPART_TEMPORARY_DIR_SUFFIX - Static variable in class alluxio.Constants
 
S3_STANDARD_STORAGE_CLASS - Static variable in class alluxio.proxy.s3.S3Constants
 
S3A_ACCESS_KEY - Static variable in class alluxio.PropertyKey.Name
 
S3A_ACCESS_KEY - Static variable in class alluxio.PropertyKey
 
S3A_SECRET_KEY - Static variable in class alluxio.PropertyKey.Name
 
S3A_SECRET_KEY - Static variable in class alluxio.PropertyKey
 
S3AInputStream - Class in alluxio.underfs.s3a
A wrapper around an S3ObjectInputStream which handles skips efficiently.
S3AInputStream(String, String, AmazonS3) - Constructor for class alluxio.underfs.s3a.S3AInputStream
Constructor for an input stream of an object in s3 using the aws-sdk implementation to read the data.
S3AInputStream(String, String, AmazonS3, long) - Constructor for class alluxio.underfs.s3a.S3AInputStream
Constructor for an input stream of an object in s3 using the aws-sdk implementation to read the data.
S3AOutputStream - Class in alluxio.underfs.s3a
A stream for writing a file into S3.
S3AOutputStream(String, String, TransferManager) - Constructor for class alluxio.underfs.s3a.S3AOutputStream
Constructs a new stream for writing a file.
S3AUnderFileSystem - Class in alluxio.underfs.s3a
S3 UnderFileSystem implementation based on the aws-java-sdk-s3 library.
S3AUnderFileSystem(AlluxioURI, AmazonS3Client, String, TransferManager, UnderFileSystemConfiguration) - Constructor for class alluxio.underfs.s3a.S3AUnderFileSystem
Constructor for S3AUnderFileSystem.
S3AUnderFileSystemFactory - Class in alluxio.underfs.s3a
Factory for creating S3AUnderFileSystem.
S3AUnderFileSystemFactory() - Constructor for class alluxio.underfs.s3a.S3AUnderFileSystemFactory
Constructs a new S3AUnderFileSystemFactory.
S3AUtils - Class in alluxio.underfs.s3a
Util functions for S3A under file system.
S3Constants - Class in alluxio.proxy.s3
Constants for S3 northbound API.
S3Error - Class in alluxio.proxy.s3
Error response defined in http://docs.aws.amazon.com/AmazonS3/latest/API/ErrorResponses.html.
S3Error() - Constructor for class alluxio.proxy.s3.S3Error
Creates an S3Error.
S3Error(String, S3ErrorCode) - Constructor for class alluxio.proxy.s3.S3Error
Creates a new Error.
S3ErrorCode - Class in alluxio.proxy.s3
Error codes defined in http://docs.aws.amazon.com/AmazonS3/latest/API/ErrorResponses.html with API version 2006-03-01.
S3ErrorCode(String, String, Response.Status) - Constructor for class alluxio.proxy.s3.S3ErrorCode
Constructs a new S3ErrorCode.
S3ErrorCode.Name - Class in alluxio.proxy.s3
Error code names used in S3ErrorCode.
S3Exception - Exception in alluxio.proxy.s3
An exception thrown during processing S3 REST requests.
S3Exception(String, S3ErrorCode) - Constructor for exception alluxio.proxy.s3.S3Exception
Constructs a new S3Exception.
S3Exception(Exception, String, S3ErrorCode) - Constructor for exception alluxio.proxy.s3.S3Exception
Derives a new S3Exception from an existing exception.
S3RestServiceHandler - Class in alluxio.proxy.s3
This class is a REST handler for Amazon S3 API.
S3RestServiceHandler(ServletContext) - Constructor for class alluxio.proxy.s3.S3RestServiceHandler
Constructs a new S3RestServiceHandler.
S3RestUtils - Class in alluxio.proxy.s3
Utilities for handling S3 REST calls.
S3RestUtils.RestCallable<T> - Interface in alluxio.proxy.s3
An interface representing a callable.
SafeModeManager - Interface in alluxio.master
Interface for managing safe mode state.
SafeUfsDeleter - Class in alluxio.master.file
Helper class for deleting persisted entries from the UFS.
SafeUfsDeleter(MountTable, List<Pair<AlluxioURI, LockedInodePath>>, DeleteOptions) - Constructor for class alluxio.master.file.SafeUfsDeleter
Creates a new instance of SafeUfsDeleter.
SameKeyValueStoresTest - Class in alluxio.examples.keyvalue
Tests whether two key-value stores contain the same set of key-value pairs.
SameKeyValueStoresTest(AlluxioURI, AlluxioURI) - Constructor for class alluxio.examples.keyvalue.SameKeyValueStoresTest
 
SamplingLogger - Class in alluxio.util.logging
A logger which limits log message frequency to prevent spamming the logs.
SamplingLogger(Logger, long) - Constructor for class alluxio.util.logging.SamplingLogger
 
saveWorkdir() - Method in class alluxio.multi.process.MultiProcessCluster
Copies the work directory to the artifacts folder.
schedule(String) - Static method in class alluxio.heartbeat.HeartbeatScheduler
Schedules execution of a heartbeat for the given thread.
schedule() - Method in class alluxio.heartbeat.ScheduledTimer
Schedules execution of the heartbeat.
schedule(Runnable, long, TimeUnit) - Method in class alluxio.util.executor.ControllableScheduler
 
schedule(Callable<V>, long, TimeUnit) - Method in class alluxio.util.executor.ControllableScheduler
 
SCHEDULE_ASYNC_PERSIST - Static variable in class alluxio.master.file.FileSystemMasterClientRestServiceHandler
Deprecated.
 
scheduleAsyncPersist() - Method in class alluxio.client.file.FileOutStream
Schedules the async persistence of the current file.
scheduleAsyncPersist(AlluxioURI) - Method in interface alluxio.client.file.FileSystemMasterClient
Schedules the async persistence of the given file.
scheduleAsyncPersist(AlluxioURI) - Method in class alluxio.client.file.RetryHandlingFileSystemMasterClient
 
scheduleAsyncPersist() - Method in class alluxio.client.lineage.LineageFileOutStream
 
scheduleAsyncPersist(String) - Method in class alluxio.master.file.FileSystemMasterClientRestServiceHandler
Deprecated.
 
scheduleAsyncPersistence(AlluxioURI) - Method in interface alluxio.master.file.async.AsyncPersistHandler
Schedules a file for async persistence.
scheduleAsyncPersistence(AlluxioURI) - Method in class alluxio.master.file.async.DefaultAsyncPersistHandler
 
scheduleAsyncPersistence(AlluxioURI) - Method in class alluxio.master.file.DefaultFileSystemMaster
 
scheduleAsyncPersistence(AlluxioURI) - Method in interface alluxio.master.file.FileSystemMaster
Schedules a file for async persistence.
scheduleAsyncPersistence(String, ScheduleAsyncPersistenceTOptions) - Method in class alluxio.master.file.FileSystemMasterClientServiceHandler
 
scheduleAsyncPersistence(String, ScheduleAsyncPersistenceTOptions, AsyncMethodCallback) - Method in class alluxio.thrift.FileSystemMasterClientService.AsyncClient
 
scheduleAsyncPersistence(String, ScheduleAsyncPersistenceTOptions, AsyncMethodCallback) - Method in interface alluxio.thrift.FileSystemMasterClientService.AsyncIface
 
scheduleAsyncPersistence() - Constructor for class alluxio.thrift.FileSystemMasterClientService.AsyncProcessor.scheduleAsyncPersistence
 
scheduleAsyncPersistence(String, ScheduleAsyncPersistenceTOptions) - Method in class alluxio.thrift.FileSystemMasterClientService.Client
 
scheduleAsyncPersistence(String, ScheduleAsyncPersistenceTOptions) - Method in interface alluxio.thrift.FileSystemMasterClientService.Iface
Schedules async persistence.
scheduleAsyncPersistence() - Constructor for class alluxio.thrift.FileSystemMasterClientService.Processor.scheduleAsyncPersistence
 
scheduleAsyncPersistence_args() - Constructor for class alluxio.thrift.FileSystemMasterClientService.scheduleAsyncPersistence_args
 
scheduleAsyncPersistence_args(String, ScheduleAsyncPersistenceTOptions) - Constructor for class alluxio.thrift.FileSystemMasterClientService.scheduleAsyncPersistence_args
 
scheduleAsyncPersistence_args(FileSystemMasterClientService.scheduleAsyncPersistence_args) - Constructor for class alluxio.thrift.FileSystemMasterClientService.scheduleAsyncPersistence_args
Performs a deep copy on other.
scheduleAsyncPersistence_call(String, ScheduleAsyncPersistenceTOptions, AsyncMethodCallback, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class alluxio.thrift.FileSystemMasterClientService.AsyncClient.scheduleAsyncPersistence_call
 
scheduleAsyncPersistence_result() - Constructor for class alluxio.thrift.FileSystemMasterClientService.scheduleAsyncPersistence_result
 
scheduleAsyncPersistence_result(ScheduleAsyncPersistenceTResponse, AlluxioTException) - Constructor for class alluxio.thrift.FileSystemMasterClientService.scheduleAsyncPersistence_result
 
scheduleAsyncPersistence_result(FileSystemMasterClientService.scheduleAsyncPersistence_result) - Constructor for class alluxio.thrift.FileSystemMasterClientService.scheduleAsyncPersistence_result
Performs a deep copy on other.
ScheduleAsyncPersistenceTOptions - Class in alluxio.thrift
 
ScheduleAsyncPersistenceTOptions() - Constructor for class alluxio.thrift.ScheduleAsyncPersistenceTOptions
 
ScheduleAsyncPersistenceTOptions(ScheduleAsyncPersistenceTOptions) - Constructor for class alluxio.thrift.ScheduleAsyncPersistenceTOptions
Performs a deep copy on other.
ScheduleAsyncPersistenceTOptions._Fields - Enum in alluxio.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
ScheduleAsyncPersistenceTResponse - Class in alluxio.thrift
 
ScheduleAsyncPersistenceTResponse() - Constructor for class alluxio.thrift.ScheduleAsyncPersistenceTResponse
 
ScheduleAsyncPersistenceTResponse(ScheduleAsyncPersistenceTResponse) - Constructor for class alluxio.thrift.ScheduleAsyncPersistenceTResponse
Performs a deep copy on other.
ScheduleAsyncPersistenceTResponse._Fields - Enum in alluxio.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
scheduleAtFixedRate(Runnable, long, long, TimeUnit) - Method in class alluxio.util.executor.ControllableScheduler
 
scheduleCheckpoint(CheckpointPlan) - Method in class alluxio.master.lineage.DefaultLineageMaster
 
scheduleCheckpoint(CheckpointPlan) - Method in interface alluxio.master.lineage.LineageMaster
Schedules persistence for the output files of the given checkpoint plan.
SCHEDULED_TIMER_CLASS - Static variable in class alluxio.heartbeat.HeartbeatContext
 
ScheduledTimer - Class in alluxio.heartbeat
This class can be used for controlling heartbeat execution of threads.
ScheduledTimer(String, long) - Constructor for class alluxio.heartbeat.ScheduledTimer
Creates a new instance of ScheduledTimer.
schedulerIsIdle() - Method in class alluxio.util.executor.ControllableScheduler
Reports whether scheduler has no commands/tasks pending immediate execution.
scheduleWithFixedDelay(Runnable, long, long, TimeUnit) - Method in class alluxio.util.executor.ControllableScheduler
 
SCHEME - Static variable in class alluxio.Constants
 
SCHEME - Static variable in class alluxio.underfs.wasb.WasbUnderFileSystem
Constant for the wasb URI scheme.
SCHEME_FT - Static variable in class alluxio.Constants
 
Scope - Enum in alluxio.thrift
 
Scope - Enum in alluxio.wire
Scope where the property applies to.
Scoped - Interface in alluxio.util.interfaces
Extension of Closeable which throws no checked exceptions.
searchPropertiesFile(String, String[]) - Static method in class alluxio.util.ConfigurationUtils
Searches the given properties file from a list of paths.
SECOND - Static variable in class alluxio.Constants
 
SECOND_MS - Static variable in class alluxio.Constants
 
SECOND_NANO - Static variable in class alluxio.Constants
 
SECOND_TIER - Static variable in class alluxio.Constants
 
SecureHdfsValidationTask - Class in alluxio.cli.validation
Task for validating security configurations.
SecureHdfsValidationTask(String) - Constructor for class alluxio.cli.validation.SecureHdfsValidationTask
Constructor of SecureHdfsValidationTask.
SECURITY_AUTHENTICATION_CUSTOM_PROVIDER_CLASS - Static variable in class alluxio.PropertyKey.Name
 
SECURITY_AUTHENTICATION_CUSTOM_PROVIDER_CLASS - Static variable in class alluxio.PropertyKey
 
SECURITY_AUTHENTICATION_TYPE - Static variable in class alluxio.PropertyKey.Name
 
SECURITY_AUTHENTICATION_TYPE - Static variable in class alluxio.PropertyKey
 
SECURITY_AUTHORIZATION_PERMISSION_ENABLED - Static variable in class alluxio.PropertyKey.Name
 
SECURITY_AUTHORIZATION_PERMISSION_ENABLED - Static variable in class alluxio.PropertyKey
 
SECURITY_AUTHORIZATION_PERMISSION_SUPERGROUP - Static variable in class alluxio.PropertyKey.Name
 
SECURITY_AUTHORIZATION_PERMISSION_SUPERGROUP - Static variable in class alluxio.PropertyKey
 
SECURITY_AUTHORIZATION_PERMISSION_UMASK - Static variable in class alluxio.PropertyKey.Name
 
SECURITY_AUTHORIZATION_PERMISSION_UMASK - Static variable in class alluxio.PropertyKey
 
SECURITY_GROUP_MAPPING_CACHE_TIMEOUT_MS - Static variable in class alluxio.PropertyKey.Name
 
SECURITY_GROUP_MAPPING_CACHE_TIMEOUT_MS - Static variable in class alluxio.PropertyKey
 
SECURITY_GROUP_MAPPING_CLASS - Static variable in class alluxio.PropertyKey.Name
 
SECURITY_GROUP_MAPPING_CLASS - Static variable in class alluxio.PropertyKey
 
SECURITY_LOGIN_IMPERSONATION_USERNAME - Static variable in class alluxio.PropertyKey.Name
 
SECURITY_LOGIN_IMPERSONATION_USERNAME - Static variable in class alluxio.PropertyKey
 
SECURITY_LOGIN_USERNAME - Static variable in class alluxio.PropertyKey.Name
 
SECURITY_LOGIN_USERNAME - Static variable in class alluxio.PropertyKey
 
SecurityUtils - Class in alluxio.util
Utility methods for security.
seek(long) - Method in class alluxio.client.block.stream.BlockInStream
 
seek(long) - Method in class alluxio.client.file.FileInStream
 
seek(long) - Method in class alluxio.hadoop.HdfsFileInputStream
 
seek(long) - Method in interface alluxio.Seekable
Moves the starting read position of the stream to the specified position which is relative to the start of the stream.
seek(long) - Method in class alluxio.underfs.hdfs.HdfsUnderFileInputStream
 
Seekable - Interface in alluxio
This interface should be implemented by all Alluxio streams which support moving the read position to a specific byte offset.
SeekableUnderFileInputStream - Class in alluxio.underfs
A seekable under file input stream wrapper that encapsulates the under file input stream.
SeekableUnderFileInputStream(InputStream) - Constructor for class alluxio.underfs.SeekableUnderFileInputStream
 
seekToNewSource(long) - Method in class alluxio.hadoop.HdfsFileInputStream
This method is not supported in HdfsFileInputStream.
selectDirWithRequestedSpace(long, BlockStoreLocation, BlockMetadataManagerView) - Static method in class alluxio.worker.block.evictor.EvictorUtils
Finds a directory in the given location range with capacity upwards of the given bound.
send_accessBlock(long, AccessBlockTOptions) - Method in class alluxio.thrift.BlockWorkerClientService.Client
 
send_backup(BackupTOptions) - Method in class alluxio.thrift.MetaMasterClientService.Client
 
send_blockHeartbeat(long, Map<String, Long>, List<Long>, Map<String, List<Long>>, BlockHeartbeatTOptions) - Method in class alluxio.thrift.BlockMasterWorkerService.Client
 
send_cacheBlock(long, long, CacheBlockTOptions) - Method in class alluxio.thrift.BlockWorkerClientService.Client
 
send_cancelBlock(long, long, CancelBlockTOptions) - Method in class alluxio.thrift.BlockWorkerClientService.Client
 
send_cancelUfsFile(long, long, CancelUfsFileTOptions) - Method in class alluxio.thrift.FileSystemWorkerClientService.Client
 
send_checkConsistency(String, CheckConsistencyTOptions) - Method in class alluxio.thrift.FileSystemMasterClientService.Client
 
send_closeUfsFile(long, long, CloseUfsFileTOptions) - Method in class alluxio.thrift.FileSystemWorkerClientService.Client
 
send_commitBlock(long, long, String, long, long, CommitBlockTOptions) - Method in class alluxio.thrift.BlockMasterWorkerService.Client
 
send_completeFile(String, CompleteFileTOptions) - Method in class alluxio.thrift.FileSystemMasterClientService.Client
 
send_completePartition(String, PartitionInfo, CompletePartitionTOptions) - Method in class alluxio.thrift.KeyValueMasterClientService.Client
 
send_completeStore(String, CompleteStoreTOptions) - Method in class alluxio.thrift.KeyValueMasterClientService.Client
 
send_completeUfsFile(long, long, CompleteUfsFileTOptions) - Method in class alluxio.thrift.FileSystemWorkerClientService.Client
 
send_createDirectory(String, CreateDirectoryTOptions) - Method in class alluxio.thrift.FileSystemMasterClientService.Client
 
send_createFile(String, CreateFileTOptions) - Method in class alluxio.thrift.FileSystemMasterClientService.Client
 
send_createLineage(List<String>, List<String>, CommandLineJobInfo, CreateLineageTOptions) - Method in class alluxio.thrift.LineageMasterClientService.Client
 
send_createStore(String, CreateStoreTOptions) - Method in class alluxio.thrift.KeyValueMasterClientService.Client
 
send_createUfsFile(long, String, CreateUfsFileTOptions) - Method in class alluxio.thrift.FileSystemWorkerClientService.Client
 
send_deleteLineage(long, boolean, DeleteLineageTOptions) - Method in class alluxio.thrift.LineageMasterClientService.Client
 
send_deleteStore(String, DeleteStoreTOptions) - Method in class alluxio.thrift.KeyValueMasterClientService.Client
 
send_fileSystemHeartbeat(long, List<Long>, FileSystemHeartbeatTOptions) - Method in class alluxio.thrift.FileSystemMasterWorkerService.Client
 
send_free(String, boolean, FreeTOptions) - Method in class alluxio.thrift.FileSystemMasterClientService.Client
 
send_get(long, ByteBuffer, GetTOptions) - Method in class alluxio.thrift.KeyValueWorkerClientService.Client
 
send_getBlockInfo(long, GetBlockInfoTOptions) - Method in class alluxio.thrift.BlockMasterClientService.Client
 
send_getBlockMasterInfo(GetBlockMasterInfoTOptions) - Method in class alluxio.thrift.BlockMasterClientService.Client
 
send_getCapacityBytes(GetCapacityBytesTOptions) - Method in class alluxio.thrift.BlockMasterClientService.Client
 
send_getConfigReport(GetConfigReportTOptions) - Method in class alluxio.thrift.MetaMasterClientService.Client
 
send_getConfiguration(GetConfigurationTOptions) - Method in class alluxio.thrift.MetaMasterClientService.Client
 
send_getFileInfo(long, GetFileInfoTOptions) - Method in class alluxio.thrift.FileSystemMasterWorkerService.Client
 
send_getFilePath(GetFilePathTOptions) - Method in class alluxio.thrift.FileSystemMasterClientService.Client
 
send_getLineageInfoList(GetLineageInfoListTOptions) - Method in class alluxio.thrift.LineageMasterClientService.Client
 
send_getMasterId(MasterNetAddress, GetMasterIdTOptions) - Method in class alluxio.thrift.MetaMasterMasterService.Client
 
send_getMasterInfo(GetMasterInfoTOptions) - Method in class alluxio.thrift.MetaMasterClientService.Client
 
send_getMetrics(GetMetricsTOptions) - Method in class alluxio.thrift.MetaMasterClientService.Client
 
send_getMountTable() - Method in class alluxio.thrift.FileSystemMasterClientService.Client
 
send_getNewBlockIdForFile(String, GetNewBlockIdForFileTOptions) - Method in class alluxio.thrift.FileSystemMasterClientService.Client
 
send_getNextKeys(long, ByteBuffer, int, GetNextKeysTOptions) - Method in class alluxio.thrift.KeyValueWorkerClientService.Client
 
send_getPartitionInfo(String, GetPartitionInfoTOptions) - Method in class alluxio.thrift.KeyValueMasterClientService.Client
 
send_getPinnedFileIds(GetPinnedFileIdsTOptions) - Method in class alluxio.thrift.FileSystemMasterWorkerService.Client
 
send_getServiceVersion(GetServiceVersionTOptions) - Method in class alluxio.thrift.AlluxioService.Client
 
send_getSize(long, GetSizeTOptions) - Method in class alluxio.thrift.KeyValueWorkerClientService.Client
 
send_getStatus(String, GetStatusTOptions) - Method in class alluxio.thrift.FileSystemMasterClientService.Client
 
send_getUfsInfo(long, GetUfsInfoTOptions) - Method in class alluxio.thrift.FileSystemMasterWorkerService.Client
 
send_getUsedBytes(GetUsedBytesTOptions) - Method in class alluxio.thrift.BlockMasterClientService.Client
 
send_getWorkerId(WorkerNetAddress, GetWorkerIdTOptions) - Method in class alluxio.thrift.BlockMasterWorkerService.Client
 
send_getWorkerInfoList(GetWorkerInfoListTOptions) - Method in class alluxio.thrift.BlockMasterClientService.Client
 
send_getWorkerReport(GetWorkerReportTOptions) - Method in class alluxio.thrift.BlockMasterClientService.Client
 
send_listStatus(String, ListStatusTOptions) - Method in class alluxio.thrift.FileSystemMasterClientService.Client
 
send_loadMetadata(String, boolean, LoadMetadataTOptions) - Method in class alluxio.thrift.FileSystemMasterClientService.Client
 
send_lockBlock(long, long, LockBlockTOptions) - Method in class alluxio.thrift.BlockWorkerClientService.Client
 
send_masterHeartbeat(long, MasterHeartbeatTOptions) - Method in class alluxio.thrift.MetaMasterMasterService.Client
 
send_mergeStore(String, String, MergeStoreTOptions) - Method in class alluxio.thrift.KeyValueMasterClientService.Client
 
send_metricsHeartbeat(String, String, MetricsHeartbeatTOptions) - Method in class alluxio.thrift.MetricsMasterClientService.Client
 
send_mount(String, String, MountTOptions) - Method in class alluxio.thrift.FileSystemMasterClientService.Client
 
send_openUfsFile(long, String, OpenUfsFileTOptions) - Method in class alluxio.thrift.FileSystemWorkerClientService.Client
 
send_promoteBlock(long, PromoteBlockTOptions) - Method in class alluxio.thrift.BlockWorkerClientService.Client
 
send_registerMaster(long, RegisterMasterTOptions) - Method in class alluxio.thrift.MetaMasterMasterService.Client
 
send_registerWorker(long, List<String>, Map<String, Long>, Map<String, Long>, Map<String, List<Long>>, RegisterWorkerTOptions) - Method in class alluxio.thrift.BlockMasterWorkerService.Client
 
send_reinitializeFile(String, long, long, TTtlAction, ReinitializeFileTOptions) - Method in class alluxio.thrift.LineageMasterClientService.Client
 
send_remove(String, boolean, DeleteTOptions) - Method in class alluxio.thrift.FileSystemMasterClientService.Client
 
send_removeBlock(long, RemoveBlockTOptions) - Method in class alluxio.thrift.BlockWorkerClientService.Client
 
send_rename(String, String, RenameTOptions) - Method in class alluxio.thrift.FileSystemMasterClientService.Client
 
send_renameStore(String, String, RenameStoreTOptions) - Method in class alluxio.thrift.KeyValueMasterClientService.Client
 
send_reportLostFile(String, ReportLostFileTOptions) - Method in class alluxio.thrift.LineageMasterClientService.Client
 
send_requestBlockLocation(long, long, long, int, RequestBlockLocationTOptions) - Method in class alluxio.thrift.BlockWorkerClientService.Client
 
send_requestSpace(long, long, long, RequestSpaceTOptions) - Method in class alluxio.thrift.BlockWorkerClientService.Client
 
send_scheduleAsyncPersistence(String, ScheduleAsyncPersistenceTOptions) - Method in class alluxio.thrift.FileSystemMasterClientService.Client
 
send_sessionBlockHeartbeat(long, List<Long>, SessionBlockHeartbeatTOptions) - Method in class alluxio.thrift.BlockWorkerClientService.Client
 
send_sessionFileSystemHeartbeat(long, List<Long>, SessionFileSystemHeartbeatTOptions) - Method in class alluxio.thrift.FileSystemWorkerClientService.Client
 
send_setAttribute(String, SetAttributeTOptions) - Method in class alluxio.thrift.FileSystemMasterClientService.Client
 
send_unlockBlock(long, long, UnlockBlockTOptions) - Method in class alluxio.thrift.BlockWorkerClientService.Client
 
send_unmount(String, UnmountTOptions) - Method in class alluxio.thrift.FileSystemMasterClientService.Client
 
send_updateUfsMode(String, UpdateUfsModeTOptions) - Method in class alluxio.thrift.FileSystemMasterClientService.Client
 
SEPARATOR - Static variable in class alluxio.AlluxioURI
 
SEQUENCE_NUMBER_FIELD_NUMBER - Static variable in class alluxio.proto.journal.File.InodeDirectoryIdGeneratorEntry
 
SEQUENCE_NUMBER_FIELD_NUMBER - Static variable in class alluxio.proto.journal.Journal.JournalEntry
 
SEQUENCE_NUMBER_FIELD_NUMBER - Static variable in class alluxio.proto.journal.Lineage.LineageIdGeneratorEntry
 
serialize(Journal.JournalEntry, OutputStream) - Method in interface alluxio.master.journalv0.JournalFormatter
Serializes the given entry and writes it to the given output stream.
serialize(Journal.JournalEntry, OutputStream) - Method in class alluxio.master.journalv0.ProtoBufJournalFormatter
 
serialize() - Method in class alluxio.underfs.Fingerprint
 
Server<T> - Interface in alluxio
Interface representing an Alluxio server.
ServerConfigurationChecker - Class in alluxio.master.meta.checkconf
This class is responsible for checking server-side configuration.
ServerConfigurationChecker(ServerConfigurationStore, ServerConfigurationStore) - Constructor for class alluxio.master.meta.checkconf.ServerConfigurationChecker
Constructs a new ServerConfigurationChecker.
ServerConfigurationStore - Class in alluxio.master.meta.checkconf
This class is responsible for recording server-side configuration.
ServerConfigurationStore() - Constructor for class alluxio.master.meta.checkconf.ServerConfigurationStore
Constructs a new ServerConfigurationStore.
SERVICE_NAME - Static variable in class alluxio.master.block.BlockMasterClientRestServiceHandler
Deprecated.
 
SERVICE_NAME - Static variable in class alluxio.master.file.FileSystemMasterClientRestServiceHandler
Deprecated.
 
SERVICE_NAME - Static variable in class alluxio.master.lineage.LineageMasterClientRestServiceHandler
Deprecated.
 
SERVICE_PREFIX - Static variable in class alluxio.master.block.BlockMasterClientRestServiceHandler
Deprecated.
 
SERVICE_PREFIX - Static variable in class alluxio.master.file.FileSystemMasterClientRestServiceHandler
Deprecated.
 
SERVICE_PREFIX - Static variable in class alluxio.master.lineage.LineageMasterClientRestServiceHandler
Deprecated.
 
SERVICE_PREFIX - Static variable in class alluxio.master.meta.AlluxioMasterRestServiceHandler
 
SERVICE_PREFIX - Static variable in class alluxio.proxy.AlluxioProxyRestServiceHandler
 
SERVICE_PREFIX - Static variable in class alluxio.proxy.PathsRestServiceHandler
 
SERVICE_PREFIX - Static variable in class alluxio.proxy.s3.S3RestServiceHandler
 
SERVICE_PREFIX - Static variable in class alluxio.proxy.StreamsRestServiceHandler
 
SERVICE_PREFIX - Static variable in class alluxio.worker.AlluxioWorkerRestServiceHandler
 
SERVICE_VERSION - Static variable in class alluxio.master.block.BlockMasterClientRestServiceHandler
Deprecated.
 
SERVICE_VERSION - Static variable in class alluxio.master.file.FileSystemMasterClientRestServiceHandler
Deprecated.
 
SERVICE_VERSION - Static variable in class alluxio.master.lineage.LineageMasterClientRestServiceHandler
Deprecated.
 
ServiceUtils - Class in alluxio
Utility methods for Alluxio services.
sessionBlockHeartbeat(long, List<Long>, SessionBlockHeartbeatTOptions, AsyncMethodCallback) - Method in class alluxio.thrift.BlockWorkerClientService.AsyncClient
 
sessionBlockHeartbeat(long, List<Long>, SessionBlockHeartbeatTOptions, AsyncMethodCallback) - Method in interface alluxio.thrift.BlockWorkerClientService.AsyncIface
 
sessionBlockHeartbeat() - Constructor for class alluxio.thrift.BlockWorkerClientService.AsyncProcessor.sessionBlockHeartbeat
 
sessionBlockHeartbeat(long, List<Long>, SessionBlockHeartbeatTOptions) - Method in class alluxio.thrift.BlockWorkerClientService.Client
 
sessionBlockHeartbeat(long, List<Long>, SessionBlockHeartbeatTOptions) - Method in interface alluxio.thrift.BlockWorkerClientService.Iface
Local session send heartbeat to local worker to keep its temporary folder.
sessionBlockHeartbeat() - Constructor for class alluxio.thrift.BlockWorkerClientService.Processor.sessionBlockHeartbeat
 
sessionBlockHeartbeat(long, List<Long>, SessionBlockHeartbeatTOptions) - Method in class alluxio.worker.block.BlockWorkerClientServiceHandler
 
sessionBlockHeartbeat_args() - Constructor for class alluxio.thrift.BlockWorkerClientService.sessionBlockHeartbeat_args
 
sessionBlockHeartbeat_args(long, List<Long>, SessionBlockHeartbeatTOptions) - Constructor for class alluxio.thrift.BlockWorkerClientService.sessionBlockHeartbeat_args
 
sessionBlockHeartbeat_args(BlockWorkerClientService.sessionBlockHeartbeat_args) - Constructor for class alluxio.thrift.BlockWorkerClientService.sessionBlockHeartbeat_args
Performs a deep copy on other.
sessionBlockHeartbeat_call(long, List<Long>, SessionBlockHeartbeatTOptions, AsyncMethodCallback, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class alluxio.thrift.BlockWorkerClientService.AsyncClient.sessionBlockHeartbeat_call
 
sessionBlockHeartbeat_result() - Constructor for class alluxio.thrift.BlockWorkerClientService.sessionBlockHeartbeat_result
 
sessionBlockHeartbeat_result(SessionBlockHeartbeatTResponse, AlluxioTException) - Constructor for class alluxio.thrift.BlockWorkerClientService.sessionBlockHeartbeat_result
 
sessionBlockHeartbeat_result(BlockWorkerClientService.sessionBlockHeartbeat_result) - Constructor for class alluxio.thrift.BlockWorkerClientService.sessionBlockHeartbeat_result
Performs a deep copy on other.
SessionBlockHeartbeatTOptions - Class in alluxio.thrift
 
SessionBlockHeartbeatTOptions() - Constructor for class alluxio.thrift.SessionBlockHeartbeatTOptions
 
SessionBlockHeartbeatTOptions(SessionBlockHeartbeatTOptions) - Constructor for class alluxio.thrift.SessionBlockHeartbeatTOptions
Performs a deep copy on other.
SessionBlockHeartbeatTOptions._Fields - Enum in alluxio.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
SessionBlockHeartbeatTResponse - Class in alluxio.thrift
 
SessionBlockHeartbeatTResponse() - Constructor for class alluxio.thrift.SessionBlockHeartbeatTResponse
 
SessionBlockHeartbeatTResponse(SessionBlockHeartbeatTResponse) - Constructor for class alluxio.thrift.SessionBlockHeartbeatTResponse
Performs a deep copy on other.
SessionBlockHeartbeatTResponse._Fields - Enum in alluxio.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
SessionCleanable - Interface in alluxio.worker
Interface for classes which track sessions and provide a method to clean any expired sessions.
SessionCleaner - Class in alluxio.worker
SessionCleaner periodically checks if any session have become zombies, removes the zombie session and associated data when necessary.
SessionCleaner(Sessions, SessionCleanable...) - Constructor for class alluxio.worker.SessionCleaner
Creates a new instance of SessionCleaner.
sessionFileSystemHeartbeat(long, List<Long>, SessionFileSystemHeartbeatTOptions, AsyncMethodCallback) - Method in class alluxio.thrift.FileSystemWorkerClientService.AsyncClient
 
sessionFileSystemHeartbeat(long, List<Long>, SessionFileSystemHeartbeatTOptions, AsyncMethodCallback) - Method in interface alluxio.thrift.FileSystemWorkerClientService.AsyncIface
 
sessionFileSystemHeartbeat() - Constructor for class alluxio.thrift.FileSystemWorkerClientService.AsyncProcessor.sessionFileSystemHeartbeat
 
sessionFileSystemHeartbeat(long, List<Long>, SessionFileSystemHeartbeatTOptions) - Method in class alluxio.thrift.FileSystemWorkerClientService.Client
 
sessionFileSystemHeartbeat(long, List<Long>, SessionFileSystemHeartbeatTOptions) - Method in interface alluxio.thrift.FileSystemWorkerClientService.Iface
Local session send heartbeat to local worker to keep its state.
sessionFileSystemHeartbeat() - Constructor for class alluxio.thrift.FileSystemWorkerClientService.Processor.sessionFileSystemHeartbeat
 
sessionFileSystemHeartbeat(long, List<Long>, SessionFileSystemHeartbeatTOptions) - Method in class alluxio.worker.file.FileSystemWorkerClientServiceHandler
 
sessionFileSystemHeartbeat_args() - Constructor for class alluxio.thrift.FileSystemWorkerClientService.sessionFileSystemHeartbeat_args
 
sessionFileSystemHeartbeat_args(long, List<Long>, SessionFileSystemHeartbeatTOptions) - Constructor for class alluxio.thrift.FileSystemWorkerClientService.sessionFileSystemHeartbeat_args
 
sessionFileSystemHeartbeat_args(FileSystemWorkerClientService.sessionFileSystemHeartbeat_args) - Constructor for class alluxio.thrift.FileSystemWorkerClientService.sessionFileSystemHeartbeat_args
Performs a deep copy on other.
sessionFileSystemHeartbeat_call(long, List<Long>, SessionFileSystemHeartbeatTOptions, AsyncMethodCallback, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class alluxio.thrift.FileSystemWorkerClientService.AsyncClient.sessionFileSystemHeartbeat_call
 
sessionFileSystemHeartbeat_result() - Constructor for class alluxio.thrift.FileSystemWorkerClientService.sessionFileSystemHeartbeat_result
 
sessionFileSystemHeartbeat_result(SessionFileSystemHeartbeatTResponse, AlluxioTException) - Constructor for class alluxio.thrift.FileSystemWorkerClientService.sessionFileSystemHeartbeat_result
 
sessionFileSystemHeartbeat_result(FileSystemWorkerClientService.sessionFileSystemHeartbeat_result) - Constructor for class alluxio.thrift.FileSystemWorkerClientService.sessionFileSystemHeartbeat_result
Performs a deep copy on other.
SessionFileSystemHeartbeatTOptions - Class in alluxio.thrift
 
SessionFileSystemHeartbeatTOptions() - Constructor for class alluxio.thrift.SessionFileSystemHeartbeatTOptions
 
SessionFileSystemHeartbeatTOptions(SessionFileSystemHeartbeatTOptions) - Constructor for class alluxio.thrift.SessionFileSystemHeartbeatTOptions
Performs a deep copy on other.
SessionFileSystemHeartbeatTOptions._Fields - Enum in alluxio.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
SessionFileSystemHeartbeatTResponse - Class in alluxio.thrift
 
SessionFileSystemHeartbeatTResponse() - Constructor for class alluxio.thrift.SessionFileSystemHeartbeatTResponse
 
SessionFileSystemHeartbeatTResponse(SessionFileSystemHeartbeatTResponse) - Constructor for class alluxio.thrift.SessionFileSystemHeartbeatTResponse
Performs a deep copy on other.
SessionFileSystemHeartbeatTResponse._Fields - Enum in alluxio.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
sessionHeartbeat(long) - Method in class alluxio.Sessions
Performs session heartbeat.
sessionHeartbeat(long) - Method in interface alluxio.worker.block.BlockWorker
Handles the heartbeat from a client.
sessionHeartbeat(long) - Method in class alluxio.worker.block.DefaultBlockWorker
 
SessionInfo - Class in alluxio
Represents one session in the worker daemon.
SessionInfo(long, int) - Constructor for class alluxio.SessionInfo
Creates a new instance of SessionInfo.
Sessions - Class in alluxio
Sessions represents and manages all sessions contacting a worker.
Sessions() - Constructor for class alluxio.Sessions
Creates a new instance of Sessions.
set(PropertyKey, Object) - Static method in class alluxio.Configuration
Sets the value for the appropriate key in the Properties.
set(PropertyKey, Object, Source) - Static method in class alluxio.Configuration
Sets the value for the appropriate key in the Properties by source.
set(String) - Static method in class alluxio.security.authentication.AuthenticatedClientUser
Creates a User and sets it to the ThreadLocal variable.
set(User) - Static method in class alluxio.security.authentication.AuthenticatedClientUser
Sets User to the ThreadLocal variable.
SET_ATTRIBUTE - Static variable in class alluxio.master.file.FileSystemMasterClientRestServiceHandler
Deprecated.
 
SET_ATTRIBUTE - Static variable in class alluxio.proxy.PathsRestServiceHandler
 
SET_ATTRIBUTE_FIELD_NUMBER - Static variable in class alluxio.proto.journal.Journal.JournalEntry
 
SET_ATTRIBUTE_OPS - Static variable in class alluxio.metrics.MasterMetrics
 
SET_PERMISSION_COMMAND - Static variable in class alluxio.util.ShellUtils
a Unix command to set permission.
setAddedBlocksOnTiers(Map<String, List<Long>>) - Method in class alluxio.thrift.BlockMasterWorkerService.blockHeartbeat_args
the map of added blocks on all tiers
setAddedBlocksOnTiersIsSet(boolean) - Method in class alluxio.thrift.BlockMasterWorkerService.blockHeartbeat_args
 
setAddMountPoint(File.AddMountPointEntry) - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
optional .alluxio.proto.journal.AddMountPointEntry add_mount_point = 2;
setAddMountPoint(File.AddMountPointEntry.Builder) - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
optional .alluxio.proto.journal.AddMountPointEntry add_mount_point = 2;
setAddress(WorkerNetAddress) - Method in class alluxio.thrift.WorkerInfo
 
setAddress(WorkerNetAddress) - Method in class alluxio.wire.WorkerInfo
 
setAddresses(Set<String>) - Method in class alluxio.client.block.options.GetWorkerReportOptions
 
setAddresses(Set<String>) - Method in class alluxio.thrift.GetWorkerReportTOptions
addresses are only valid when workerRange is SPECIFIED
setAddressesIsSet(boolean) - Method in class alluxio.thrift.GetWorkerReportTOptions
 
setAddressIsSet(boolean) - Method in class alluxio.thrift.WorkerInfo
 
setAlias(String[]) - Method in class alluxio.PropertyKey.Builder
 
setAllowed(boolean) - Method in interface alluxio.master.audit.AuditContext
Set to true if the operation associated with this AuditContext is allowed, false otherwise.
setAllowed(boolean) - Method in class alluxio.master.file.FileSystemMasterAuditContext
 
setAllowExists(boolean) - Method in class alluxio.client.file.options.CreateDirectoryOptions
 
setAllowExists(boolean) - Method in class alluxio.master.file.options.CreateDirectoryOptions
 
setAllowExists(boolean) - Method in class alluxio.thrift.CreateDirectoryTOptions
 
setAllowExistsIsSet(boolean) - Method in class alluxio.thrift.CreateDirectoryTOptions
 
setAlluxioOnly(boolean) - Method in class alluxio.client.file.options.DeleteOptions
 
setAlluxioOnly(boolean) - Method in class alluxio.master.file.options.DeleteOptions
 
setAlluxioOnly(boolean) - Method in class alluxio.proto.journal.File.DeleteFileEntry.Builder
optional bool alluxioOnly = 4;
setAlluxioOnly(boolean) - Method in class alluxio.thrift.DeleteTOptions
 
setAlluxioOnlyIsSet(boolean) - Method in class alluxio.thrift.DeleteTOptions
 
setAlluxioPath(String) - Method in class alluxio.proto.journal.File.AddMountPointEntry.Builder
optional string alluxio_path = 1;
setAlluxioPath(String) - Method in class alluxio.proto.journal.File.DeleteMountPointEntry.Builder
optional string alluxio_path = 1;
setAlluxioPath(String) - Method in class alluxio.thrift.FileSystemMasterClientService.mount_args
the path of alluxio mount point
setAlluxioPath(String) - Method in class alluxio.thrift.FileSystemMasterClientService.unmount_args
the path of the alluxio mount point
setAlluxioPathBytes(ByteString) - Method in class alluxio.proto.journal.File.AddMountPointEntry.Builder
optional string alluxio_path = 1;
setAlluxioPathBytes(ByteString) - Method in class alluxio.proto.journal.File.DeleteMountPointEntry.Builder
optional string alluxio_path = 1;
setAlluxioPathIsSet(boolean) - Method in class alluxio.thrift.FileSystemMasterClientService.mount_args
 
setAlluxioPathIsSet(boolean) - Method in class alluxio.thrift.FileSystemMasterClientService.unmount_args
 
setAlluxioWorkDirectory() - Method in class alluxio.master.AbstractLocalAlluxioCluster
Sets Alluxio work directory.
setAsyncPersistRequest(File.AsyncPersistRequestEntry) - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
optional .alluxio.proto.journal.AsyncPersistRequestEntry async_persist_request = 16;
setAsyncPersistRequest(File.AsyncPersistRequestEntry.Builder) - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
optional .alluxio.proto.journal.AsyncPersistRequestEntry async_persist_request = 16;
setAttribute(AlluxioURI) - Method in class alluxio.client.file.BaseFileSystem
 
setAttribute(AlluxioURI, SetAttributeOptions) - Method in class alluxio.client.file.BaseFileSystem
 
setAttribute(AlluxioURI) - Method in interface alluxio.client.file.FileSystem
Convenience method for FileSystem.setAttribute(AlluxioURI, SetAttributeOptions) with default options.
setAttribute(AlluxioURI, SetAttributeOptions) - Method in interface alluxio.client.file.FileSystem
Sets any number of a path's attributes, such as TTL and pin status.
setAttribute(AlluxioURI, SetAttributeOptions) - Method in interface alluxio.client.file.FileSystemMasterClient
Sets the file or directory attributes.
setAttribute(AlluxioURI, SetAttributeOptions) - Method in class alluxio.client.file.RetryHandlingFileSystemMasterClient
 
setAttribute(AlluxioURI, SetAttributeOptions) - Method in class alluxio.master.file.DefaultFileSystemMaster
 
setAttribute(AlluxioURI, SetAttributeOptions) - Method in interface alluxio.master.file.FileSystemMaster
Sets the file attribute.
setAttribute(String, Boolean, Long, Boolean, String, String, Short, Boolean, TtlAction) - Method in class alluxio.master.file.FileSystemMasterClientRestServiceHandler
Deprecated.
 
setAttribute(String, SetAttributeTOptions) - Method in class alluxio.master.file.FileSystemMasterClientServiceHandler
 
setAttribute(String, SetAttributeOptions) - Method in class alluxio.proxy.PathsRestServiceHandler
 
setAttribute(String, SetAttributeTOptions, AsyncMethodCallback) - Method in class alluxio.thrift.FileSystemMasterClientService.AsyncClient
 
setAttribute(String, SetAttributeTOptions, AsyncMethodCallback) - Method in interface alluxio.thrift.FileSystemMasterClientService.AsyncIface
 
setAttribute() - Constructor for class alluxio.thrift.FileSystemMasterClientService.AsyncProcessor.setAttribute
 
setAttribute(String, SetAttributeTOptions) - Method in class alluxio.thrift.FileSystemMasterClientService.Client
 
setAttribute(String, SetAttributeTOptions) - Method in interface alluxio.thrift.FileSystemMasterClientService.Iface
Sets file or directory attributes.
setAttribute() - Constructor for class alluxio.thrift.FileSystemMasterClientService.Processor.setAttribute
 
setAttribute_args() - Constructor for class alluxio.thrift.FileSystemMasterClientService.setAttribute_args
 
setAttribute_args(String, SetAttributeTOptions) - Constructor for class alluxio.thrift.FileSystemMasterClientService.setAttribute_args
 
setAttribute_args(FileSystemMasterClientService.setAttribute_args) - Constructor for class alluxio.thrift.FileSystemMasterClientService.setAttribute_args
Performs a deep copy on other.
setAttribute_call(String, SetAttributeTOptions, AsyncMethodCallback, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class alluxio.thrift.FileSystemMasterClientService.AsyncClient.setAttribute_call
 
setAttribute_result() - Constructor for class alluxio.thrift.FileSystemMasterClientService.setAttribute_result
 
setAttribute_result(SetAttributeTResponse, AlluxioTException) - Constructor for class alluxio.thrift.FileSystemMasterClientService.setAttribute_result
 
setAttribute_result(FileSystemMasterClientService.setAttribute_result) - Constructor for class alluxio.thrift.FileSystemMasterClientService.setAttribute_result
Performs a deep copy on other.
SetAttributeOptions - Class in alluxio.client.file.options
Method options for setting any number of a path's attributes.
SetAttributeOptions - Class in alluxio.master.file.options
Method options for setting the attributes.
SetAttributeOptions(SetAttributeTOptions) - Constructor for class alluxio.master.file.options.SetAttributeOptions
Constructs a new method option for setting the attributes.
SetAttributeTOptions - Class in alluxio.thrift
 
SetAttributeTOptions() - Constructor for class alluxio.thrift.SetAttributeTOptions
 
SetAttributeTOptions(SetAttributeTOptions) - Constructor for class alluxio.thrift.SetAttributeTOptions
Performs a deep copy on other.
SetAttributeTOptions._Fields - Enum in alluxio.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
SetAttributeTResponse - Class in alluxio.thrift
 
SetAttributeTResponse() - Constructor for class alluxio.thrift.SetAttributeTResponse
 
SetAttributeTResponse(SetAttributeTResponse) - Constructor for class alluxio.thrift.SetAttributeTResponse
Performs a deep copy on other.
SetAttributeTResponse._Fields - Enum in alluxio.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
setAuthType(AuthType) - Method in class alluxio.master.file.FileSystemMasterAuditContext
Sets mAuthType field.
setBackupUri(String) - Method in class alluxio.thrift.BackupTResponse
 
setBackupUriIsSet(boolean) - Method in class alluxio.thrift.BackupTResponse
 
setBlockContainerIdGenerator(Block.BlockContainerIdGeneratorEntry) - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
optional .alluxio.proto.journal.BlockContainerIdGeneratorEntry block_container_id_generator = 3;
setBlockContainerIdGenerator(Block.BlockContainerIdGeneratorEntry.Builder) - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
optional .alluxio.proto.journal.BlockContainerIdGeneratorEntry block_container_id_generator = 3;
setBlockId(long) - Method in class alluxio.client.block.policy.options.GetWorkerOptions
 
setBlockId(long) - Method in class alluxio.proto.dataserver.Protocol.AsyncCacheRequest.Builder
optional int64 block_id = 1;
setBlockId(long) - Method in class alluxio.proto.dataserver.Protocol.LocalBlockCloseRequest.Builder
optional int64 block_id = 1;
setBlockId(long) - Method in class alluxio.proto.dataserver.Protocol.LocalBlockCompleteRequest.Builder
optional int64 block_id = 1;
setBlockId(long) - Method in class alluxio.proto.dataserver.Protocol.LocalBlockCreateRequest.Builder
optional int64 block_id = 1;
setBlockId(long) - Method in class alluxio.proto.dataserver.Protocol.LocalBlockOpenRequest.Builder
optional int64 block_id = 1;
setBlockId(long) - Method in class alluxio.proto.dataserver.Protocol.ReadRequest.Builder
optional int64 block_id = 1;
setBlockId(long) - Method in class alluxio.proto.journal.Block.BlockInfoEntry.Builder
optional int64 block_id = 1;
setBlockId(long) - Method in class alluxio.proto.journal.Block.DeleteBlockEntry.Builder
optional int64 block_id = 1;
setBlockId(long) - Method in class alluxio.proto.journal.KeyValue.CompletePartitionEntry.Builder
optional int64 block_id = 4;
setBlockId(long) - Method in class alluxio.thrift.BlockInfo
 
setBlockId(long) - Method in class alluxio.thrift.BlockMasterClientService.getBlockInfo_args
the id of the block
setBlockId(long) - Method in class alluxio.thrift.BlockMasterWorkerService.commitBlock_args
the id of the block being committed
setBlockId(long) - Method in class alluxio.thrift.BlockWorkerClientService.accessBlock_args
the id of the block being accessed
setBlockId(long) - Method in class alluxio.thrift.BlockWorkerClientService.cacheBlock_args
the id of the block being accessed
setBlockId(long) - Method in class alluxio.thrift.BlockWorkerClientService.cancelBlock_args
the id of the block being accessed
setBlockId(long) - Method in class alluxio.thrift.BlockWorkerClientService.lockBlock_args
the id of the block being accessed
setBlockId(long) - Method in class alluxio.thrift.BlockWorkerClientService.promoteBlock_args
the id of the block being accessed
setBlockId(long) - Method in class alluxio.thrift.BlockWorkerClientService.removeBlock_args
the id of the block being removed
setBlockId(long) - Method in class alluxio.thrift.BlockWorkerClientService.requestBlockLocation_args
the id of the block being accessed
setBlockId(long) - Method in class alluxio.thrift.BlockWorkerClientService.requestSpace_args
the id of the block being accessed
setBlockId(long) - Method in class alluxio.thrift.BlockWorkerClientService.unlockBlock_args
the id of the block being accessed
setBlockId(long) - Method in class alluxio.thrift.KeyValueWorkerClientService.get_args
the id of the block being accessed
setBlockId(long) - Method in class alluxio.thrift.KeyValueWorkerClientService.getNextKeys_args
the id of the partition
setBlockId(long) - Method in class alluxio.thrift.KeyValueWorkerClientService.getSize_args
the id of the partition
setBlockId(long) - Method in class alluxio.thrift.PartitionInfo
 
setBlockId(long) - Method in class alluxio.wire.BlockInfo
 
setBlockIdIsSet(boolean) - Method in class alluxio.thrift.BlockInfo
 
setBlockIdIsSet(boolean) - Method in class alluxio.thrift.BlockMasterClientService.getBlockInfo_args
 
setBlockIdIsSet(boolean) - Method in class alluxio.thrift.BlockMasterWorkerService.commitBlock_args
 
setBlockIdIsSet(boolean) - Method in class alluxio.thrift.BlockWorkerClientService.accessBlock_args
 
setBlockIdIsSet(boolean) - Method in class alluxio.thrift.BlockWorkerClientService.cacheBlock_args
 
setBlockIdIsSet(boolean) - Method in class alluxio.thrift.BlockWorkerClientService.cancelBlock_args
 
setBlockIdIsSet(boolean) - Method in class alluxio.thrift.BlockWorkerClientService.lockBlock_args
 
setBlockIdIsSet(boolean) - Method in class alluxio.thrift.BlockWorkerClientService.promoteBlock_args
 
setBlockIdIsSet(boolean) - Method in class alluxio.thrift.BlockWorkerClientService.removeBlock_args
 
setBlockIdIsSet(boolean) - Method in class alluxio.thrift.BlockWorkerClientService.requestBlockLocation_args
 
setBlockIdIsSet(boolean) - Method in class alluxio.thrift.BlockWorkerClientService.requestSpace_args
 
setBlockIdIsSet(boolean) - Method in class alluxio.thrift.BlockWorkerClientService.unlockBlock_args
 
setBlockIdIsSet(boolean) - Method in class alluxio.thrift.KeyValueWorkerClientService.get_args
 
setBlockIdIsSet(boolean) - Method in class alluxio.thrift.KeyValueWorkerClientService.getNextKeys_args
 
setBlockIdIsSet(boolean) - Method in class alluxio.thrift.KeyValueWorkerClientService.getSize_args
 
setBlockIdIsSet(boolean) - Method in class alluxio.thrift.PartitionInfo
 
setBlockIds(List<Long>) - Method in class alluxio.master.file.meta.InodeFile
 
setBlockIds(int, long) - Method in class alluxio.proto.journal.File.CompleteFileEntry.Builder
repeated int64 block_ids = 1;
setBlockIds(List<Long>) - Method in class alluxio.thrift.FileInfo
 
setBlockIds(List<Long>) - Method in class alluxio.thrift.PersistFile
 
setBlockIds(List<Long>) - Method in class alluxio.wire.FileInfo
 
setBlockIdsIsSet(boolean) - Method in class alluxio.thrift.FileInfo
 
setBlockIdsIsSet(boolean) - Method in class alluxio.thrift.PersistFile
 
setBlockInfo(Block.BlockInfoEntry) - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
optional .alluxio.proto.journal.BlockInfoEntry block_info = 4;
setBlockInfo(Block.BlockInfoEntry.Builder) - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
optional .alluxio.proto.journal.BlockInfoEntry block_info = 4;
setBlockInfo(BlockInfo) - Method in class alluxio.thrift.FileBlockInfo
 
setBlockInfo(BlockInfo) - Method in class alluxio.thrift.GetBlockInfoTResponse
 
setBlockInfo(BlockInfo) - Method in class alluxio.wire.FileBlockInfo
 
setBlockInfoIsSet(boolean) - Method in class alluxio.thrift.FileBlockInfo
 
setBlockInfoIsSet(boolean) - Method in class alluxio.thrift.GetBlockInfoTResponse
 
setBlockMasterInfo(BlockMasterInfo) - Method in class alluxio.thrift.GetBlockMasterInfoTResponse
 
setBlockMasterInfoIsSet(boolean) - Method in class alluxio.thrift.GetBlockMasterInfoTResponse
 
setBlockPath(String) - Method in class alluxio.thrift.LockBlockTResponse
 
setBlockPathIsSet(boolean) - Method in class alluxio.thrift.LockBlockTResponse
 
setBlockReader(BlockReader) - Method in class alluxio.worker.netty.BlockReadRequestContext
 
setBlocks(int, long) - Method in class alluxio.proto.journal.File.InodeFileEntry.Builder
repeated int64 blocks = 12;
setBlockSize(long) - Method in class alluxio.client.block.options.LockBlockOptions
 
setBlockSize(long) - Method in class alluxio.client.block.policy.options.GetWorkerOptions
 
setBlockSize(long) - Method in class alluxio.proto.dataserver.Protocol.OpenUfsBlockOptions.Builder
optional int64 block_size = 3;
setBlockSize(long) - Method in class alluxio.thrift.LockBlockTOptions
 
setBlockSize(long) - Method in class alluxio.worker.block.meta.TempBlockMeta
 
setBlockSizeBytes(long) - Method in class alluxio.client.file.options.CreateFileOptions
 
setBlockSizeBytes(long) - Method in class alluxio.client.file.options.OutStreamOptions
Sets the size of the block in bytes.
setBlockSizeBytes(long) - Method in class alluxio.master.file.meta.InodeFile
 
setBlockSizeBytes(long) - Method in class alluxio.master.file.options.CreateFileOptions
 
setBlockSizeBytes(long) - Method in class alluxio.proto.journal.File.InodeFileEntry.Builder
optional int64 block_size_bytes = 8;
setBlockSizeBytes(long) - Method in class alluxio.proto.journal.File.ReinitializeFileEntry.Builder
optional int64 block_size_bytes = 2;
setBlockSizeBytes(long) - Method in class alluxio.thrift.CreateFileTOptions
 
setBlockSizeBytes(long) - Method in class alluxio.thrift.FileInfo
 
setBlockSizeBytes(long) - Method in class alluxio.thrift.LineageMasterClientService.reinitializeFile_args
block size in bytes
setBlockSizeBytes(long) - Method in class alluxio.wire.FileInfo
 
setBlockSizeBytesIsSet(boolean) - Method in class alluxio.thrift.CreateFileTOptions
 
setBlockSizeBytesIsSet(boolean) - Method in class alluxio.thrift.FileInfo
 
setBlockSizeBytesIsSet(boolean) - Method in class alluxio.thrift.LineageMasterClientService.reinitializeFile_args
 
setBlockSizeIsSet(boolean) - Method in class alluxio.thrift.LockBlockTOptions
 
setBlockWorkerInfos(List<BlockWorkerInfo>) - Method in class alluxio.client.block.policy.options.GetWorkerOptions
 
setBlockWriter(BlockWriter) - Method in class alluxio.worker.netty.BlockWriteRequestContext
 
setBucket(String) - Method in class alluxio.proxy.s3.CompleteMultipartUploadResult
 
setBucket(String) - Method in class alluxio.proxy.s3.InitiateMultipartUploadResult
 
setBucket(String) - Method in class alluxio.proxy.s3.ListPartsResult
 
setBytes(long) - Method in class alluxio.thrift.GetCapacityBytesTResponse
 
setBytes(long) - Method in class alluxio.thrift.GetUsedBytesTResponse
 
setBytesIsSet(boolean) - Method in class alluxio.thrift.GetCapacityBytesTResponse
 
setBytesIsSet(boolean) - Method in class alluxio.thrift.GetUsedBytesTResponse
 
setBytesReserved(long) - Method in class alluxio.worker.netty.BlockWriteRequestContext
 
setCacheable(boolean) - Method in class alluxio.master.file.meta.InodeFile
 
setCacheable(boolean) - Method in class alluxio.master.file.options.CreateFileOptions
 
setCacheable(boolean) - Method in class alluxio.proto.journal.File.InodeFileEntry.Builder
optional bool cacheable = 11;
setCacheable(boolean) - Method in class alluxio.thrift.FileInfo
 
setCacheable(boolean) - Method in class alluxio.wire.FileInfo
 
setCacheableIsSet(boolean) - Method in class alluxio.thrift.FileInfo
 
setCacheLocationPolicy(FileWriteLocationPolicy) - Method in class alluxio.client.file.options.OpenFileOptions
 
setCacheLocationPolicyClass(String) - Method in class alluxio.client.file.options.OpenFileOptions
 
setCancel(boolean) - Method in class alluxio.proto.dataserver.Protocol.LocalBlockCompleteRequest.Builder
optional bool cancel = 2;
setCancel(boolean) - Method in class alluxio.proto.dataserver.Protocol.ReadRequest.Builder
optional bool cancel = 4;
setCancel(boolean) - Method in class alluxio.proto.dataserver.Protocol.WriteRequest.Builder
optional bool cancel = 6;
setCancel(boolean) - Method in class alluxio.worker.netty.ReadRequestContext
 
setCapacity(Capacity) - Method in class alluxio.wire.AlluxioMasterInfo
 
setCapacity(Capacity) - Method in class alluxio.wire.AlluxioWorkerInfo
 
setCapacityBytes(long) - Method in class alluxio.thrift.BlockMasterInfo
 
setCapacityBytes(long) - Method in class alluxio.thrift.WorkerInfo
 
setCapacityBytes(long) - Method in class alluxio.wire.BlockMasterInfo
 
setCapacityBytes(long) - Method in class alluxio.wire.WorkerInfo
 
setCapacityBytesIsSet(boolean) - Method in class alluxio.thrift.BlockMasterInfo
 
setCapacityBytesIsSet(boolean) - Method in class alluxio.thrift.WorkerInfo
 
setCapacityBytesOnTiers(Map<String, Long>) - Method in class alluxio.thrift.BlockMasterInfo
 
setCapacityBytesOnTiers(Map<String, Long>) - Method in class alluxio.thrift.WorkerInfo
 
setCapacityBytesOnTiers(Map<String, Long>) - Method in class alluxio.wire.BlockMasterInfo
 
setCapacityBytesOnTiers(Map<String, Long>) - Method in class alluxio.wire.WorkerInfo
 
setCapacityBytesOnTiersIsSet(boolean) - Method in class alluxio.thrift.BlockMasterInfo
 
setCapacityBytesOnTiersIsSet(boolean) - Method in class alluxio.thrift.WorkerInfo
 
setCascade(boolean) - Method in class alluxio.client.lineage.options.DeleteLineageOptions
Sets the cascade flag for this option.
setCascade(boolean) - Method in class alluxio.proto.journal.Lineage.DeleteLineageEntry.Builder
optional bool cascade = 2;
setCascade(boolean) - Method in class alluxio.thrift.LineageMasterClientService.deleteLineage_args
whether to delete the lineage in cascade
setCascadeIsSet(boolean) - Method in class alluxio.thrift.LineageMasterClientService.deleteLineage_args
 
setChannel(Channel) - Method in class alluxio.network.netty.NettyRPCContext
 
setChildren(List<Long>) - Method in class alluxio.thrift.LineageInfo
 
setChildren(List<Long>) - Method in class alluxio.wire.LineageInfo
 
setChildrenIsSet(boolean) - Method in class alluxio.thrift.LineageInfo
 
setClientId(String) - Method in class alluxio.thrift.MetricsMasterClientService.metricsHeartbeat_args
the id of the client
setClientIdIsSet(boolean) - Method in class alluxio.thrift.MetricsMasterClientService.metricsHeartbeat_args
 
setClusterName(String) - Method in class alluxio.multi.process.MultiProcessCluster.Builder
 
setCode(String) - Method in class alluxio.proxy.s3.S3Error
 
setCommand(String) - Method in class alluxio.master.file.FileSystemMasterAuditContext
Sets mCommand field.
setCommand(Command) - Method in class alluxio.thrift.BlockHeartbeatTResponse
 
setCommand(String) - Method in class alluxio.thrift.CommandLineJobInfo
 
setCommand(FileSystemCommand) - Method in class alluxio.thrift.FileSystemHeartbeatTResponse
 
setCommand(MetaCommand) - Method in class alluxio.thrift.MasterHeartbeatTResponse
 
setCommand(String) - Method in class alluxio.wire.CommandLineJobInfo
 
setCommandIsSet(boolean) - Method in class alluxio.thrift.BlockHeartbeatTResponse
 
setCommandIsSet(boolean) - Method in class alluxio.thrift.CommandLineJobInfo
 
setCommandIsSet(boolean) - Method in class alluxio.thrift.FileSystemHeartbeatTResponse
 
setCommandIsSet(boolean) - Method in class alluxio.thrift.MasterHeartbeatTResponse
 
setCommandOptions(FileSystemCommandOptions) - Method in class alluxio.thrift.FileSystemCommand
 
setCommandOptionsIsSet(boolean) - Method in class alluxio.thrift.FileSystemCommand
 
setCommandType(CommandType) - Method in class alluxio.thrift.Command
 
setCommandType(CommandType) - Method in class alluxio.thrift.FileSystemCommand
 
setCommandTypeIsSet(boolean) - Method in class alluxio.thrift.Command
 
setCommandTypeIsSet(boolean) - Method in class alluxio.thrift.FileSystemCommand
 
setCommonOptions(CommonOptions) - Method in class alluxio.client.file.options.CheckConsistencyOptions
 
setCommonOptions(CommonOptions) - Method in class alluxio.client.file.options.CompleteFileOptions
 
setCommonOptions(CommonOptions) - Method in class alluxio.client.file.options.CreateDirectoryOptions
 
setCommonOptions(CommonOptions) - Method in class alluxio.client.file.options.CreateFileOptions
 
setCommonOptions(CommonOptions) - Method in class alluxio.client.file.options.DeleteOptions
 
setCommonOptions(CommonOptions) - Method in class alluxio.client.file.options.ExistsOptions
 
setCommonOptions(CommonOptions) - Method in class alluxio.client.file.options.FreeOptions
 
setCommonOptions(CommonOptions) - Method in class alluxio.client.file.options.GetStatusOptions
 
setCommonOptions(CommonOptions) - Method in class alluxio.client.file.options.ListStatusOptions
 
setCommonOptions(CommonOptions) - Method in class alluxio.client.file.options.MountOptions
 
setCommonOptions(CommonOptions) - Method in class alluxio.client.file.options.RenameOptions
 
setCommonOptions(CommonOptions) - Method in class alluxio.client.file.options.SetAttributeOptions
 
setCommonOptions(CommonOptions) - Method in class alluxio.client.file.options.UnmountOptions
 
setCommonOptions(CommonOptions) - Method in class alluxio.master.file.options.CheckConsistencyOptions
 
setCommonOptions(CommonOptions) - Method in class alluxio.master.file.options.CompleteFileOptions
 
setCommonOptions(CommonOptions) - Method in class alluxio.master.file.options.CreatePathOptions
 
setCommonOptions(CommonOptions) - Method in class alluxio.master.file.options.DeleteOptions
 
setCommonOptions(CommonOptions) - Method in class alluxio.master.file.options.FreeOptions
 
setCommonOptions(CommonOptions) - Method in class alluxio.master.file.options.GetStatusOptions
 
setCommonOptions(CommonOptions) - Method in class alluxio.master.file.options.ListStatusOptions
 
setCommonOptions(CommonOptions) - Method in class alluxio.master.file.options.LoadMetadataOptions
 
setCommonOptions(CommonOptions) - Method in class alluxio.master.file.options.MountOptions
 
setCommonOptions(CommonOptions) - Method in class alluxio.master.file.options.RenameOptions
 
setCommonOptions(CommonOptions) - Method in class alluxio.master.file.options.SetAttributeOptions
 
setCommonOptions(CommonOptions) - Method in class alluxio.master.file.options.SyncMetadataOptions
 
setCommonOptions(FileSystemMasterCommonTOptions) - Method in class alluxio.thrift.CheckConsistencyTOptions
 
setCommonOptions(FileSystemMasterCommonTOptions) - Method in class alluxio.thrift.CompleteFileTOptions
 
setCommonOptions(FileSystemMasterCommonTOptions) - Method in class alluxio.thrift.CreateDirectoryTOptions
 
setCommonOptions(FileSystemMasterCommonTOptions) - Method in class alluxio.thrift.CreateFileTOptions
 
setCommonOptions(FileSystemMasterCommonTOptions) - Method in class alluxio.thrift.DeleteTOptions
 
setCommonOptions(FileSystemMasterCommonTOptions) - Method in class alluxio.thrift.FreeTOptions
 
setCommonOptions(FileSystemMasterCommonTOptions) - Method in class alluxio.thrift.GetNewBlockIdForFileTOptions
 
setCommonOptions(FileSystemMasterCommonTOptions) - Method in class alluxio.thrift.GetStatusTOptions
 
setCommonOptions(FileSystemMasterCommonTOptions) - Method in class alluxio.thrift.ListStatusTOptions
 
setCommonOptions(FileSystemMasterCommonTOptions) - Method in class alluxio.thrift.LoadMetadataTOptions
 
setCommonOptions(FileSystemMasterCommonTOptions) - Method in class alluxio.thrift.MountTOptions
 
setCommonOptions(FileSystemMasterCommonTOptions) - Method in class alluxio.thrift.RenameTOptions
 
setCommonOptions(FileSystemMasterCommonTOptions) - Method in class alluxio.thrift.ScheduleAsyncPersistenceTOptions
 
setCommonOptions(FileSystemMasterCommonTOptions) - Method in class alluxio.thrift.SetAttributeTOptions
 
setCommonOptions(FileSystemMasterCommonTOptions) - Method in class alluxio.thrift.SyncMetadataTOptions
 
setCommonOptions(FileSystemMasterCommonTOptions) - Method in class alluxio.thrift.UnmountTOptions
 
setCommonOptionsIsSet(boolean) - Method in class alluxio.thrift.CheckConsistencyTOptions
 
setCommonOptionsIsSet(boolean) - Method in class alluxio.thrift.CompleteFileTOptions
 
setCommonOptionsIsSet(boolean) - Method in class alluxio.thrift.CreateDirectoryTOptions
 
setCommonOptionsIsSet(boolean) - Method in class alluxio.thrift.CreateFileTOptions
 
setCommonOptionsIsSet(boolean) - Method in class alluxio.thrift.DeleteTOptions
 
setCommonOptionsIsSet(boolean) - Method in class alluxio.thrift.FreeTOptions
 
setCommonOptionsIsSet(boolean) - Method in class alluxio.thrift.GetNewBlockIdForFileTOptions
 
setCommonOptionsIsSet(boolean) - Method in class alluxio.thrift.GetStatusTOptions
 
setCommonOptionsIsSet(boolean) - Method in class alluxio.thrift.ListStatusTOptions
 
setCommonOptionsIsSet(boolean) - Method in class alluxio.thrift.LoadMetadataTOptions
 
setCommonOptionsIsSet(boolean) - Method in class alluxio.thrift.MountTOptions
 
setCommonOptionsIsSet(boolean) - Method in class alluxio.thrift.RenameTOptions
 
setCommonOptionsIsSet(boolean) - Method in class alluxio.thrift.ScheduleAsyncPersistenceTOptions
 
setCommonOptionsIsSet(boolean) - Method in class alluxio.thrift.SetAttributeTOptions
 
setCommonOptionsIsSet(boolean) - Method in class alluxio.thrift.SyncMetadataTOptions
 
setCommonOptionsIsSet(boolean) - Method in class alluxio.thrift.UnmountTOptions
 
setCompleted(boolean) - Method in class alluxio.master.file.meta.InodeFile
 
setCompleted(boolean) - Method in class alluxio.proto.journal.File.InodeFileEntry.Builder
optional bool completed = 10;
setCompleted(boolean) - Method in class alluxio.thrift.FileInfo
 
setCompleted(boolean) - Method in class alluxio.wire.FileInfo
 
setCompletedIsSet(boolean) - Method in class alluxio.thrift.FileInfo
 
setCompleteFile(File.CompleteFileEntry) - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
optional .alluxio.proto.journal.CompleteFileEntry complete_file = 5;
setCompleteFile(File.CompleteFileEntry.Builder) - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
optional .alluxio.proto.journal.CompleteFileEntry complete_file = 5;
setCompletePartition(KeyValue.CompletePartitionEntry) - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
optional .alluxio.proto.journal.CompletePartitionEntry complete_partition = 21;
setCompletePartition(KeyValue.CompletePartitionEntry.Builder) - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
optional .alluxio.proto.journal.CompletePartitionEntry complete_partition = 21;
setCompleteStore(KeyValue.CompleteStoreEntry) - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
optional .alluxio.proto.journal.CompleteStoreEntry complete_store = 22;
setCompleteStore(KeyValue.CompleteStoreEntry.Builder) - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
optional .alluxio.proto.journal.CompleteStoreEntry complete_store = 22;
setConf(JobConfInfo) - Method in class alluxio.thrift.CommandLineJobInfo
 
setConf(JobConfInfo) - Method in class alluxio.wire.CommandLineJobInfo
 
setConfigList(List<ConfigProperty>) - Method in class alluxio.thrift.GetConfigurationTResponse
 
setConfigList(List<ConfigProperty>) - Method in class alluxio.thrift.RegisterMasterTOptions
 
setConfigList(List<ConfigProperty>) - Method in class alluxio.thrift.RegisterWorkerTOptions
 
setConfigListIsSet(boolean) - Method in class alluxio.thrift.GetConfigurationTResponse
 
setConfigListIsSet(boolean) - Method in class alluxio.thrift.RegisterMasterTOptions
 
setConfigListIsSet(boolean) - Method in class alluxio.thrift.RegisterWorkerTOptions
 
setConfiguration(Map<String, String>) - Method in class alluxio.wire.AlluxioMasterInfo
 
setConfiguration(Map<String, String>) - Method in class alluxio.wire.AlluxioProxyInfo
 
setConfiguration(Map<String, String>) - Method in class alluxio.wire.AlluxioWorkerInfo
 
setConfIsSet(boolean) - Method in class alluxio.thrift.CommandLineJobInfo
 
setConsistencyCheckLevel(PropertyKey.ConsistencyCheckLevel) - Method in class alluxio.PropertyKey.Builder
 
setContainerId(long) - Method in class alluxio.proto.journal.File.InodeDirectoryIdGeneratorEntry.Builder
optional int64 container_id = 1;
setContent(List<ListBucketResult.Content>) - Method in class alluxio.proxy.s3.ListBucketResult
 
setContinuationToken(String) - Method in class alluxio.proxy.s3.ListBucketOptions
 
setContinuationToken(String) - Method in class alluxio.proxy.s3.ListBucketResult
 
setCounter(Counter) - Method in class alluxio.worker.netty.ReadRequestContext
 
setCounter(Counter) - Method in class alluxio.worker.netty.WriteRequestContext
 
setCreateAncestors(boolean) - Method in class alluxio.master.file.options.LoadMetadataOptions
Sets the recursive flag.
setCreateOptions(CreateOptions) - Method in class alluxio.worker.netty.UfsFileWriteRequestContext
 
setCreateParent(boolean) - Method in class alluxio.underfs.options.CreateOptions
Sets option to force creation of parent directories.
setCreateParent(boolean) - Method in class alluxio.underfs.options.MkdirsOptions
Sets option to create parent directories.
setCreateStore(KeyValue.CreateStoreEntry) - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
optional .alluxio.proto.journal.CreateStoreEntry create_store = 23;
setCreateStore(KeyValue.CreateStoreEntry.Builder) - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
optional .alluxio.proto.journal.CreateStoreEntry create_store = 23;
setCreateUfsFileOptions(Protocol.CreateUfsFileOptions) - Method in class alluxio.proto.dataserver.Protocol.WriteRequest.Builder
optional .alluxio.proto.dataserver.CreateUfsFileOptions create_ufs_file_options = 7;
setCreateUfsFileOptions(Protocol.CreateUfsFileOptions.Builder) - Method in class alluxio.proto.dataserver.Protocol.WriteRequest.Builder
optional .alluxio.proto.dataserver.CreateUfsFileOptions create_ufs_file_options = 7;
setCreationTimeMs(long) - Method in class alluxio.master.file.meta.Inode
 
setCreationTimeMs(long) - Method in class alluxio.proto.journal.File.InodeDirectoryEntry.Builder
optional int64 creation_time_ms = 6;
setCreationTimeMs(long) - Method in class alluxio.proto.journal.File.InodeFileEntry.Builder
optional int64 creation_time_ms = 6;
setCreationTimeMs(long) - Method in class alluxio.proto.journal.Lineage.LineageEntry.Builder
optional int64 creation_time_ms = 6;
setCreationTimeMs(long) - Method in class alluxio.thrift.FileInfo
 
setCreationTimeMs(long) - Method in class alluxio.thrift.LineageInfo
 
setCreationTimeMs(long) - Method in class alluxio.wire.FileInfo
 
setCreationTimeMs(long) - Method in class alluxio.wire.LineageInfo
 
setCreationTimeMsIsSet(boolean) - Method in class alluxio.thrift.FileInfo
 
setCreationTimeMsIsSet(boolean) - Method in class alluxio.thrift.LineageInfo
 
setCurrentBlocksOnTiers(Map<String, List<Long>>) - Method in class alluxio.thrift.BlockMasterWorkerService.registerWorker_args
the map of list of blocks on each tier
setCurrentBlocksOnTiersIsSet(boolean) - Method in class alluxio.thrift.BlockMasterWorkerService.registerWorker_args
 
setData(List<Long>) - Method in class alluxio.thrift.Command
 
setData(byte[]) - Method in class alluxio.thrift.GetTResponse
 
setData(ByteBuffer) - Method in class alluxio.thrift.GetTResponse
 
setDataIsSet(boolean) - Method in class alluxio.thrift.Command
 
setDataIsSet(boolean) - Method in class alluxio.thrift.GetTResponse
 
setDataPort(int) - Method in class alluxio.thrift.WorkerNetAddress
 
setDataPort(int) - Method in class alluxio.wire.WorkerNetAddress
 
setDataPortIsSet(boolean) - Method in class alluxio.thrift.WorkerNetAddress
 
setDefaultSupplier(DefaultSupplier) - Method in class alluxio.PropertyKey.Builder
 
setDefaultSupplier(Supplier<Object>, String) - Method in class alluxio.PropertyKey.Builder
 
setDefaultValue(Object) - Method in class alluxio.PropertyKey.Builder
 
setDelay(long) - Method in class alluxio.util.executor.ControllableQueue.DelayNode
Sets the delay.
setDeleteBlock(Block.DeleteBlockEntry) - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
optional .alluxio.proto.journal.DeleteBlockEntry delete_block = 29;
setDeleteBlock(Block.DeleteBlockEntry.Builder) - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
optional .alluxio.proto.journal.DeleteBlockEntry delete_block = 29;
setDeleted(boolean) - Method in class alluxio.master.file.meta.Inode
 
setDeleteFile(File.DeleteFileEntry) - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
optional .alluxio.proto.journal.DeleteFileEntry delete_file = 6;
setDeleteFile(File.DeleteFileEntry.Builder) - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
optional .alluxio.proto.journal.DeleteFileEntry delete_file = 6;
setDeleteLineage(Lineage.DeleteLineageEntry) - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
optional .alluxio.proto.journal.DeleteLineageEntry delete_lineage = 7;
setDeleteLineage(Lineage.DeleteLineageEntry.Builder) - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
optional .alluxio.proto.journal.DeleteLineageEntry delete_lineage = 7;
setDeleteMountPoint(File.DeleteMountPointEntry) - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
optional .alluxio.proto.journal.DeleteMountPointEntry delete_mount_point = 8;
setDeleteMountPoint(File.DeleteMountPointEntry.Builder) - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
optional .alluxio.proto.journal.DeleteMountPointEntry delete_mount_point = 8;
setDeleteStore(KeyValue.DeleteStoreEntry) - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
optional .alluxio.proto.journal.DeleteStoreEntry delete_store = 25;
setDeleteStore(KeyValue.DeleteStoreEntry.Builder) - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
optional .alluxio.proto.journal.DeleteStoreEntry delete_store = 25;
setDeployMode(MultiProcessCluster.DeployMode) - Method in class alluxio.multi.process.MultiProcessCluster.Builder
 
setDescription(String) - Method in class alluxio.PropertyKey.Builder
 
setDeterministicHashPolicyNumShards(int) - Method in class alluxio.client.block.policy.options.CreateOptions
 
setDeviceSpec(String) - Method in class alluxio.util.UnixMountInfo.Builder
 
setDirectChildrenLoaded(boolean) - Method in class alluxio.master.file.meta.InodeDirectory
 
setDirectChildrenLoaded(boolean) - Method in class alluxio.proto.journal.File.InodeDirectoryEntry.Builder
optional bool direct_children_loaded = 12;
setDisplayType(PropertyKey.DisplayType) - Method in class alluxio.PropertyKey.Builder
 
setDomainSocketPath(String) - Method in class alluxio.thrift.WorkerNetAddress
 
setDomainSocketPath(String) - Method in class alluxio.wire.WorkerNetAddress
 
setDomainSocketPathIsSet(boolean) - Method in class alluxio.thrift.WorkerNetAddress
 
setDoneUnsafe(boolean) - Method in class alluxio.worker.netty.ReadRequestContext
 
setDoneUnsafe(boolean) - Method in class alluxio.worker.netty.WriteRequestContext
 
setDoubleValue(double) - Method in class alluxio.thrift.MetricValue
 
setDoubleValueIsSet(boolean) - Method in class alluxio.thrift.MetricValue
 
setDstPath(AlluxioURI) - Method in class alluxio.master.file.FileSystemMasterAuditContext
Sets mDstPath field.
setDstPath(String) - Method in class alluxio.proto.journal.File.RenameEntry.Builder
optional string dst_path = 2;
setDstPath(String) - Method in class alluxio.thrift.FileSystemMasterClientService.rename_args
the desination path of the file
setDstPathBytes(ByteString) - Method in class alluxio.proto.journal.File.RenameEntry.Builder
optional string dst_path = 2;
setDstPathIsSet(boolean) - Method in class alluxio.thrift.FileSystemMasterClientService.rename_args
 
setE(AlluxioTException) - Method in class alluxio.thrift.AlluxioService.getServiceVersion_result
 
setE(AlluxioTException) - Method in class alluxio.thrift.BlockMasterClientService.getBlockInfo_result
 
setE(AlluxioTException) - Method in class alluxio.thrift.BlockMasterClientService.getBlockMasterInfo_result
 
setE(AlluxioTException) - Method in class alluxio.thrift.BlockMasterClientService.getCapacityBytes_result
 
setE(AlluxioTException) - Method in class alluxio.thrift.BlockMasterClientService.getUsedBytes_result
 
setE(AlluxioTException) - Method in class alluxio.thrift.BlockMasterClientService.getWorkerInfoList_result
 
setE(AlluxioTException) - Method in class alluxio.thrift.BlockMasterClientService.getWorkerReport_result
 
setE(AlluxioTException) - Method in class alluxio.thrift.BlockMasterWorkerService.blockHeartbeat_result
 
setE(AlluxioTException) - Method in class alluxio.thrift.BlockMasterWorkerService.commitBlock_result
 
setE(AlluxioTException) - Method in class alluxio.thrift.BlockMasterWorkerService.getWorkerId_result
 
setE(AlluxioTException) - Method in class alluxio.thrift.BlockMasterWorkerService.registerWorker_result
 
setE(AlluxioTException) - Method in class alluxio.thrift.BlockWorkerClientService.accessBlock_result
 
setE(AlluxioTException) - Method in class alluxio.thrift.BlockWorkerClientService.cacheBlock_result
 
setE(AlluxioTException) - Method in class alluxio.thrift.BlockWorkerClientService.cancelBlock_result
 
setE(AlluxioTException) - Method in class alluxio.thrift.BlockWorkerClientService.lockBlock_result
 
setE(AlluxioTException) - Method in class alluxio.thrift.BlockWorkerClientService.promoteBlock_result
 
setE(AlluxioTException) - Method in class alluxio.thrift.BlockWorkerClientService.removeBlock_result
 
setE(AlluxioTException) - Method in class alluxio.thrift.BlockWorkerClientService.requestBlockLocation_result
 
setE(AlluxioTException) - Method in class alluxio.thrift.BlockWorkerClientService.requestSpace_result
 
setE(AlluxioTException) - Method in class alluxio.thrift.BlockWorkerClientService.sessionBlockHeartbeat_result
 
setE(AlluxioTException) - Method in class alluxio.thrift.BlockWorkerClientService.unlockBlock_result
 
setE(AlluxioTException) - Method in class alluxio.thrift.FileSystemMasterClientService.checkConsistency_result
 
setE(AlluxioTException) - Method in class alluxio.thrift.FileSystemMasterClientService.completeFile_result
 
setE(AlluxioTException) - Method in class alluxio.thrift.FileSystemMasterClientService.createDirectory_result
 
setE(AlluxioTException) - Method in class alluxio.thrift.FileSystemMasterClientService.createFile_result
 
setE(AlluxioTException) - Method in class alluxio.thrift.FileSystemMasterClientService.free_result
 
setE(AlluxioTException) - Method in class alluxio.thrift.FileSystemMasterClientService.getFilePath_result
 
setE(AlluxioTException) - Method in class alluxio.thrift.FileSystemMasterClientService.getMountTable_result
 
setE(AlluxioTException) - Method in class alluxio.thrift.FileSystemMasterClientService.getNewBlockIdForFile_result
 
setE(AlluxioTException) - Method in class alluxio.thrift.FileSystemMasterClientService.getStatus_result
 
setE(AlluxioTException) - Method in class alluxio.thrift.FileSystemMasterClientService.listStatus_result
 
setE(AlluxioTException) - Method in class alluxio.thrift.FileSystemMasterClientService.loadMetadata_result
 
setE(AlluxioTException) - Method in class alluxio.thrift.FileSystemMasterClientService.mount_result
 
setE(AlluxioTException) - Method in class alluxio.thrift.FileSystemMasterClientService.remove_result
 
setE(AlluxioTException) - Method in class alluxio.thrift.FileSystemMasterClientService.rename_result
 
setE(AlluxioTException) - Method in class alluxio.thrift.FileSystemMasterClientService.scheduleAsyncPersistence_result
 
setE(AlluxioTException) - Method in class alluxio.thrift.FileSystemMasterClientService.setAttribute_result
 
setE(AlluxioTException) - Method in class alluxio.thrift.FileSystemMasterClientService.unmount_result
 
setE(AlluxioTException) - Method in class alluxio.thrift.FileSystemMasterClientService.updateUfsMode_result
 
setE(AlluxioTException) - Method in class alluxio.thrift.FileSystemMasterWorkerService.fileSystemHeartbeat_result
 
setE(AlluxioTException) - Method in class alluxio.thrift.FileSystemMasterWorkerService.getFileInfo_result
 
setE(AlluxioTException) - Method in class alluxio.thrift.FileSystemMasterWorkerService.getPinnedFileIds_result
 
setE(AlluxioTException) - Method in class alluxio.thrift.FileSystemMasterWorkerService.getUfsInfo_result
 
setE(AlluxioTException) - Method in class alluxio.thrift.FileSystemWorkerClientService.cancelUfsFile_result
 
setE(AlluxioTException) - Method in class alluxio.thrift.FileSystemWorkerClientService.closeUfsFile_result
 
setE(AlluxioTException) - Method in class alluxio.thrift.FileSystemWorkerClientService.completeUfsFile_result
 
setE(AlluxioTException) - Method in class alluxio.thrift.FileSystemWorkerClientService.createUfsFile_result
 
setE(AlluxioTException) - Method in class alluxio.thrift.FileSystemWorkerClientService.openUfsFile_result
 
setE(AlluxioTException) - Method in class alluxio.thrift.FileSystemWorkerClientService.sessionFileSystemHeartbeat_result
 
setE(AlluxioTException) - Method in class alluxio.thrift.KeyValueMasterClientService.completePartition_result
 
setE(AlluxioTException) - Method in class alluxio.thrift.KeyValueMasterClientService.completeStore_result
 
setE(AlluxioTException) - Method in class alluxio.thrift.KeyValueMasterClientService.createStore_result
 
setE(AlluxioTException) - Method in class alluxio.thrift.KeyValueMasterClientService.deleteStore_result
 
setE(AlluxioTException) - Method in class alluxio.thrift.KeyValueMasterClientService.getPartitionInfo_result
 
setE(AlluxioTException) - Method in class alluxio.thrift.KeyValueMasterClientService.mergeStore_result
 
setE(AlluxioTException) - Method in class alluxio.thrift.KeyValueMasterClientService.renameStore_result
 
setE(AlluxioTException) - Method in class alluxio.thrift.KeyValueWorkerClientService.get_result
 
setE(AlluxioTException) - Method in class alluxio.thrift.KeyValueWorkerClientService.getNextKeys_result
 
setE(AlluxioTException) - Method in class alluxio.thrift.KeyValueWorkerClientService.getSize_result
 
setE(AlluxioTException) - Method in class alluxio.thrift.LineageMasterClientService.createLineage_result
 
setE(AlluxioTException) - Method in class alluxio.thrift.LineageMasterClientService.deleteLineage_result
 
setE(AlluxioTException) - Method in class alluxio.thrift.LineageMasterClientService.getLineageInfoList_result
 
setE(AlluxioTException) - Method in class alluxio.thrift.LineageMasterClientService.reinitializeFile_result
 
setE(AlluxioTException) - Method in class alluxio.thrift.LineageMasterClientService.reportLostFile_result
 
setE(AlluxioTException) - Method in class alluxio.thrift.MetaMasterClientService.backup_result
 
setE(AlluxioTException) - Method in class alluxio.thrift.MetaMasterClientService.getConfigReport_result
 
setE(AlluxioTException) - Method in class alluxio.thrift.MetaMasterClientService.getConfiguration_result
 
setE(AlluxioTException) - Method in class alluxio.thrift.MetaMasterClientService.getMasterInfo_result
 
setE(AlluxioTException) - Method in class alluxio.thrift.MetaMasterClientService.getMetrics_result
 
setE(AlluxioTException) - Method in class alluxio.thrift.MetaMasterMasterService.getMasterId_result
 
setE(AlluxioTException) - Method in class alluxio.thrift.MetaMasterMasterService.masterHeartbeat_result
 
setE(AlluxioTException) - Method in class alluxio.thrift.MetaMasterMasterService.registerMaster_result
 
setE(AlluxioTException) - Method in class alluxio.thrift.MetricsMasterClientService.metricsHeartbeat_result
 
setEIsSet(boolean) - Method in class alluxio.thrift.AlluxioService.getServiceVersion_result
 
setEIsSet(boolean) - Method in class alluxio.thrift.BlockMasterClientService.getBlockInfo_result
 
setEIsSet(boolean) - Method in class alluxio.thrift.BlockMasterClientService.getBlockMasterInfo_result
 
setEIsSet(boolean) - Method in class alluxio.thrift.BlockMasterClientService.getCapacityBytes_result
 
setEIsSet(boolean) - Method in class alluxio.thrift.BlockMasterClientService.getUsedBytes_result
 
setEIsSet(boolean) - Method in class alluxio.thrift.BlockMasterClientService.getWorkerInfoList_result
 
setEIsSet(boolean) - Method in class alluxio.thrift.BlockMasterClientService.getWorkerReport_result
 
setEIsSet(boolean) - Method in class alluxio.thrift.BlockMasterWorkerService.blockHeartbeat_result
 
setEIsSet(boolean) - Method in class alluxio.thrift.BlockMasterWorkerService.commitBlock_result
 
setEIsSet(boolean) - Method in class alluxio.thrift.BlockMasterWorkerService.getWorkerId_result
 
setEIsSet(boolean) - Method in class alluxio.thrift.BlockMasterWorkerService.registerWorker_result
 
setEIsSet(boolean) - Method in class alluxio.thrift.BlockWorkerClientService.accessBlock_result
 
setEIsSet(boolean) - Method in class alluxio.thrift.BlockWorkerClientService.cacheBlock_result
 
setEIsSet(boolean) - Method in class alluxio.thrift.BlockWorkerClientService.cancelBlock_result
 
setEIsSet(boolean) - Method in class alluxio.thrift.BlockWorkerClientService.lockBlock_result
 
setEIsSet(boolean) - Method in class alluxio.thrift.BlockWorkerClientService.promoteBlock_result
 
setEIsSet(boolean) - Method in class alluxio.thrift.BlockWorkerClientService.removeBlock_result
 
setEIsSet(boolean) - Method in class alluxio.thrift.BlockWorkerClientService.requestBlockLocation_result
 
setEIsSet(boolean) - Method in class alluxio.thrift.BlockWorkerClientService.requestSpace_result
 
setEIsSet(boolean) - Method in class alluxio.thrift.BlockWorkerClientService.sessionBlockHeartbeat_result
 
setEIsSet(boolean) - Method in class alluxio.thrift.BlockWorkerClientService.unlockBlock_result
 
setEIsSet(boolean) - Method in class alluxio.thrift.FileSystemMasterClientService.checkConsistency_result
 
setEIsSet(boolean) - Method in class alluxio.thrift.FileSystemMasterClientService.completeFile_result
 
setEIsSet(boolean) - Method in class alluxio.thrift.FileSystemMasterClientService.createDirectory_result
 
setEIsSet(boolean) - Method in class alluxio.thrift.FileSystemMasterClientService.createFile_result
 
setEIsSet(boolean) - Method in class alluxio.thrift.FileSystemMasterClientService.free_result
 
setEIsSet(boolean) - Method in class alluxio.thrift.FileSystemMasterClientService.getFilePath_result
 
setEIsSet(boolean) - Method in class alluxio.thrift.FileSystemMasterClientService.getMountTable_result
 
setEIsSet(boolean) - Method in class alluxio.thrift.FileSystemMasterClientService.getNewBlockIdForFile_result
 
setEIsSet(boolean) - Method in class alluxio.thrift.FileSystemMasterClientService.getStatus_result
 
setEIsSet(boolean) - Method in class alluxio.thrift.FileSystemMasterClientService.listStatus_result
 
setEIsSet(boolean) - Method in class alluxio.thrift.FileSystemMasterClientService.loadMetadata_result
 
setEIsSet(boolean) - Method in class alluxio.thrift.FileSystemMasterClientService.mount_result
 
setEIsSet(boolean) - Method in class alluxio.thrift.FileSystemMasterClientService.remove_result
 
setEIsSet(boolean) - Method in class alluxio.thrift.FileSystemMasterClientService.rename_result
 
setEIsSet(boolean) - Method in class alluxio.thrift.FileSystemMasterClientService.scheduleAsyncPersistence_result
 
setEIsSet(boolean) - Method in class alluxio.thrift.FileSystemMasterClientService.setAttribute_result
 
setEIsSet(boolean) - Method in class alluxio.thrift.FileSystemMasterClientService.unmount_result
 
setEIsSet(boolean) - Method in class alluxio.thrift.FileSystemMasterClientService.updateUfsMode_result
 
setEIsSet(boolean) - Method in class alluxio.thrift.FileSystemMasterWorkerService.fileSystemHeartbeat_result
 
setEIsSet(boolean) - Method in class alluxio.thrift.FileSystemMasterWorkerService.getFileInfo_result
 
setEIsSet(boolean) - Method in class alluxio.thrift.FileSystemMasterWorkerService.getPinnedFileIds_result
 
setEIsSet(boolean) - Method in class alluxio.thrift.FileSystemMasterWorkerService.getUfsInfo_result
 
setEIsSet(boolean) - Method in class alluxio.thrift.FileSystemWorkerClientService.cancelUfsFile_result
 
setEIsSet(boolean) - Method in class alluxio.thrift.FileSystemWorkerClientService.closeUfsFile_result
 
setEIsSet(boolean) - Method in class alluxio.thrift.FileSystemWorkerClientService.completeUfsFile_result
 
setEIsSet(boolean) - Method in class alluxio.thrift.FileSystemWorkerClientService.createUfsFile_result
 
setEIsSet(boolean) - Method in class alluxio.thrift.FileSystemWorkerClientService.openUfsFile_result
 
setEIsSet(boolean) - Method in class alluxio.thrift.FileSystemWorkerClientService.sessionFileSystemHeartbeat_result
 
setEIsSet(boolean) - Method in class alluxio.thrift.KeyValueMasterClientService.completePartition_result
 
setEIsSet(boolean) - Method in class alluxio.thrift.KeyValueMasterClientService.completeStore_result
 
setEIsSet(boolean) - Method in class alluxio.thrift.KeyValueMasterClientService.createStore_result
 
setEIsSet(boolean) - Method in class alluxio.thrift.KeyValueMasterClientService.deleteStore_result
 
setEIsSet(boolean) - Method in class alluxio.thrift.KeyValueMasterClientService.getPartitionInfo_result
 
setEIsSet(boolean) - Method in class alluxio.thrift.KeyValueMasterClientService.mergeStore_result
 
setEIsSet(boolean) - Method in class alluxio.thrift.KeyValueMasterClientService.renameStore_result
 
setEIsSet(boolean) - Method in class alluxio.thrift.KeyValueWorkerClientService.get_result
 
setEIsSet(boolean) - Method in class alluxio.thrift.KeyValueWorkerClientService.getNextKeys_result
 
setEIsSet(boolean) - Method in class alluxio.thrift.KeyValueWorkerClientService.getSize_result
 
setEIsSet(boolean) - Method in class alluxio.thrift.LineageMasterClientService.createLineage_result
 
setEIsSet(boolean) - Method in class alluxio.thrift.LineageMasterClientService.deleteLineage_result
 
setEIsSet(boolean) - Method in class alluxio.thrift.LineageMasterClientService.getLineageInfoList_result
 
setEIsSet(boolean) - Method in class alluxio.thrift.LineageMasterClientService.reinitializeFile_result
 
setEIsSet(boolean) - Method in class alluxio.thrift.LineageMasterClientService.reportLostFile_result
 
setEIsSet(boolean) - Method in class alluxio.thrift.MetaMasterClientService.backup_result
 
setEIsSet(boolean) - Method in class alluxio.thrift.MetaMasterClientService.getConfigReport_result
 
setEIsSet(boolean) - Method in class alluxio.thrift.MetaMasterClientService.getConfiguration_result
 
setEIsSet(boolean) - Method in class alluxio.thrift.MetaMasterClientService.getMasterInfo_result
 
setEIsSet(boolean) - Method in class alluxio.thrift.MetaMasterClientService.getMetrics_result
 
setEIsSet(boolean) - Method in class alluxio.thrift.MetaMasterMasterService.getMasterId_result
 
setEIsSet(boolean) - Method in class alluxio.thrift.MetaMasterMasterService.masterHeartbeat_result
 
setEIsSet(boolean) - Method in class alluxio.thrift.MetaMasterMasterService.registerMaster_result
 
setEIsSet(boolean) - Method in class alluxio.thrift.MetricsMasterClientService.metricsHeartbeat_result
 
setEnsureAtomic(boolean) - Method in class alluxio.underfs.options.CreateOptions
Set atomicity guarantees.
setEntryCount(long) - Method in class alluxio.thrift.BackupTResponse
 
setEntryCountIsSet(boolean) - Method in class alluxio.thrift.BackupTResponse
 
setEof(boolean) - Method in class alluxio.proto.dataserver.Protocol.WriteRequest.Builder
optional bool eof = 5;
setEof(boolean) - Method in class alluxio.worker.netty.ReadRequestContext
 
setError(Error) - Method in class alluxio.worker.netty.ReadRequestContext
 
setError(Error) - Method in class alluxio.worker.netty.WriteRequestContext
 
setErrors(Map<Scope, List<InconsistentProperty>>) - Method in class alluxio.thrift.ConfigCheckReport
 
setErrorsIsSet(boolean) - Method in class alluxio.thrift.ConfigCheckReport
 
setETag(String) - Method in class alluxio.proxy.s3.CompleteMultipartUploadResult
 
setETag(String) - Method in class alluxio.proxy.s3.ListBucketResult.Content
 
setETag(String) - Method in class alluxio.proxy.s3.ListPartsResult.Part
 
setFieldRange(Set<GetWorkerReportOptions.WorkerInfoField>) - Method in class alluxio.client.block.options.GetWorkerReportOptions
 
setFieldRange(Set<WorkerInfoField>) - Method in class alluxio.thrift.GetWorkerReportTOptions
 
setFieldRangeIsSet(boolean) - Method in class alluxio.thrift.GetWorkerReportTOptions
 
setFieldValue(AccessBlockTOptions._Fields, Object) - Method in class alluxio.thrift.AccessBlockTOptions
 
setFieldValue(AccessBlockTResponse._Fields, Object) - Method in class alluxio.thrift.AccessBlockTResponse
 
setFieldValue(AlluxioService.getServiceVersion_args._Fields, Object) - Method in class alluxio.thrift.AlluxioService.getServiceVersion_args
 
setFieldValue(AlluxioService.getServiceVersion_result._Fields, Object) - Method in class alluxio.thrift.AlluxioService.getServiceVersion_result
 
setFieldValue(AlluxioTException._Fields, Object) - Method in exception alluxio.thrift.AlluxioTException
 
setFieldValue(BackupTOptions._Fields, Object) - Method in class alluxio.thrift.BackupTOptions
 
setFieldValue(BackupTResponse._Fields, Object) - Method in class alluxio.thrift.BackupTResponse
 
setFieldValue(BlockHeartbeatTOptions._Fields, Object) - Method in class alluxio.thrift.BlockHeartbeatTOptions
 
setFieldValue(BlockHeartbeatTResponse._Fields, Object) - Method in class alluxio.thrift.BlockHeartbeatTResponse
 
setFieldValue(BlockInfo._Fields, Object) - Method in class alluxio.thrift.BlockInfo
 
setFieldValue(BlockLocation._Fields, Object) - Method in class alluxio.thrift.BlockLocation
 
setFieldValue(BlockMasterClientService.getBlockInfo_args._Fields, Object) - Method in class alluxio.thrift.BlockMasterClientService.getBlockInfo_args
 
setFieldValue(BlockMasterClientService.getBlockInfo_result._Fields, Object) - Method in class alluxio.thrift.BlockMasterClientService.getBlockInfo_result
 
setFieldValue(BlockMasterClientService.getBlockMasterInfo_args._Fields, Object) - Method in class alluxio.thrift.BlockMasterClientService.getBlockMasterInfo_args
 
setFieldValue(BlockMasterClientService.getBlockMasterInfo_result._Fields, Object) - Method in class alluxio.thrift.BlockMasterClientService.getBlockMasterInfo_result
 
setFieldValue(BlockMasterClientService.getCapacityBytes_args._Fields, Object) - Method in class alluxio.thrift.BlockMasterClientService.getCapacityBytes_args
 
setFieldValue(BlockMasterClientService.getCapacityBytes_result._Fields, Object) - Method in class alluxio.thrift.BlockMasterClientService.getCapacityBytes_result
 
setFieldValue(BlockMasterClientService.getUsedBytes_args._Fields, Object) - Method in class alluxio.thrift.BlockMasterClientService.getUsedBytes_args
 
setFieldValue(BlockMasterClientService.getUsedBytes_result._Fields, Object) - Method in class alluxio.thrift.BlockMasterClientService.getUsedBytes_result
 
setFieldValue(BlockMasterClientService.getWorkerInfoList_args._Fields, Object) - Method in class alluxio.thrift.BlockMasterClientService.getWorkerInfoList_args
 
setFieldValue(BlockMasterClientService.getWorkerInfoList_result._Fields, Object) - Method in class alluxio.thrift.BlockMasterClientService.getWorkerInfoList_result
 
setFieldValue(BlockMasterClientService.getWorkerReport_args._Fields, Object) - Method in class alluxio.thrift.BlockMasterClientService.getWorkerReport_args
 
setFieldValue(BlockMasterClientService.getWorkerReport_result._Fields, Object) - Method in class alluxio.thrift.BlockMasterClientService.getWorkerReport_result
 
setFieldValue(BlockMasterInfo._Fields, Object) - Method in class alluxio.thrift.BlockMasterInfo
 
setFieldValue(BlockMasterWorkerService.blockHeartbeat_args._Fields, Object) - Method in class alluxio.thrift.BlockMasterWorkerService.blockHeartbeat_args
 
setFieldValue(BlockMasterWorkerService.blockHeartbeat_result._Fields, Object) - Method in class alluxio.thrift.BlockMasterWorkerService.blockHeartbeat_result
 
setFieldValue(BlockMasterWorkerService.commitBlock_args._Fields, Object) - Method in class alluxio.thrift.BlockMasterWorkerService.commitBlock_args
 
setFieldValue(BlockMasterWorkerService.commitBlock_result._Fields, Object) - Method in class alluxio.thrift.BlockMasterWorkerService.commitBlock_result
 
setFieldValue(BlockMasterWorkerService.getWorkerId_args._Fields, Object) - Method in class alluxio.thrift.BlockMasterWorkerService.getWorkerId_args
 
setFieldValue(BlockMasterWorkerService.getWorkerId_result._Fields, Object) - Method in class alluxio.thrift.BlockMasterWorkerService.getWorkerId_result
 
setFieldValue(BlockMasterWorkerService.registerWorker_args._Fields, Object) - Method in class alluxio.thrift.BlockMasterWorkerService.registerWorker_args
 
setFieldValue(BlockMasterWorkerService.registerWorker_result._Fields, Object) - Method in class alluxio.thrift.BlockMasterWorkerService.registerWorker_result
 
setFieldValue(BlockWorkerClientService.accessBlock_args._Fields, Object) - Method in class alluxio.thrift.BlockWorkerClientService.accessBlock_args
 
setFieldValue(BlockWorkerClientService.accessBlock_result._Fields, Object) - Method in class alluxio.thrift.BlockWorkerClientService.accessBlock_result
 
setFieldValue(BlockWorkerClientService.cacheBlock_args._Fields, Object) - Method in class alluxio.thrift.BlockWorkerClientService.cacheBlock_args
 
setFieldValue(BlockWorkerClientService.cacheBlock_result._Fields, Object) - Method in class alluxio.thrift.BlockWorkerClientService.cacheBlock_result
 
setFieldValue(BlockWorkerClientService.cancelBlock_args._Fields, Object) - Method in class alluxio.thrift.BlockWorkerClientService.cancelBlock_args
 
setFieldValue(BlockWorkerClientService.cancelBlock_result._Fields, Object) - Method in class alluxio.thrift.BlockWorkerClientService.cancelBlock_result
 
setFieldValue(BlockWorkerClientService.lockBlock_args._Fields, Object) - Method in class alluxio.thrift.BlockWorkerClientService.lockBlock_args
 
setFieldValue(BlockWorkerClientService.lockBlock_result._Fields, Object) - Method in class alluxio.thrift.BlockWorkerClientService.lockBlock_result
 
setFieldValue(BlockWorkerClientService.promoteBlock_args._Fields, Object) - Method in class alluxio.thrift.BlockWorkerClientService.promoteBlock_args
 
setFieldValue(BlockWorkerClientService.promoteBlock_result._Fields, Object) - Method in class alluxio.thrift.BlockWorkerClientService.promoteBlock_result
 
setFieldValue(BlockWorkerClientService.removeBlock_args._Fields, Object) - Method in class alluxio.thrift.BlockWorkerClientService.removeBlock_args
 
setFieldValue(BlockWorkerClientService.removeBlock_result._Fields, Object) - Method in class alluxio.thrift.BlockWorkerClientService.removeBlock_result
 
setFieldValue(BlockWorkerClientService.requestBlockLocation_args._Fields, Object) - Method in class alluxio.thrift.BlockWorkerClientService.requestBlockLocation_args
 
setFieldValue(BlockWorkerClientService.requestBlockLocation_result._Fields, Object) - Method in class alluxio.thrift.BlockWorkerClientService.requestBlockLocation_result
 
setFieldValue(BlockWorkerClientService.requestSpace_args._Fields, Object) - Method in class alluxio.thrift.BlockWorkerClientService.requestSpace_args
 
setFieldValue(BlockWorkerClientService.requestSpace_result._Fields, Object) - Method in class alluxio.thrift.BlockWorkerClientService.requestSpace_result
 
setFieldValue(BlockWorkerClientService.sessionBlockHeartbeat_args._Fields, Object) - Method in class alluxio.thrift.BlockWorkerClientService.sessionBlockHeartbeat_args
 
setFieldValue(BlockWorkerClientService.sessionBlockHeartbeat_result._Fields, Object) - Method in class alluxio.thrift.BlockWorkerClientService.sessionBlockHeartbeat_result
 
setFieldValue(BlockWorkerClientService.unlockBlock_args._Fields, Object) - Method in class alluxio.thrift.BlockWorkerClientService.unlockBlock_args
 
setFieldValue(BlockWorkerClientService.unlockBlock_result._Fields, Object) - Method in class alluxio.thrift.BlockWorkerClientService.unlockBlock_result
 
setFieldValue(CacheBlockTOptions._Fields, Object) - Method in class alluxio.thrift.CacheBlockTOptions
 
setFieldValue(CacheBlockTResponse._Fields, Object) - Method in class alluxio.thrift.CacheBlockTResponse
 
setFieldValue(CancelBlockTOptions._Fields, Object) - Method in class alluxio.thrift.CancelBlockTOptions
 
setFieldValue(CancelBlockTResponse._Fields, Object) - Method in class alluxio.thrift.CancelBlockTResponse
 
setFieldValue(CancelUfsFileTOptions._Fields, Object) - Method in class alluxio.thrift.CancelUfsFileTOptions
 
setFieldValue(CancelUfsFileTResponse._Fields, Object) - Method in class alluxio.thrift.CancelUfsFileTResponse
 
setFieldValue(CheckConsistencyTOptions._Fields, Object) - Method in class alluxio.thrift.CheckConsistencyTOptions
 
setFieldValue(CheckConsistencyTResponse._Fields, Object) - Method in class alluxio.thrift.CheckConsistencyTResponse
 
setFieldValue(CloseUfsFileTOptions._Fields, Object) - Method in class alluxio.thrift.CloseUfsFileTOptions
 
setFieldValue(CloseUfsFileTResponse._Fields, Object) - Method in class alluxio.thrift.CloseUfsFileTResponse
 
setFieldValue(Command._Fields, Object) - Method in class alluxio.thrift.Command
 
setFieldValue(CommandLineJobInfo._Fields, Object) - Method in class alluxio.thrift.CommandLineJobInfo
 
setFieldValue(CommitBlockTOptions._Fields, Object) - Method in class alluxio.thrift.CommitBlockTOptions
 
setFieldValue(CommitBlockTResponse._Fields, Object) - Method in class alluxio.thrift.CommitBlockTResponse
 
setFieldValue(CompleteFileTOptions._Fields, Object) - Method in class alluxio.thrift.CompleteFileTOptions
 
setFieldValue(CompleteFileTResponse._Fields, Object) - Method in class alluxio.thrift.CompleteFileTResponse
 
setFieldValue(CompletePartitionTOptions._Fields, Object) - Method in class alluxio.thrift.CompletePartitionTOptions
 
setFieldValue(CompletePartitionTResponse._Fields, Object) - Method in class alluxio.thrift.CompletePartitionTResponse
 
setFieldValue(CompleteStoreTOptions._Fields, Object) - Method in class alluxio.thrift.CompleteStoreTOptions
 
setFieldValue(CompleteStoreTResponse._Fields, Object) - Method in class alluxio.thrift.CompleteStoreTResponse
 
setFieldValue(CompleteUfsFileTOptions._Fields, Object) - Method in class alluxio.thrift.CompleteUfsFileTOptions
 
setFieldValue(CompleteUfsFileTReponse._Fields, Object) - Method in class alluxio.thrift.CompleteUfsFileTReponse
 
setFieldValue(ConfigCheckReport._Fields, Object) - Method in class alluxio.thrift.ConfigCheckReport
 
setFieldValue(ConfigProperty._Fields, Object) - Method in class alluxio.thrift.ConfigProperty
 
setFieldValue(CreateDirectoryTOptions._Fields, Object) - Method in class alluxio.thrift.CreateDirectoryTOptions
 
setFieldValue(CreateDirectoryTResponse._Fields, Object) - Method in class alluxio.thrift.CreateDirectoryTResponse
 
setFieldValue(CreateFileTOptions._Fields, Object) - Method in class alluxio.thrift.CreateFileTOptions
 
setFieldValue(CreateFileTResponse._Fields, Object) - Method in class alluxio.thrift.CreateFileTResponse
 
setFieldValue(CreateLineageTOptions._Fields, Object) - Method in class alluxio.thrift.CreateLineageTOptions
 
setFieldValue(CreateLineageTResponse._Fields, Object) - Method in class alluxio.thrift.CreateLineageTResponse
 
setFieldValue(CreateStoreTOptions._Fields, Object) - Method in class alluxio.thrift.CreateStoreTOptions
 
setFieldValue(CreateStoreTResponse._Fields, Object) - Method in class alluxio.thrift.CreateStoreTResponse
 
setFieldValue(CreateUfsFileTOptions._Fields, Object) - Method in class alluxio.thrift.CreateUfsFileTOptions
 
setFieldValue(CreateUfsFileTResponse._Fields, Object) - Method in class alluxio.thrift.CreateUfsFileTResponse
 
setFieldValue(DeleteLineageTOptions._Fields, Object) - Method in class alluxio.thrift.DeleteLineageTOptions
 
setFieldValue(DeleteLineageTResponse._Fields, Object) - Method in class alluxio.thrift.DeleteLineageTResponse
 
setFieldValue(DeleteStoreTOptions._Fields, Object) - Method in class alluxio.thrift.DeleteStoreTOptions
 
setFieldValue(DeleteStoreTResponse._Fields, Object) - Method in class alluxio.thrift.DeleteStoreTResponse
 
setFieldValue(DeleteTOptions._Fields, Object) - Method in class alluxio.thrift.DeleteTOptions
 
setFieldValue(DeleteTResponse._Fields, Object) - Method in class alluxio.thrift.DeleteTResponse
 
setFieldValue(DependencyInfo._Fields, Object) - Method in class alluxio.thrift.DependencyInfo
 
setFieldValue(FileBlockInfo._Fields, Object) - Method in class alluxio.thrift.FileBlockInfo
 
setFieldValue(FileInfo._Fields, Object) - Method in class alluxio.thrift.FileInfo
 
setFieldValue(FileSystemCommand._Fields, Object) - Method in class alluxio.thrift.FileSystemCommand
 
setFieldValue(FileSystemHeartbeatTOptions._Fields, Object) - Method in class alluxio.thrift.FileSystemHeartbeatTOptions
 
setFieldValue(FileSystemHeartbeatTResponse._Fields, Object) - Method in class alluxio.thrift.FileSystemHeartbeatTResponse
 
setFieldValue(FileSystemMasterClientService.checkConsistency_args._Fields, Object) - Method in class alluxio.thrift.FileSystemMasterClientService.checkConsistency_args
 
setFieldValue(FileSystemMasterClientService.checkConsistency_result._Fields, Object) - Method in class alluxio.thrift.FileSystemMasterClientService.checkConsistency_result
 
setFieldValue(FileSystemMasterClientService.completeFile_args._Fields, Object) - Method in class alluxio.thrift.FileSystemMasterClientService.completeFile_args
 
setFieldValue(FileSystemMasterClientService.completeFile_result._Fields, Object) - Method in class alluxio.thrift.FileSystemMasterClientService.completeFile_result
 
setFieldValue(FileSystemMasterClientService.createDirectory_args._Fields, Object) - Method in class alluxio.thrift.FileSystemMasterClientService.createDirectory_args
 
setFieldValue(FileSystemMasterClientService.createDirectory_result._Fields, Object) - Method in class alluxio.thrift.FileSystemMasterClientService.createDirectory_result
 
setFieldValue(FileSystemMasterClientService.createFile_args._Fields, Object) - Method in class alluxio.thrift.FileSystemMasterClientService.createFile_args
 
setFieldValue(FileSystemMasterClientService.createFile_result._Fields, Object) - Method in class alluxio.thrift.FileSystemMasterClientService.createFile_result
 
setFieldValue(FileSystemMasterClientService.free_args._Fields, Object) - Method in class alluxio.thrift.FileSystemMasterClientService.free_args
 
setFieldValue(FileSystemMasterClientService.free_result._Fields, Object) - Method in class alluxio.thrift.FileSystemMasterClientService.free_result
 
setFieldValue(FileSystemMasterClientService.getFilePath_args._Fields, Object) - Method in class alluxio.thrift.FileSystemMasterClientService.getFilePath_args
 
setFieldValue(FileSystemMasterClientService.getFilePath_result._Fields, Object) - Method in class alluxio.thrift.FileSystemMasterClientService.getFilePath_result
 
setFieldValue(FileSystemMasterClientService.getMountTable_args._Fields, Object) - Method in class alluxio.thrift.FileSystemMasterClientService.getMountTable_args
 
setFieldValue(FileSystemMasterClientService.getMountTable_result._Fields, Object) - Method in class alluxio.thrift.FileSystemMasterClientService.getMountTable_result
 
setFieldValue(FileSystemMasterClientService.getNewBlockIdForFile_args._Fields, Object) - Method in class alluxio.thrift.FileSystemMasterClientService.getNewBlockIdForFile_args
 
setFieldValue(FileSystemMasterClientService.getNewBlockIdForFile_result._Fields, Object) - Method in class alluxio.thrift.FileSystemMasterClientService.getNewBlockIdForFile_result
 
setFieldValue(FileSystemMasterClientService.getStatus_args._Fields, Object) - Method in class alluxio.thrift.FileSystemMasterClientService.getStatus_args
 
setFieldValue(FileSystemMasterClientService.getStatus_result._Fields, Object) - Method in class alluxio.thrift.FileSystemMasterClientService.getStatus_result
 
setFieldValue(FileSystemMasterClientService.listStatus_args._Fields, Object) - Method in class alluxio.thrift.FileSystemMasterClientService.listStatus_args
 
setFieldValue(FileSystemMasterClientService.listStatus_result._Fields, Object) - Method in class alluxio.thrift.FileSystemMasterClientService.listStatus_result
 
setFieldValue(FileSystemMasterClientService.loadMetadata_args._Fields, Object) - Method in class alluxio.thrift.FileSystemMasterClientService.loadMetadata_args
 
setFieldValue(FileSystemMasterClientService.loadMetadata_result._Fields, Object) - Method in class alluxio.thrift.FileSystemMasterClientService.loadMetadata_result
 
setFieldValue(FileSystemMasterClientService.mount_args._Fields, Object) - Method in class alluxio.thrift.FileSystemMasterClientService.mount_args
 
setFieldValue(FileSystemMasterClientService.mount_result._Fields, Object) - Method in class alluxio.thrift.FileSystemMasterClientService.mount_result
 
setFieldValue(FileSystemMasterClientService.remove_args._Fields, Object) - Method in class alluxio.thrift.FileSystemMasterClientService.remove_args
 
setFieldValue(FileSystemMasterClientService.remove_result._Fields, Object) - Method in class alluxio.thrift.FileSystemMasterClientService.remove_result
 
setFieldValue(FileSystemMasterClientService.rename_args._Fields, Object) - Method in class alluxio.thrift.FileSystemMasterClientService.rename_args
 
setFieldValue(FileSystemMasterClientService.rename_result._Fields, Object) - Method in class alluxio.thrift.FileSystemMasterClientService.rename_result
 
setFieldValue(FileSystemMasterClientService.scheduleAsyncPersistence_args._Fields, Object) - Method in class alluxio.thrift.FileSystemMasterClientService.scheduleAsyncPersistence_args
 
setFieldValue(FileSystemMasterClientService.scheduleAsyncPersistence_result._Fields, Object) - Method in class alluxio.thrift.FileSystemMasterClientService.scheduleAsyncPersistence_result
 
setFieldValue(FileSystemMasterClientService.setAttribute_args._Fields, Object) - Method in class alluxio.thrift.FileSystemMasterClientService.setAttribute_args
 
setFieldValue(FileSystemMasterClientService.setAttribute_result._Fields, Object) - Method in class alluxio.thrift.FileSystemMasterClientService.setAttribute_result
 
setFieldValue(FileSystemMasterClientService.unmount_args._Fields, Object) - Method in class alluxio.thrift.FileSystemMasterClientService.unmount_args
 
setFieldValue(FileSystemMasterClientService.unmount_result._Fields, Object) - Method in class alluxio.thrift.FileSystemMasterClientService.unmount_result
 
setFieldValue(FileSystemMasterClientService.updateUfsMode_args._Fields, Object) - Method in class alluxio.thrift.FileSystemMasterClientService.updateUfsMode_args
 
setFieldValue(FileSystemMasterClientService.updateUfsMode_result._Fields, Object) - Method in class alluxio.thrift.FileSystemMasterClientService.updateUfsMode_result
 
setFieldValue(FileSystemMasterCommonTOptions._Fields, Object) - Method in class alluxio.thrift.FileSystemMasterCommonTOptions
 
setFieldValue(FileSystemMasterWorkerService.fileSystemHeartbeat_args._Fields, Object) - Method in class alluxio.thrift.FileSystemMasterWorkerService.fileSystemHeartbeat_args
 
setFieldValue(FileSystemMasterWorkerService.fileSystemHeartbeat_result._Fields, Object) - Method in class alluxio.thrift.FileSystemMasterWorkerService.fileSystemHeartbeat_result
 
setFieldValue(FileSystemMasterWorkerService.getFileInfo_args._Fields, Object) - Method in class alluxio.thrift.FileSystemMasterWorkerService.getFileInfo_args
 
setFieldValue(FileSystemMasterWorkerService.getFileInfo_result._Fields, Object) - Method in class alluxio.thrift.FileSystemMasterWorkerService.getFileInfo_result
 
setFieldValue(FileSystemMasterWorkerService.getPinnedFileIds_args._Fields, Object) - Method in class alluxio.thrift.FileSystemMasterWorkerService.getPinnedFileIds_args
 
setFieldValue(FileSystemMasterWorkerService.getPinnedFileIds_result._Fields, Object) - Method in class alluxio.thrift.FileSystemMasterWorkerService.getPinnedFileIds_result
 
setFieldValue(FileSystemMasterWorkerService.getUfsInfo_args._Fields, Object) - Method in class alluxio.thrift.FileSystemMasterWorkerService.getUfsInfo_args
 
setFieldValue(FileSystemMasterWorkerService.getUfsInfo_result._Fields, Object) - Method in class alluxio.thrift.FileSystemMasterWorkerService.getUfsInfo_result
 
setFieldValue(FileSystemWorkerClientService.cancelUfsFile_args._Fields, Object) - Method in class alluxio.thrift.FileSystemWorkerClientService.cancelUfsFile_args
 
setFieldValue(FileSystemWorkerClientService.cancelUfsFile_result._Fields, Object) - Method in class alluxio.thrift.FileSystemWorkerClientService.cancelUfsFile_result
 
setFieldValue(FileSystemWorkerClientService.closeUfsFile_args._Fields, Object) - Method in class alluxio.thrift.FileSystemWorkerClientService.closeUfsFile_args
 
setFieldValue(FileSystemWorkerClientService.closeUfsFile_result._Fields, Object) - Method in class alluxio.thrift.FileSystemWorkerClientService.closeUfsFile_result
 
setFieldValue(FileSystemWorkerClientService.completeUfsFile_args._Fields, Object) - Method in class alluxio.thrift.FileSystemWorkerClientService.completeUfsFile_args
 
setFieldValue(FileSystemWorkerClientService.completeUfsFile_result._Fields, Object) - Method in class alluxio.thrift.FileSystemWorkerClientService.completeUfsFile_result
 
setFieldValue(FileSystemWorkerClientService.createUfsFile_args._Fields, Object) - Method in class alluxio.thrift.FileSystemWorkerClientService.createUfsFile_args
 
setFieldValue(FileSystemWorkerClientService.createUfsFile_result._Fields, Object) - Method in class alluxio.thrift.FileSystemWorkerClientService.createUfsFile_result
 
setFieldValue(FileSystemWorkerClientService.openUfsFile_args._Fields, Object) - Method in class alluxio.thrift.FileSystemWorkerClientService.openUfsFile_args
 
setFieldValue(FileSystemWorkerClientService.openUfsFile_result._Fields, Object) - Method in class alluxio.thrift.FileSystemWorkerClientService.openUfsFile_result
 
setFieldValue(FileSystemWorkerClientService.sessionFileSystemHeartbeat_args._Fields, Object) - Method in class alluxio.thrift.FileSystemWorkerClientService.sessionFileSystemHeartbeat_args
 
setFieldValue(FileSystemWorkerClientService.sessionFileSystemHeartbeat_result._Fields, Object) - Method in class alluxio.thrift.FileSystemWorkerClientService.sessionFileSystemHeartbeat_result
 
setFieldValue(FreeTOptions._Fields, Object) - Method in class alluxio.thrift.FreeTOptions
 
setFieldValue(FreeTResponse._Fields, Object) - Method in class alluxio.thrift.FreeTResponse
 
setFieldValue(GetBlockInfoTOptions._Fields, Object) - Method in class alluxio.thrift.GetBlockInfoTOptions
 
setFieldValue(GetBlockInfoTResponse._Fields, Object) - Method in class alluxio.thrift.GetBlockInfoTResponse
 
setFieldValue(GetBlockMasterInfoTOptions._Fields, Object) - Method in class alluxio.thrift.GetBlockMasterInfoTOptions
 
setFieldValue(GetBlockMasterInfoTResponse._Fields, Object) - Method in class alluxio.thrift.GetBlockMasterInfoTResponse
 
setFieldValue(GetCapacityBytesTOptions._Fields, Object) - Method in class alluxio.thrift.GetCapacityBytesTOptions
 
setFieldValue(GetCapacityBytesTResponse._Fields, Object) - Method in class alluxio.thrift.GetCapacityBytesTResponse
 
setFieldValue(GetConfigReportTOptions._Fields, Object) - Method in class alluxio.thrift.GetConfigReportTOptions
 
setFieldValue(GetConfigReportTResponse._Fields, Object) - Method in class alluxio.thrift.GetConfigReportTResponse
 
setFieldValue(GetConfigurationTOptions._Fields, Object) - Method in class alluxio.thrift.GetConfigurationTOptions
 
setFieldValue(GetConfigurationTResponse._Fields, Object) - Method in class alluxio.thrift.GetConfigurationTResponse
 
setFieldValue(GetFileInfoTOptions._Fields, Object) - Method in class alluxio.thrift.GetFileInfoTOptions
 
setFieldValue(GetFileInfoTResponse._Fields, Object) - Method in class alluxio.thrift.GetFileInfoTResponse
 
setFieldValue(GetFilePathTOptions._Fields, Object) - Method in class alluxio.thrift.GetFilePathTOptions
 
setFieldValue(GetFilePathTResponse._Fields, Object) - Method in class alluxio.thrift.GetFilePathTResponse
 
setFieldValue(GetLineageInfoListTOptions._Fields, Object) - Method in class alluxio.thrift.GetLineageInfoListTOptions
 
setFieldValue(GetLineageInfoListTResponse._Fields, Object) - Method in class alluxio.thrift.GetLineageInfoListTResponse
 
setFieldValue(GetMasterIdTOptions._Fields, Object) - Method in class alluxio.thrift.GetMasterIdTOptions
 
setFieldValue(GetMasterIdTResponse._Fields, Object) - Method in class alluxio.thrift.GetMasterIdTResponse
 
setFieldValue(GetMasterInfoTOptions._Fields, Object) - Method in class alluxio.thrift.GetMasterInfoTOptions
 
setFieldValue(GetMasterInfoTResponse._Fields, Object) - Method in class alluxio.thrift.GetMasterInfoTResponse
 
setFieldValue(GetMetricsTOptions._Fields, Object) - Method in class alluxio.thrift.GetMetricsTOptions
 
setFieldValue(GetMetricsTResponse._Fields, Object) - Method in class alluxio.thrift.GetMetricsTResponse
 
setFieldValue(GetMountTableTResponse._Fields, Object) - Method in class alluxio.thrift.GetMountTableTResponse
 
setFieldValue(GetNewBlockIdForFileTOptions._Fields, Object) - Method in class alluxio.thrift.GetNewBlockIdForFileTOptions
 
setFieldValue(GetNewBlockIdForFileTResponse._Fields, Object) - Method in class alluxio.thrift.GetNewBlockIdForFileTResponse
 
setFieldValue(GetNextKeysTOptions._Fields, Object) - Method in class alluxio.thrift.GetNextKeysTOptions
 
setFieldValue(GetNextKeysTResponse._Fields, Object) - Method in class alluxio.thrift.GetNextKeysTResponse
 
setFieldValue(GetPartitionInfoTOptions._Fields, Object) - Method in class alluxio.thrift.GetPartitionInfoTOptions
 
setFieldValue(GetPartitionInfoTResponse._Fields, Object) - Method in class alluxio.thrift.GetPartitionInfoTResponse
 
setFieldValue(GetPinnedFileIdsTOptions._Fields, Object) - Method in class alluxio.thrift.GetPinnedFileIdsTOptions
 
setFieldValue(GetPinnedFileIdsTResponse._Fields, Object) - Method in class alluxio.thrift.GetPinnedFileIdsTResponse
 
setFieldValue(GetServiceVersionTOptions._Fields, Object) - Method in class alluxio.thrift.GetServiceVersionTOptions
 
setFieldValue(GetServiceVersionTResponse._Fields, Object) - Method in class alluxio.thrift.GetServiceVersionTResponse
 
setFieldValue(GetSizeTOptions._Fields, Object) - Method in class alluxio.thrift.GetSizeTOptions
 
setFieldValue(GetSizeTResponse._Fields, Object) - Method in class alluxio.thrift.GetSizeTResponse
 
setFieldValue(GetStatusTOptions._Fields, Object) - Method in class alluxio.thrift.GetStatusTOptions
 
setFieldValue(GetStatusTResponse._Fields, Object) - Method in class alluxio.thrift.GetStatusTResponse
 
setFieldValue(GetTOptions._Fields, Object) - Method in class alluxio.thrift.GetTOptions
 
setFieldValue(GetTResponse._Fields, Object) - Method in class alluxio.thrift.GetTResponse
 
setFieldValue(GetUfsInfoTOptions._Fields, Object) - Method in class alluxio.thrift.GetUfsInfoTOptions
 
setFieldValue(GetUfsInfoTResponse._Fields, Object) - Method in class alluxio.thrift.GetUfsInfoTResponse
 
setFieldValue(GetUsedBytesTOptions._Fields, Object) - Method in class alluxio.thrift.GetUsedBytesTOptions
 
setFieldValue(GetUsedBytesTResponse._Fields, Object) - Method in class alluxio.thrift.GetUsedBytesTResponse
 
setFieldValue(GetWorkerIdTOptions._Fields, Object) - Method in class alluxio.thrift.GetWorkerIdTOptions
 
setFieldValue(GetWorkerIdTResponse._Fields, Object) - Method in class alluxio.thrift.GetWorkerIdTResponse
 
setFieldValue(GetWorkerInfoListTOptions._Fields, Object) - Method in class alluxio.thrift.GetWorkerInfoListTOptions
 
setFieldValue(GetWorkerInfoListTResponse._Fields, Object) - Method in class alluxio.thrift.GetWorkerInfoListTResponse
 
setFieldValue(GetWorkerReportTOptions._Fields, Object) - Method in class alluxio.thrift.GetWorkerReportTOptions
 
setFieldValue(InconsistentProperty._Fields, Object) - Method in class alluxio.thrift.InconsistentProperty
 
setFieldValue(JobConfInfo._Fields, Object) - Method in class alluxio.thrift.JobConfInfo
 
setFieldValue(KeyValueMasterClientService.completePartition_args._Fields, Object) - Method in class alluxio.thrift.KeyValueMasterClientService.completePartition_args
 
setFieldValue(KeyValueMasterClientService.completePartition_result._Fields, Object) - Method in class alluxio.thrift.KeyValueMasterClientService.completePartition_result
 
setFieldValue(KeyValueMasterClientService.completeStore_args._Fields, Object) - Method in class alluxio.thrift.KeyValueMasterClientService.completeStore_args
 
setFieldValue(KeyValueMasterClientService.completeStore_result._Fields, Object) - Method in class alluxio.thrift.KeyValueMasterClientService.completeStore_result
 
setFieldValue(KeyValueMasterClientService.createStore_args._Fields, Object) - Method in class alluxio.thrift.KeyValueMasterClientService.createStore_args
 
setFieldValue(KeyValueMasterClientService.createStore_result._Fields, Object) - Method in class alluxio.thrift.KeyValueMasterClientService.createStore_result
 
setFieldValue(KeyValueMasterClientService.deleteStore_args._Fields, Object) - Method in class alluxio.thrift.KeyValueMasterClientService.deleteStore_args
 
setFieldValue(KeyValueMasterClientService.deleteStore_result._Fields, Object) - Method in class alluxio.thrift.KeyValueMasterClientService.deleteStore_result
 
setFieldValue(KeyValueMasterClientService.getPartitionInfo_args._Fields, Object) - Method in class alluxio.thrift.KeyValueMasterClientService.getPartitionInfo_args
 
setFieldValue(KeyValueMasterClientService.getPartitionInfo_result._Fields, Object) - Method in class alluxio.thrift.KeyValueMasterClientService.getPartitionInfo_result
 
setFieldValue(KeyValueMasterClientService.mergeStore_args._Fields, Object) - Method in class alluxio.thrift.KeyValueMasterClientService.mergeStore_args
 
setFieldValue(KeyValueMasterClientService.mergeStore_result._Fields, Object) - Method in class alluxio.thrift.KeyValueMasterClientService.mergeStore_result
 
setFieldValue(KeyValueMasterClientService.renameStore_args._Fields, Object) - Method in class alluxio.thrift.KeyValueMasterClientService.renameStore_args
 
setFieldValue(KeyValueMasterClientService.renameStore_result._Fields, Object) - Method in class alluxio.thrift.KeyValueMasterClientService.renameStore_result
 
setFieldValue(KeyValueWorkerClientService.get_args._Fields, Object) - Method in class alluxio.thrift.KeyValueWorkerClientService.get_args
 
setFieldValue(KeyValueWorkerClientService.get_result._Fields, Object) - Method in class alluxio.thrift.KeyValueWorkerClientService.get_result
 
setFieldValue(KeyValueWorkerClientService.getNextKeys_args._Fields, Object) - Method in class alluxio.thrift.KeyValueWorkerClientService.getNextKeys_args
 
setFieldValue(KeyValueWorkerClientService.getNextKeys_result._Fields, Object) - Method in class alluxio.thrift.KeyValueWorkerClientService.getNextKeys_result
 
setFieldValue(KeyValueWorkerClientService.getSize_args._Fields, Object) - Method in class alluxio.thrift.KeyValueWorkerClientService.getSize_args
 
setFieldValue(KeyValueWorkerClientService.getSize_result._Fields, Object) - Method in class alluxio.thrift.KeyValueWorkerClientService.getSize_result
 
setFieldValue(LineageInfo._Fields, Object) - Method in class alluxio.thrift.LineageInfo
 
setFieldValue(LineageMasterClientService.createLineage_args._Fields, Object) - Method in class alluxio.thrift.LineageMasterClientService.createLineage_args
 
setFieldValue(LineageMasterClientService.createLineage_result._Fields, Object) - Method in class alluxio.thrift.LineageMasterClientService.createLineage_result
 
setFieldValue(LineageMasterClientService.deleteLineage_args._Fields, Object) - Method in class alluxio.thrift.LineageMasterClientService.deleteLineage_args
 
setFieldValue(LineageMasterClientService.deleteLineage_result._Fields, Object) - Method in class alluxio.thrift.LineageMasterClientService.deleteLineage_result
 
setFieldValue(LineageMasterClientService.getLineageInfoList_args._Fields, Object) - Method in class alluxio.thrift.LineageMasterClientService.getLineageInfoList_args
 
setFieldValue(LineageMasterClientService.getLineageInfoList_result._Fields, Object) - Method in class alluxio.thrift.LineageMasterClientService.getLineageInfoList_result
 
setFieldValue(LineageMasterClientService.reinitializeFile_args._Fields, Object) - Method in class alluxio.thrift.LineageMasterClientService.reinitializeFile_args
 
setFieldValue(LineageMasterClientService.reinitializeFile_result._Fields, Object) - Method in class alluxio.thrift.LineageMasterClientService.reinitializeFile_result
 
setFieldValue(LineageMasterClientService.reportLostFile_args._Fields, Object) - Method in class alluxio.thrift.LineageMasterClientService.reportLostFile_args
 
setFieldValue(LineageMasterClientService.reportLostFile_result._Fields, Object) - Method in class alluxio.thrift.LineageMasterClientService.reportLostFile_result
 
setFieldValue(ListStatusTOptions._Fields, Object) - Method in class alluxio.thrift.ListStatusTOptions
 
setFieldValue(ListStatusTResponse._Fields, Object) - Method in class alluxio.thrift.ListStatusTResponse
 
setFieldValue(LoadMetadataTOptions._Fields, Object) - Method in class alluxio.thrift.LoadMetadataTOptions
 
setFieldValue(LoadMetadataTResponse._Fields, Object) - Method in class alluxio.thrift.LoadMetadataTResponse
 
setFieldValue(LocalityTier._Fields, Object) - Method in class alluxio.thrift.LocalityTier
 
setFieldValue(LockBlockTOptions._Fields, Object) - Method in class alluxio.thrift.LockBlockTOptions
 
setFieldValue(LockBlockTResponse._Fields, Object) - Method in class alluxio.thrift.LockBlockTResponse
 
setFieldValue(MasterHeartbeatTOptions._Fields, Object) - Method in class alluxio.thrift.MasterHeartbeatTOptions
 
setFieldValue(MasterHeartbeatTResponse._Fields, Object) - Method in class alluxio.thrift.MasterHeartbeatTResponse
 
setFieldValue(MasterInfo._Fields, Object) - Method in class alluxio.thrift.MasterInfo
 
setFieldValue(MasterNetAddress._Fields, Object) - Method in class alluxio.thrift.MasterNetAddress
 
setFieldValue(MergeStoreTOptions._Fields, Object) - Method in class alluxio.thrift.MergeStoreTOptions
 
setFieldValue(MergeStoreTResponse._Fields, Object) - Method in class alluxio.thrift.MergeStoreTResponse
 
setFieldValue(MetaMasterClientService.backup_args._Fields, Object) - Method in class alluxio.thrift.MetaMasterClientService.backup_args
 
setFieldValue(MetaMasterClientService.backup_result._Fields, Object) - Method in class alluxio.thrift.MetaMasterClientService.backup_result
 
setFieldValue(MetaMasterClientService.getConfigReport_args._Fields, Object) - Method in class alluxio.thrift.MetaMasterClientService.getConfigReport_args
 
setFieldValue(MetaMasterClientService.getConfigReport_result._Fields, Object) - Method in class alluxio.thrift.MetaMasterClientService.getConfigReport_result
 
setFieldValue(MetaMasterClientService.getConfiguration_args._Fields, Object) - Method in class alluxio.thrift.MetaMasterClientService.getConfiguration_args
 
setFieldValue(MetaMasterClientService.getConfiguration_result._Fields, Object) - Method in class alluxio.thrift.MetaMasterClientService.getConfiguration_result
 
setFieldValue(MetaMasterClientService.getMasterInfo_args._Fields, Object) - Method in class alluxio.thrift.MetaMasterClientService.getMasterInfo_args
 
setFieldValue(MetaMasterClientService.getMasterInfo_result._Fields, Object) - Method in class alluxio.thrift.MetaMasterClientService.getMasterInfo_result
 
setFieldValue(MetaMasterClientService.getMetrics_args._Fields, Object) - Method in class alluxio.thrift.MetaMasterClientService.getMetrics_args
 
setFieldValue(MetaMasterClientService.getMetrics_result._Fields, Object) - Method in class alluxio.thrift.MetaMasterClientService.getMetrics_result
 
setFieldValue(MetaMasterMasterService.getMasterId_args._Fields, Object) - Method in class alluxio.thrift.MetaMasterMasterService.getMasterId_args
 
setFieldValue(MetaMasterMasterService.getMasterId_result._Fields, Object) - Method in class alluxio.thrift.MetaMasterMasterService.getMasterId_result
 
setFieldValue(MetaMasterMasterService.masterHeartbeat_args._Fields, Object) - Method in class alluxio.thrift.MetaMasterMasterService.masterHeartbeat_args
 
setFieldValue(MetaMasterMasterService.masterHeartbeat_result._Fields, Object) - Method in class alluxio.thrift.MetaMasterMasterService.masterHeartbeat_result
 
setFieldValue(MetaMasterMasterService.registerMaster_args._Fields, Object) - Method in class alluxio.thrift.MetaMasterMasterService.registerMaster_args
 
setFieldValue(MetaMasterMasterService.registerMaster_result._Fields, Object) - Method in class alluxio.thrift.MetaMasterMasterService.registerMaster_result
 
setFieldValue(Metric._Fields, Object) - Method in class alluxio.thrift.Metric
 
setFieldValue(MetricsHeartbeatTOptions._Fields, Object) - Method in class alluxio.thrift.MetricsHeartbeatTOptions
 
setFieldValue(MetricsHeartbeatTResponse._Fields, Object) - Method in class alluxio.thrift.MetricsHeartbeatTResponse
 
setFieldValue(MetricsMasterClientService.metricsHeartbeat_args._Fields, Object) - Method in class alluxio.thrift.MetricsMasterClientService.metricsHeartbeat_args
 
setFieldValue(MetricsMasterClientService.metricsHeartbeat_result._Fields, Object) - Method in class alluxio.thrift.MetricsMasterClientService.metricsHeartbeat_result
 
setFieldValue(MetricValue._Fields, Object) - Method in class alluxio.thrift.MetricValue
 
setFieldValue(MountPointInfo._Fields, Object) - Method in class alluxio.thrift.MountPointInfo
 
setFieldValue(MountTOptions._Fields, Object) - Method in class alluxio.thrift.MountTOptions
 
setFieldValue(MountTResponse._Fields, Object) - Method in class alluxio.thrift.MountTResponse
 
setFieldValue(OpenUfsFileTOptions._Fields, Object) - Method in class alluxio.thrift.OpenUfsFileTOptions
 
setFieldValue(OpenUfsFileTResponse._Fields, Object) - Method in class alluxio.thrift.OpenUfsFileTResponse
 
setFieldValue(OptionalString._Fields, Object) - Method in class alluxio.thrift.OptionalString
 
setFieldValue(PartitionInfo._Fields, Object) - Method in class alluxio.thrift.PartitionInfo
 
setFieldValue(PersistCommandOptions._Fields, Object) - Method in class alluxio.thrift.PersistCommandOptions
 
setFieldValue(PersistFile._Fields, Object) - Method in class alluxio.thrift.PersistFile
 
setFieldValue(PromoteBlockTOptions._Fields, Object) - Method in class alluxio.thrift.PromoteBlockTOptions
 
setFieldValue(PromoteBlockTResponse._Fields, Object) - Method in class alluxio.thrift.PromoteBlockTResponse
 
setFieldValue(RegisterMasterTOptions._Fields, Object) - Method in class alluxio.thrift.RegisterMasterTOptions
 
setFieldValue(RegisterMasterTResponse._Fields, Object) - Method in class alluxio.thrift.RegisterMasterTResponse
 
setFieldValue(RegisterWorkerTOptions._Fields, Object) - Method in class alluxio.thrift.RegisterWorkerTOptions
 
setFieldValue(RegisterWorkerTResponse._Fields, Object) - Method in class alluxio.thrift.RegisterWorkerTResponse
 
setFieldValue(ReinitializeFileTOptions._Fields, Object) - Method in class alluxio.thrift.ReinitializeFileTOptions
 
setFieldValue(ReinitializeFileTResponse._Fields, Object) - Method in class alluxio.thrift.ReinitializeFileTResponse
 
setFieldValue(RemoveBlockTOptions._Fields, Object) - Method in class alluxio.thrift.RemoveBlockTOptions
 
setFieldValue(RemoveBlockTResponse._Fields, Object) - Method in class alluxio.thrift.RemoveBlockTResponse
 
setFieldValue(RenameStoreTOptions._Fields, Object) - Method in class alluxio.thrift.RenameStoreTOptions
 
setFieldValue(RenameStoreTResponse._Fields, Object) - Method in class alluxio.thrift.RenameStoreTResponse
 
setFieldValue(RenameTOptions._Fields, Object) - Method in class alluxio.thrift.RenameTOptions
 
setFieldValue(RenameTResponse._Fields, Object) - Method in class alluxio.thrift.RenameTResponse
 
setFieldValue(ReportLostFileTOptions._Fields, Object) - Method in class alluxio.thrift.ReportLostFileTOptions
 
setFieldValue(ReportLostFileTResponse._Fields, Object) - Method in class alluxio.thrift.ReportLostFileTResponse
 
setFieldValue(RequestBlockLocationTOptions._Fields, Object) - Method in class alluxio.thrift.RequestBlockLocationTOptions
 
setFieldValue(RequestBlockLocationTResponse._Fields, Object) - Method in class alluxio.thrift.RequestBlockLocationTResponse
 
setFieldValue(RequestSpaceTOptions._Fields, Object) - Method in class alluxio.thrift.RequestSpaceTOptions
 
setFieldValue(RequestSpaceTResponse._Fields, Object) - Method in class alluxio.thrift.RequestSpaceTResponse
 
setFieldValue(ScheduleAsyncPersistenceTOptions._Fields, Object) - Method in class alluxio.thrift.ScheduleAsyncPersistenceTOptions
 
setFieldValue(ScheduleAsyncPersistenceTResponse._Fields, Object) - Method in class alluxio.thrift.ScheduleAsyncPersistenceTResponse
 
setFieldValue(SessionBlockHeartbeatTOptions._Fields, Object) - Method in class alluxio.thrift.SessionBlockHeartbeatTOptions
 
setFieldValue(SessionBlockHeartbeatTResponse._Fields, Object) - Method in class alluxio.thrift.SessionBlockHeartbeatTResponse
 
setFieldValue(SessionFileSystemHeartbeatTOptions._Fields, Object) - Method in class alluxio.thrift.SessionFileSystemHeartbeatTOptions
 
setFieldValue(SessionFileSystemHeartbeatTResponse._Fields, Object) - Method in class alluxio.thrift.SessionFileSystemHeartbeatTResponse
 
setFieldValue(SetAttributeTOptions._Fields, Object) - Method in class alluxio.thrift.SetAttributeTOptions
 
setFieldValue(SetAttributeTResponse._Fields, Object) - Method in class alluxio.thrift.SetAttributeTResponse
 
setFieldValue(SyncMetadataTOptions._Fields, Object) - Method in class alluxio.thrift.SyncMetadataTOptions
 
setFieldValue(SyncMetadataTResponse._Fields, Object) - Method in class alluxio.thrift.SyncMetadataTResponse
 
setFieldValue(TieredIdentity._Fields, Object) - Method in class alluxio.thrift.TieredIdentity
 
setFieldValue(UfsInfo._Fields, Object) - Method in class alluxio.thrift.UfsInfo
 
setFieldValue(UnlockBlockTOptions._Fields, Object) - Method in class alluxio.thrift.UnlockBlockTOptions
 
setFieldValue(UnlockBlockTResponse._Fields, Object) - Method in class alluxio.thrift.UnlockBlockTResponse
 
setFieldValue(UnmountTOptions._Fields, Object) - Method in class alluxio.thrift.UnmountTOptions
 
setFieldValue(UnmountTResponse._Fields, Object) - Method in class alluxio.thrift.UnmountTResponse
 
setFieldValue(UpdateUfsModeTOptions._Fields, Object) - Method in class alluxio.thrift.UpdateUfsModeTOptions
 
setFieldValue(UpdateUfsModeTResponse._Fields, Object) - Method in class alluxio.thrift.UpdateUfsModeTResponse
 
setFieldValue(WorkerInfo._Fields, Object) - Method in class alluxio.thrift.WorkerInfo
 
setFieldValue(WorkerNetAddress._Fields, Object) - Method in class alluxio.thrift.WorkerNetAddress
 
setFileBlockInfos(List<FileBlockInfo>) - Method in class alluxio.thrift.FileInfo
 
setFileBlockInfos(List<FileBlockInfo>) - Method in class alluxio.wire.FileInfo
 
setFileBlockInfosIsSet(boolean) - Method in class alluxio.thrift.FileInfo
 
setFileId(long) - Method in class alluxio.proto.journal.File.AsyncPersistRequestEntry.Builder
optional int64 file_id = 1;
setFileId(long) - Method in class alluxio.thrift.FileInfo
 
setFileId(long) - Method in class alluxio.thrift.FileSystemMasterWorkerService.getFileInfo_args
the id of the file
setFileId(long) - Method in class alluxio.thrift.GetFilePathTOptions
 
setFileId(long) - Method in class alluxio.thrift.PersistFile
 
setFileId(long) - Method in class alluxio.wire.FileInfo
 
setFileIdIsSet(boolean) - Method in class alluxio.thrift.FileInfo
 
setFileIdIsSet(boolean) - Method in class alluxio.thrift.FileSystemMasterWorkerService.getFileInfo_args
 
setFileIdIsSet(boolean) - Method in class alluxio.thrift.GetFilePathTOptions
 
setFileIdIsSet(boolean) - Method in class alluxio.thrift.PersistFile
 
setFileInfo(FileInfo) - Method in class alluxio.thrift.GetFileInfoTResponse
 
setFileInfo(FileInfo) - Method in class alluxio.thrift.GetStatusTResponse
 
setFileInfoIsSet(boolean) - Method in class alluxio.thrift.GetFileInfoTResponse
 
setFileInfoIsSet(boolean) - Method in class alluxio.thrift.GetStatusTResponse
 
setFileInfoList(List<FileInfo>) - Method in class alluxio.thrift.ListStatusTResponse
 
setFileInfoListIsSet(boolean) - Method in class alluxio.thrift.ListStatusTResponse
 
setFileLocations(List<String>) - Method in class alluxio.web.UIFileInfo
 
setFilter(Set<BlockMasterInfoField>) - Method in class alluxio.thrift.GetBlockMasterInfoTOptions
 
setFilter(Set<MasterInfoField>) - Method in class alluxio.thrift.GetMasterInfoTOptions
 
setFilterIsSet(boolean) - Method in class alluxio.thrift.GetBlockMasterInfoTOptions
 
setFilterIsSet(boolean) - Method in class alluxio.thrift.GetMasterInfoTOptions
 
setFirst(T1) - Method in class alluxio.collections.Pair
Set the first value.
setFirst(LockedInodePath) - Method in class alluxio.master.file.meta.InodePathPair
 
setFolder(boolean) - Method in class alluxio.thrift.FileInfo
 
setFolder(boolean) - Method in class alluxio.wire.FileInfo
 
setFolderIsSet(boolean) - Method in class alluxio.thrift.FileInfo
 
setForced(boolean) - Method in class alluxio.client.file.options.FreeOptions
Sets the forced flag.
setForced(boolean) - Method in class alluxio.master.file.options.FreeOptions
Sets the forced flag.
setForced(boolean) - Method in class alluxio.thrift.FreeTOptions
 
setForcedIsSet(boolean) - Method in class alluxio.thrift.FreeTOptions
 
setFreeBytes(long) - Method in class alluxio.thrift.BlockMasterInfo
 
setFreeBytes(long) - Method in class alluxio.wire.BlockMasterInfo
 
setFreeBytesIsSet(boolean) - Method in class alluxio.thrift.BlockMasterInfo
 
setFromPath(String) - Method in class alluxio.thrift.KeyValueMasterClientService.mergeStore_args
the path of the store to be merged
setFromPathIsSet(boolean) - Method in class alluxio.thrift.KeyValueMasterClientService.mergeStore_args
 
setFromStoreId(long) - Method in class alluxio.proto.journal.KeyValue.MergeStoreEntry.Builder
optional int64 from_store_id = 1;
setFsType(String) - Method in class alluxio.util.UnixMountInfo.Builder
 
setGcExecutor(ScheduledExecutorService) - Method in class alluxio.resource.DynamicResourcePool.Options
 
setGcIntervalMs(long) - Method in class alluxio.resource.DynamicResourcePool.Options
 
setGroup(String) - Method in class alluxio.client.file.options.CompleteUfsFileOptions
 
setGroup(String) - Method in class alluxio.client.file.options.CreateUfsFileOptions
 
setGroup(String) - Method in class alluxio.client.file.options.OutStreamOptions
 
setGroup(String) - Method in class alluxio.client.file.options.SetAttributeOptions
 
setGroup(String) - Method in class alluxio.master.file.meta.Inode
 
setGroup(String) - Method in class alluxio.master.file.options.CreatePathOptions
 
setGroup(String) - Method in class alluxio.master.file.options.SetAttributeOptions
 
setGroup(String) - Method in class alluxio.proto.dataserver.Protocol.CreateUfsFileOptions.Builder
optional string group = 3;
setGroup(String) - Method in class alluxio.proto.journal.File.InodeDirectoryEntry.Builder
optional string group = 9;
setGroup(String) - Method in class alluxio.proto.journal.File.InodeFileEntry.Builder
optional string group = 15;
setGroup(String) - Method in class alluxio.proto.journal.File.SetAttributeEntry.Builder
optional string group = 7;
setGroup(String) - Method in class alluxio.thrift.CompleteUfsFileTOptions
 
setGroup(String) - Method in class alluxio.thrift.CreateUfsFileTOptions
 
setGroup(String) - Method in class alluxio.thrift.FileInfo
 
setGroup(String) - Method in class alluxio.thrift.SetAttributeTOptions
 
setGroup(String) - Method in class alluxio.underfs.options.CreateOptions
 
setGroup(String) - Method in class alluxio.underfs.options.MkdirsOptions
 
setGroup(String) - Method in class alluxio.wire.FileInfo
 
setGroupBits(Mode.Bits) - Method in class alluxio.security.authorization.Mode
Sets group bits.
setGroupBytes(ByteString) - Method in class alluxio.proto.dataserver.Protocol.CreateUfsFileOptions.Builder
optional string group = 3;
setGroupBytes(ByteString) - Method in class alluxio.proto.journal.File.InodeDirectoryEntry.Builder
optional string group = 9;
setGroupBytes(ByteString) - Method in class alluxio.proto.journal.File.InodeFileEntry.Builder
optional string group = 15;
setGroupBytes(ByteString) - Method in class alluxio.proto.journal.File.SetAttributeEntry.Builder
optional string group = 7;
setGroupIsSet(boolean) - Method in class alluxio.thrift.CompleteUfsFileTOptions
 
setGroupIsSet(boolean) - Method in class alluxio.thrift.CreateUfsFileTOptions
 
setGroupIsSet(boolean) - Method in class alluxio.thrift.FileInfo
 
setGroupIsSet(boolean) - Method in class alluxio.thrift.SetAttributeTOptions
 
setHandler(AbstractHandler) - Method in class alluxio.web.WebServer
 
setHost(String) - Method in class alluxio.thrift.MasterNetAddress
 
setHost(String) - Method in class alluxio.thrift.WorkerNetAddress
 
setHost(String) - Method in class alluxio.wire.Address
 
setHost(String) - Method in class alluxio.wire.WorkerNetAddress
 
setHostIsSet(boolean) - Method in class alluxio.thrift.MasterNetAddress
 
setHostIsSet(boolean) - Method in class alluxio.thrift.WorkerNetAddress
 
setHostname() - Method in class alluxio.master.AbstractLocalAlluxioCluster
Sets hostname.
setHostname(String) - Method in class alluxio.thrift.BackupTResponse
 
setHostname(String) - Method in class alluxio.thrift.Metric
 
setHostname(String) - Method in class alluxio.thrift.MetricsMasterClientService.metricsHeartbeat_args
the client hostname
setHostnameIsSet(boolean) - Method in class alluxio.thrift.BackupTResponse
 
setHostnameIsSet(boolean) - Method in class alluxio.thrift.Metric
 
setHostnameIsSet(boolean) - Method in class alluxio.thrift.MetricsMasterClientService.metricsHeartbeat_args
 
setId(long) - Method in class alluxio.proto.dataserver.Protocol.WriteRequest.Builder
optional int64 id = 2;
setId(long) - Method in class alluxio.proto.journal.File.CompleteFileEntry.Builder
optional int64 id = 2;
setId(long) - Method in class alluxio.proto.journal.File.DeleteFileEntry.Builder
optional int64 id = 1;
setId(long) - Method in class alluxio.proto.journal.File.InodeDirectoryEntry.Builder
optional int64 id = 1;
setId(long) - Method in class alluxio.proto.journal.File.InodeFileEntry.Builder
optional int64 id = 1;
setId(long) - Method in class alluxio.proto.journal.File.InodeLastModificationTimeEntry.Builder
optional int64 id = 1;
setId(long) - Method in class alluxio.proto.journal.File.PersistDirectoryEntry.Builder
optional int64 id = 1;
setId(long) - Method in class alluxio.proto.journal.File.PersistFileEntry.Builder
optional int64 id = 1;
setId(long) - Method in class alluxio.proto.journal.File.RenameEntry.Builder
optional int64 id = 1;
setId(long) - Method in class alluxio.proto.journal.File.SetAttributeEntry.Builder
optional int64 id = 1;
setId(long) - Method in class alluxio.proto.journal.Lineage.LineageEntry.Builder
optional int64 id = 1;
setId(long) - Method in class alluxio.thrift.CompleteUfsFileTReponse
 
setId(long) - Method in class alluxio.thrift.CreateLineageTResponse
 
setId(long) - Method in class alluxio.thrift.CreateUfsFileTResponse
 
setId(long) - Method in class alluxio.thrift.GetNewBlockIdForFileTResponse
 
setId(long) - Method in class alluxio.thrift.LineageInfo
 
setId(long) - Method in class alluxio.thrift.LoadMetadataTResponse
 
setId(long) - Method in class alluxio.thrift.OpenUfsFileTResponse
 
setId(long) - Method in class alluxio.thrift.ReinitializeFileTResponse
 
setId(long) - Method in class alluxio.thrift.WorkerInfo
 
setId(long) - Method in class alluxio.wire.LineageInfo
 
setId(long) - Method in class alluxio.wire.WorkerInfo
 
setIdIsSet(boolean) - Method in class alluxio.thrift.CompleteUfsFileTReponse
 
setIdIsSet(boolean) - Method in class alluxio.thrift.CreateLineageTResponse
 
setIdIsSet(boolean) - Method in class alluxio.thrift.CreateUfsFileTResponse
 
setIdIsSet(boolean) - Method in class alluxio.thrift.GetNewBlockIdForFileTResponse
 
setIdIsSet(boolean) - Method in class alluxio.thrift.LineageInfo
 
setIdIsSet(boolean) - Method in class alluxio.thrift.LoadMetadataTResponse
 
setIdIsSet(boolean) - Method in class alluxio.thrift.OpenUfsFileTResponse
 
setIdIsSet(boolean) - Method in class alluxio.thrift.ReinitializeFileTResponse
 
setIdIsSet(boolean) - Method in class alluxio.thrift.WorkerInfo
 
setIgnoredSiteProperty(boolean) - Method in class alluxio.PropertyKey.Builder
 
setInAlluxioPercentage(int) - Method in class alluxio.thrift.FileInfo
 
setInAlluxioPercentage(int) - Method in class alluxio.wire.FileInfo
 
setInAlluxioPercentageIsSet(boolean) - Method in class alluxio.thrift.FileInfo
 
setInconsistentPaths(List<String>) - Method in class alluxio.thrift.CheckConsistencyTResponse
 
setInconsistentPathsIsSet(boolean) - Method in class alluxio.thrift.CheckConsistencyTResponse
 
setInconsistentUris(List<String>) - Method in class alluxio.wire.StartupConsistencyCheck
 
setInfo(PartitionInfo) - Method in class alluxio.thrift.KeyValueMasterClientService.completePartition_args
information about the partition to mark complete
setInfoIsSet(boolean) - Method in class alluxio.thrift.KeyValueMasterClientService.completePartition_args
 
setInitialBytes(long) - Method in class alluxio.thrift.BlockWorkerClientService.requestBlockLocation_args
initial number of bytes requested
setInitialBytesIsSet(boolean) - Method in class alluxio.thrift.BlockWorkerClientService.requestBlockLocation_args
 
setInitialDelayMs(long) - Method in class alluxio.resource.DynamicResourcePool.Options
 
setInMemoryPercentage(int) - Method in class alluxio.thrift.FileInfo
 
setInMemoryPercentage(int) - Method in class alluxio.wire.FileInfo
 
setInMemoryPercentageIsSet(boolean) - Method in class alluxio.thrift.FileInfo
 
setInodeDirectory(File.InodeDirectoryEntry) - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
optional .alluxio.proto.journal.InodeDirectoryEntry inode_directory = 9;
setInodeDirectory(File.InodeDirectoryEntry.Builder) - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
optional .alluxio.proto.journal.InodeDirectoryEntry inode_directory = 9;
setInodeDirectoryIdGenerator(File.InodeDirectoryIdGeneratorEntry) - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
optional .alluxio.proto.journal.InodeDirectoryIdGeneratorEntry inode_directory_id_generator = 10;
setInodeDirectoryIdGenerator(File.InodeDirectoryIdGeneratorEntry.Builder) - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
optional .alluxio.proto.journal.InodeDirectoryIdGeneratorEntry inode_directory_id_generator = 10;
setInodeFile(File.InodeFileEntry) - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
optional .alluxio.proto.journal.InodeFileEntry inode_file = 11;
setInodeFile(File.InodeFileEntry.Builder) - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
optional .alluxio.proto.journal.InodeFileEntry inode_file = 11;
setInodeLastModificationTime(File.InodeLastModificationTimeEntry) - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
optional .alluxio.proto.journal.InodeLastModificationTimeEntry inode_last_modification_time = 12;
setInodeLastModificationTime(File.InodeLastModificationTimeEntry.Builder) - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
optional .alluxio.proto.journal.InodeLastModificationTimeEntry inode_last_modification_time = 12;
setInputFiles(int, long) - Method in class alluxio.proto.journal.Lineage.LineageEntry.Builder
repeated int64 input_files = 2;
setInputFiles(List<String>) - Method in class alluxio.thrift.LineageInfo
 
setInputFiles(List<String>) - Method in class alluxio.thrift.LineageMasterClientService.createLineage_args
the list of input files
setInputFiles(List<String>) - Method in class alluxio.wire.LineageInfo
 
setInputFilesIsSet(boolean) - Method in class alluxio.thrift.LineageInfo
 
setInputFilesIsSet(boolean) - Method in class alluxio.thrift.LineageMasterClientService.createLineage_args
 
setInstance(String) - Method in class alluxio.thrift.Metric
 
setInstanceId(String) - Method in class alluxio.metrics.Metric
Sets the instance id.
setInstanceId(String) - Method in class alluxio.thrift.Metric
 
setInstanceIdIsSet(boolean) - Method in class alluxio.thrift.Metric
 
setInstanceIsSet(boolean) - Method in class alluxio.thrift.Metric
 
setInterval(int) - Method in class alluxio.util.WaitForOptions
 
setIp(String) - Method in class alluxio.master.file.FileSystemMasterAuditContext
Sets mIp field.
setIsBuiltIn(boolean) - Method in class alluxio.PropertyKey.Builder
 
setIsHidden(boolean) - Method in class alluxio.PropertyKey.Builder
 
setIsTruncated(boolean) - Method in class alluxio.proxy.s3.ListBucketResult
 
setIsTruncated(boolean) - Method in class alluxio.proxy.s3.ListPartsResult
 
setJob(CommandLineJobInfo) - Method in class alluxio.thrift.LineageInfo
 
setJob(CommandLineJobInfo) - Method in class alluxio.thrift.LineageMasterClientService.createLineage_args
the command line job info
setJob(CommandLineJobInfo) - Method in class alluxio.wire.LineageInfo
 
setJobCommand(String) - Method in class alluxio.proto.journal.Lineage.LineageEntry.Builder
optional string job_command = 4;
setJobCommandBytes(ByteString) - Method in class alluxio.proto.journal.Lineage.LineageEntry.Builder
optional string job_command = 4;
setJobIsSet(boolean) - Method in class alluxio.thrift.LineageInfo
 
setJobIsSet(boolean) - Method in class alluxio.thrift.LineageMasterClientService.createLineage_args
 
setJobOutputPath(String) - Method in class alluxio.proto.journal.Lineage.LineageEntry.Builder
optional string job_output_path = 5;
setJobOutputPathBytes(ByteString) - Method in class alluxio.proto.journal.Lineage.LineageEntry.Builder
optional string job_output_path = 5;
setKey(PropertyKey) - Method in class alluxio.master.meta.checkconf.ConfigRecord
 
setKey(String) - Method in class alluxio.proto.journal.File.StringPairEntry.Builder
optional string key = 1;
setKey(String) - Method in class alluxio.proxy.s3.CompleteMultipartUploadResult
 
setKey(String) - Method in class alluxio.proxy.s3.InitiateMultipartUploadResult
 
setKey(String) - Method in class alluxio.proxy.s3.ListBucketResult.Content
 
setKey(String) - Method in class alluxio.proxy.s3.ListPartsResult
 
setKey(byte[]) - Method in class alluxio.thrift.KeyValueWorkerClientService.get_args
binary of the key
setKey(ByteBuffer) - Method in class alluxio.thrift.KeyValueWorkerClientService.get_args
 
setKey(byte[]) - Method in class alluxio.thrift.KeyValueWorkerClientService.getNextKeys_args
current key
setKey(ByteBuffer) - Method in class alluxio.thrift.KeyValueWorkerClientService.getNextKeys_args
 
setKeyBytes(ByteString) - Method in class alluxio.proto.journal.File.StringPairEntry.Builder
optional string key = 1;
setKeyCount(int) - Method in class alluxio.proto.journal.KeyValue.CompletePartitionEntry.Builder
optional int32 key_count = 5;
setKeyCount(int) - Method in class alluxio.proxy.s3.ListBucketResult
 
setKeyCount(int) - Method in class alluxio.thrift.PartitionInfo
 
setKeyCountIsSet(boolean) - Method in class alluxio.thrift.PartitionInfo
 
setKeyIsSet(boolean) - Method in class alluxio.thrift.KeyValueWorkerClientService.get_args
 
setKeyIsSet(boolean) - Method in class alluxio.thrift.KeyValueWorkerClientService.getNextKeys_args
 
setKeyLimit(String) - Method in class alluxio.proto.journal.KeyValue.CompletePartitionEntry.Builder
optional string key_limit = 3;
setKeyLimit(byte[]) - Method in class alluxio.thrift.PartitionInfo
 
setKeyLimit(ByteBuffer) - Method in class alluxio.thrift.PartitionInfo
 
setKeyLimitBytes(ByteString) - Method in class alluxio.proto.journal.KeyValue.CompletePartitionEntry.Builder
optional string key_limit = 3;
setKeyLimitIsSet(boolean) - Method in class alluxio.thrift.PartitionInfo
 
setKeys(List<ByteBuffer>) - Method in class alluxio.thrift.GetNextKeysTResponse
 
setKeysIsSet(boolean) - Method in class alluxio.thrift.GetNextKeysTResponse
 
setKeyStart(String) - Method in class alluxio.proto.journal.KeyValue.CompletePartitionEntry.Builder
optional string key_start = 2;
setKeyStart(byte[]) - Method in class alluxio.thrift.PartitionInfo
 
setKeyStart(ByteBuffer) - Method in class alluxio.thrift.PartitionInfo
 
setKeyStartBytes(ByteString) - Method in class alluxio.proto.journal.KeyValue.CompletePartitionEntry.Builder
optional string key_start = 2;
setKeyStartIsSet(boolean) - Method in class alluxio.thrift.PartitionInfo
 
setLastAccessTimeMs(long) - Method in class alluxio.resource.DynamicResourcePool.ResourceInternal
 
setLastContactSec(int) - Method in class alluxio.thrift.WorkerInfo
 
setLastContactSec(int) - Method in class alluxio.wire.WorkerInfo
 
setLastContactSecIsSet(boolean) - Method in class alluxio.thrift.WorkerInfo
 
setLastModificationTimeMs(long) - Method in class alluxio.master.file.meta.Inode
Sets the last modification time of the inode to the new time if the new time is more recent.
setLastModificationTimeMs(long, boolean) - Method in class alluxio.master.file.meta.Inode
 
setLastModificationTimeMs(long) - Method in class alluxio.proto.journal.File.InodeDirectoryEntry.Builder
optional int64 last_modification_time_ms = 7;
setLastModificationTimeMs(long) - Method in class alluxio.proto.journal.File.InodeFileEntry.Builder
optional int64 last_modification_time_ms = 7;
setLastModificationTimeMs(long) - Method in class alluxio.proto.journal.File.InodeLastModificationTimeEntry.Builder
optional int64 last_modification_time_ms = 2;
setLastModificationTimeMs(long) - Method in class alluxio.thrift.FileInfo
 
setLastModificationTimeMs(long) - Method in class alluxio.wire.FileInfo
 
setLastModificationTimeMsIsSet(boolean) - Method in class alluxio.thrift.FileInfo
 
setLastModified(String) - Method in class alluxio.proxy.s3.ListBucketResult.Content
 
setLastModified(String) - Method in class alluxio.proxy.s3.ListPartsResult.Part
 
setLeaderMasterAddress(String) - Method in class alluxio.thrift.MasterInfo
 
setLeaderMasterAddress(String) - Method in class alluxio.wire.MasterInfo
 
setLeaderMasterAddressIsSet(boolean) - Method in class alluxio.thrift.MasterInfo
 
setLength(long) - Method in class alluxio.master.file.meta.InodeFile
 
setLength(long) - Method in class alluxio.proto.dataserver.Protocol.AsyncCacheRequest.Builder
optional int64 length = 5;
setLength(long) - Method in class alluxio.proto.dataserver.Protocol.ReadRequest.Builder
optional int64 length = 3;
setLength(long) - Method in class alluxio.proto.journal.Block.BlockInfoEntry.Builder
optional int64 length = 2;
setLength(long) - Method in class alluxio.proto.journal.File.CompleteFileEntry.Builder
optional int64 length = 3;
setLength(long) - Method in class alluxio.proto.journal.File.InodeFileEntry.Builder
optional int64 length = 9;
setLength(long) - Method in class alluxio.proto.journal.File.PersistFileEntry.Builder
optional int64 length = 2;
setLength(long) - Method in class alluxio.thrift.BlockInfo
 
setLength(long) - Method in class alluxio.thrift.BlockMasterWorkerService.commitBlock_args
the length of the block being committed
setLength(long) - Method in class alluxio.thrift.FileInfo
 
setLength(long) - Method in class alluxio.underfs.options.OpenOptions
 
setLength(long) - Method in class alluxio.wire.BlockInfo
 
setLength(long) - Method in class alluxio.wire.FileInfo
 
setLengthIsSet(boolean) - Method in class alluxio.thrift.BlockInfo
 
setLengthIsSet(boolean) - Method in class alluxio.thrift.BlockMasterWorkerService.commitBlock_args
 
setLengthIsSet(boolean) - Method in class alluxio.thrift.FileInfo
 
setLevel(String) - Method in class alluxio.wire.LogInfo
 
setLineage(Lineage.LineageEntry) - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
optional .alluxio.proto.journal.LineageEntry lineage = 13;
setLineage(Lineage.LineageEntry.Builder) - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
optional .alluxio.proto.journal.LineageEntry lineage = 13;
setLineageId(long) - Method in class alluxio.proto.journal.Lineage.DeleteLineageEntry.Builder
optional int64 lineage_id = 1;
setLineageId(long) - Method in class alluxio.thrift.LineageMasterClientService.deleteLineage_args
the lineage id
setLineageIdGenerator(Lineage.LineageIdGeneratorEntry) - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
optional .alluxio.proto.journal.LineageIdGeneratorEntry lineage_id_generator = 14;
setLineageIdGenerator(Lineage.LineageIdGeneratorEntry.Builder) - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
optional .alluxio.proto.journal.LineageIdGeneratorEntry lineage_id_generator = 14;
setLineageIdIsSet(boolean) - Method in class alluxio.thrift.LineageMasterClientService.deleteLineage_args
 
setLineageInfoList(List<LineageInfo>) - Method in class alluxio.thrift.GetLineageInfoListTResponse
 
setLineageInfoListIsSet(boolean) - Method in class alluxio.thrift.GetLineageInfoListTResponse
 
setLiveWorkerNum(int) - Method in class alluxio.thrift.BlockMasterInfo
 
setLiveWorkerNum(int) - Method in class alluxio.wire.BlockMasterInfo
 
setLiveWorkerNumIsSet(boolean) - Method in class alluxio.thrift.BlockMasterInfo
 
setLoadDescendantType(DescendantType) - Method in class alluxio.master.file.options.LoadMetadataOptions
 
setLoadDirectChildren(boolean) - Method in class alluxio.thrift.ListStatusTOptions
 
setLoadDirectChildrenIsSet(boolean) - Method in class alluxio.thrift.ListStatusTOptions
 
setLoadMetadataType(LoadMetadataType) - Method in class alluxio.client.file.options.ExistsOptions
 
setLoadMetadataType(LoadMetadataType) - Method in class alluxio.client.file.options.GetStatusOptions
 
setLoadMetadataType(LoadMetadataType) - Method in class alluxio.client.file.options.ListStatusOptions
 
setLoadMetadataType(LoadMetadataType) - Method in class alluxio.master.file.options.GetStatusOptions
setLoadMetadataType(LoadMetadataType) - Method in class alluxio.master.file.options.ListStatusOptions
setLoadMetadataType(LoadMetadataTType) - Method in class alluxio.thrift.GetStatusTOptions
 
setLoadMetadataType(LoadMetadataTType) - Method in class alluxio.thrift.ListStatusTOptions
 
setLoadMetadataTypeIsSet(boolean) - Method in class alluxio.thrift.GetStatusTOptions
 
setLoadMetadataTypeIsSet(boolean) - Method in class alluxio.thrift.ListStatusTOptions
 
setLocalDirStickyBit(String) - Static method in class alluxio.util.io.FileUtils
Sticky bit can be set primarily on directories in UNIX / Linux.
setLocalFileSystem(boolean) - Method in class alluxio.thrift.BackupTOptions
 
setLocalFileSystemIsSet(boolean) - Method in class alluxio.thrift.BackupTOptions
 
setLocation(URI) - Method in class alluxio.master.journal.JournalSystem.Builder
 
setLocation(String) - Method in class alluxio.proxy.s3.CompleteMultipartUploadResult
 
setLocation(String) - Method in class alluxio.thrift.RequestBlockLocationTResponse
 
setLocationIsSet(boolean) - Method in class alluxio.thrift.RequestBlockLocationTResponse
 
setLocationPolicy(FileWriteLocationPolicy) - Method in class alluxio.client.file.options.CreateFileOptions
 
setLocationPolicy(FileWriteLocationPolicy) - Method in class alluxio.client.file.options.OpenFileOptions
Deprecated.
since version 1.5 and will be removed in version 2.0. Use OpenFileOptions.setCacheLocationPolicy(FileWriteLocationPolicy).
setLocationPolicy(FileWriteLocationPolicy) - Method in class alluxio.client.file.options.OutStreamOptions
 
setLocationPolicyClass(String) - Method in class alluxio.client.file.options.CreateFileOptions
 
setLocationPolicyClass(String) - Method in class alluxio.client.file.options.OpenFileOptions
Deprecated.
since version 1.5 and will be removed in version 2.0. Use OpenFileOptions.setCacheLocationPolicyClass(String).
setLocationPolicyClassName(String) - Method in class alluxio.client.block.policy.options.CreateOptions
 
setLocations(List<BlockLocation>) - Method in class alluxio.thrift.BlockInfo
 
setLocations(List<BlockLocation>) - Method in class alluxio.wire.BlockInfo
 
setLocationsIsSet(boolean) - Method in class alluxio.thrift.BlockInfo
 
setLockBlockStatus(LockBlockStatus) - Method in class alluxio.thrift.LockBlockTResponse
 
setLockBlockStatusIsSet(boolean) - Method in class alluxio.thrift.LockBlockTResponse
 
setLockId(long) - Method in class alluxio.thrift.LockBlockTResponse
 
setLockIdIsSet(boolean) - Method in class alluxio.thrift.LockBlockTResponse
 
setLogLevel(String, String) - Static method in class alluxio.util.LogUtils
Gets a logger's level with specify name, if the level argument is not null, it will set to specify level first.
setLogName(String) - Method in class alluxio.wire.LogInfo
 
setLongValue(long) - Method in class alluxio.thrift.MetricValue
 
setLongValueIsSet(boolean) - Method in class alluxio.thrift.MetricValue
 
setLostWorkerNum(int) - Method in class alluxio.thrift.BlockMasterInfo
 
setLostWorkerNum(int) - Method in class alluxio.wire.BlockMasterInfo
 
setLostWorkerNumIsSet(boolean) - Method in class alluxio.thrift.BlockMasterInfo
 
setLostWorkers(List<WorkerInfo>) - Method in class alluxio.wire.AlluxioMasterInfo
 
setMasterAddress(MasterNetAddress) - Method in class alluxio.thrift.MetaMasterMasterService.getMasterId_args
the master address
setMasterAddresses(List<MasterNetAddress>) - Method in class alluxio.thrift.MasterInfo
 
setMasterAddresses(List<Address>) - Method in class alluxio.wire.MasterInfo
 
setMasterAddressesIsSet(boolean) - Method in class alluxio.thrift.MasterInfo
 
setMasterAddressIsSet(boolean) - Method in class alluxio.thrift.MetaMasterMasterService.getMasterId_args
 
setMasterId(long) - Method in class alluxio.thrift.GetMasterIdTResponse
 
setMasterId(long) - Method in class alluxio.thrift.MetaMasterMasterService.masterHeartbeat_args
the id of the master
setMasterId(long) - Method in class alluxio.thrift.MetaMasterMasterService.registerMaster_args
the id of the master
setMasterIdIsSet(boolean) - Method in class alluxio.thrift.GetMasterIdTResponse
 
setMasterIdIsSet(boolean) - Method in class alluxio.thrift.MetaMasterMasterService.masterHeartbeat_args
 
setMasterIdIsSet(boolean) - Method in class alluxio.thrift.MetaMasterMasterService.registerMaster_args
 
setMasterInfo(MasterInfo) - Method in class alluxio.thrift.GetMasterInfoTResponse
 
setMasterInfoIsSet(boolean) - Method in class alluxio.thrift.GetMasterInfoTResponse
 
setMasterProperties(Map<Integer, Map<PropertyKey, String>>) - Method in class alluxio.multi.process.MultiProcessCluster.Builder
Sets master specific properties.
setMaxCapacity(int) - Method in class alluxio.resource.DynamicResourcePool.Options
 
setMaxKeys(String) - Method in class alluxio.proxy.s3.ListBucketOptions
 
setMaxKeys(int) - Method in class alluxio.proxy.s3.ListBucketResult
 
setMaxUfsReadConcurrency(int) - Method in class alluxio.client.block.options.LockBlockOptions
 
setMaxUfsReadConcurrency(int) - Method in class alluxio.client.file.options.OpenFileOptions
 
setMaxUfsReadConcurrency(int) - Method in class alluxio.proto.dataserver.Protocol.OpenUfsBlockOptions.Builder
optional int32 maxUfsReadConcurrency = 4;
setMaxUfsReadConcurrency(int) - Method in class alluxio.thrift.LockBlockTOptions
 
setMaxUfsReadConcurrencyIsSet(boolean) - Method in class alluxio.thrift.LockBlockTOptions
 
setMergeStore(KeyValue.MergeStoreEntry) - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
optional .alluxio.proto.journal.MergeStoreEntry merge_store = 26;
setMergeStore(KeyValue.MergeStoreEntry.Builder) - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
optional .alluxio.proto.journal.MergeStoreEntry merge_store = 26;
setMessage(String) - Method in class alluxio.proto.dataserver.Protocol.Response.Builder
optional string message = 2;
setMessage(String) - Method in class alluxio.proxy.s3.S3Error
 
setMessage(String) - Method in exception alluxio.thrift.AlluxioTException
 
setMessage(String) - Method in class alluxio.wire.LogInfo
 
setMessageBytes(ByteString) - Method in class alluxio.proto.dataserver.Protocol.Response.Builder
optional string message = 2;
setMessageIsSet(boolean) - Method in exception alluxio.thrift.AlluxioTException
 
setMetadataLoad(boolean) - Method in class alluxio.master.file.options.CreatePathOptions
 
setMeter(Meter) - Method in class alluxio.worker.netty.ReadRequestContext
 
setMeter(Meter) - Method in class alluxio.worker.netty.WriteRequestContext
 
setMetrics(List<Metric>) - Method in class alluxio.thrift.BlockHeartbeatTOptions
 
setMetrics(List<Long>) - Method in class alluxio.thrift.BlockWorkerClientService.sessionBlockHeartbeat_args
deprecated since 1.3.0 and will be removed in 2.0
setMetrics(List<Long>) - Method in class alluxio.thrift.FileSystemWorkerClientService.sessionFileSystemHeartbeat_args
the client metrics.
setMetrics(List<Metric>) - Method in class alluxio.thrift.MetricsHeartbeatTOptions
 
setMetrics(Map<String, Long>) - Method in class alluxio.wire.AlluxioMasterInfo
 
setMetrics(Map<String, Long>) - Method in class alluxio.wire.AlluxioWorkerInfo
 
setMetricsIsSet(boolean) - Method in class alluxio.thrift.BlockHeartbeatTOptions
 
setMetricsIsSet(boolean) - Method in class alluxio.thrift.BlockWorkerClientService.sessionBlockHeartbeat_args
 
setMetricsIsSet(boolean) - Method in class alluxio.thrift.FileSystemWorkerClientService.sessionFileSystemHeartbeat_args
 
setMetricsIsSet(boolean) - Method in class alluxio.thrift.MetricsHeartbeatTOptions
 
setMetricsMap(Map<String, MetricValue>) - Method in class alluxio.thrift.GetMetricsTResponse
 
setMetricsMapIsSet(boolean) - Method in class alluxio.thrift.GetMetricsTResponse
 
setMinCapacity(int) - Method in class alluxio.resource.DynamicResourcePool.Options
 
setMode(Mode) - Method in class alluxio.client.file.options.CompleteUfsFileOptions
 
setMode(Mode) - Method in class alluxio.client.file.options.CreateDirectoryOptions
 
setMode(Mode) - Method in class alluxio.client.file.options.CreateFileOptions
 
setMode(Mode) - Method in class alluxio.client.file.options.CreateUfsFileOptions
 
setMode(Mode) - Method in class alluxio.client.file.options.OutStreamOptions
 
setMode(Mode) - Method in class alluxio.client.file.options.SetAttributeOptions
 
setMode(short) - Method in class alluxio.master.file.meta.Inode
 
setMode(Mode) - Method in class alluxio.master.file.options.CreatePathOptions
 
setMode(short) - Method in class alluxio.master.file.options.SetAttributeOptions
 
setMode(int) - Method in class alluxio.proto.dataserver.Protocol.CreateUfsFileOptions.Builder
optional int32 mode = 4;
setMode(int) - Method in class alluxio.proto.journal.File.InodeDirectoryEntry.Builder
optional int32 mode = 10;
setMode(int) - Method in class alluxio.proto.journal.File.InodeFileEntry.Builder
optional int32 mode = 16;
setMode(short) - Method in class alluxio.thrift.CompleteUfsFileTOptions
 
setMode(short) - Method in class alluxio.thrift.CreateDirectoryTOptions
 
setMode(short) - Method in class alluxio.thrift.CreateFileTOptions
 
setMode(short) - Method in class alluxio.thrift.CreateUfsFileTOptions
 
setMode(int) - Method in class alluxio.thrift.FileInfo
 
setMode(short) - Method in class alluxio.thrift.SetAttributeTOptions
 
setMode(String, short) - Method in class alluxio.underfs.cos.COSUnderFileSystem
 
setMode(String, short) - Method in class alluxio.underfs.gcs.GCSUnderFileSystem
 
setMode(String, short) - Method in class alluxio.underfs.hdfs.HdfsUnderFileSystem
 
setMode(String, short) - Method in class alluxio.underfs.local.LocalUnderFileSystem
 
setMode(Mode) - Method in class alluxio.underfs.options.CreateOptions
 
setMode(Mode) - Method in class alluxio.underfs.options.MkdirsOptions
 
setMode(String, short) - Method in class alluxio.underfs.oss.OSSUnderFileSystem
 
setMode(String, short) - Method in class alluxio.underfs.s3a.S3AUnderFileSystem
 
setMode(String, short) - Method in class alluxio.underfs.swift.SwiftUnderFileSystem
 
setMode(String, short) - Method in interface alluxio.underfs.UnderFileSystem
Changes posix file mode.
setMode(String, short) - Method in class alluxio.underfs.UnderFileSystemWithLogging
 
setMode(int) - Method in class alluxio.wire.FileInfo
 
setModeIsSet(boolean) - Method in class alluxio.thrift.CompleteUfsFileTOptions
 
setModeIsSet(boolean) - Method in class alluxio.thrift.CreateDirectoryTOptions
 
setModeIsSet(boolean) - Method in class alluxio.thrift.CreateFileTOptions
 
setModeIsSet(boolean) - Method in class alluxio.thrift.CreateUfsFileTOptions
 
setModeIsSet(boolean) - Method in class alluxio.thrift.FileInfo
 
setModeIsSet(boolean) - Method in class alluxio.thrift.SetAttributeTOptions
 
setMountId(long) - Method in class alluxio.client.block.options.LockBlockOptions
 
setMountId(long) - Method in class alluxio.client.file.options.OutStreamOptions
 
setMountId(long) - Method in class alluxio.proto.dataserver.Protocol.CreateUfsFileOptions.Builder
optional int64 mount_id = 5;
setMountId(long) - Method in class alluxio.proto.dataserver.Protocol.OpenUfsBlockOptions.Builder
optional int64 mountId = 5;
setMountId(long) - Method in class alluxio.proto.journal.File.AddMountPointEntry.Builder
optional int64 mount_id = 6;
setMountId(long) - Method in class alluxio.thrift.FileInfo
 
setMountId(long) - Method in class alluxio.thrift.FileSystemMasterWorkerService.getUfsInfo_args
the id of the ufs
setMountId(long) - Method in class alluxio.thrift.LockBlockTOptions
 
setMountId(long) - Method in class alluxio.wire.FileInfo
 
setMountIdIsSet(boolean) - Method in class alluxio.thrift.FileInfo
 
setMountIdIsSet(boolean) - Method in class alluxio.thrift.FileSystemMasterWorkerService.getUfsInfo_args
 
setMountIdIsSet(boolean) - Method in class alluxio.thrift.LockBlockTOptions
 
setMountPoint(boolean) - Method in class alluxio.master.file.meta.InodeDirectory
 
setMountPoint(boolean) - Method in class alluxio.master.file.options.CreatePathOptions
 
setMountPoint(boolean) - Method in class alluxio.proto.journal.File.InodeDirectoryEntry.Builder
optional bool mount_point = 11;
setMountPoint(boolean) - Method in class alluxio.thrift.FileInfo
 
setMountPoint(String) - Method in class alluxio.util.UnixMountInfo.Builder
 
setMountPoint(boolean) - Method in class alluxio.wire.FileInfo
 
setMountPointIsSet(boolean) - Method in class alluxio.thrift.FileInfo
 
setMountPoints(Map<String, MountPointInfo>) - Method in class alluxio.wire.AlluxioMasterInfo
 
setMountTable(Map<String, MountPointInfo>) - Method in class alluxio.thrift.GetMountTableTResponse
 
setMountTableIsSet(boolean) - Method in class alluxio.thrift.GetMountTableTResponse
 
setName(String) - Method in class alluxio.master.file.meta.Inode
 
setName(String) - Method in class alluxio.PropertyKey.Builder
 
setName(String) - Method in class alluxio.proto.journal.File.InodeDirectoryEntry.Builder
optional string name = 3;
setName(String) - Method in class alluxio.proto.journal.File.InodeFileEntry.Builder
optional string name = 3;
setName(String) - Method in class alluxio.proxy.s3.ListBucketResult
 
setName(String) - Method in class alluxio.thrift.ConfigProperty
 
setName(String) - Method in class alluxio.thrift.FileInfo
 
setName(String) - Method in class alluxio.thrift.InconsistentProperty
 
setName(String) - Method in class alluxio.thrift.Metric
 
setName(String) - Method in class alluxio.underfs.UfsStatus
Set the name of file or directory.
setName(String) - Method in class alluxio.wire.ConfigProperty
 
setName(String) - Method in class alluxio.wire.FileInfo
 
setName(String) - Method in class alluxio.wire.InconsistentProperty
 
setNameBytes(ByteString) - Method in class alluxio.proto.journal.File.InodeDirectoryEntry.Builder
optional string name = 3;
setNameBytes(ByteString) - Method in class alluxio.proto.journal.File.InodeFileEntry.Builder
optional string name = 3;
setNameIsSet(boolean) - Method in class alluxio.thrift.ConfigProperty
 
setNameIsSet(boolean) - Method in class alluxio.thrift.FileInfo
 
setNameIsSet(boolean) - Method in class alluxio.thrift.InconsistentProperty
 
setNameIsSet(boolean) - Method in class alluxio.thrift.Metric
 
setNewPath(String) - Method in class alluxio.thrift.KeyValueMasterClientService.renameStore_args
the new path of the store
setNewPathIsSet(boolean) - Method in class alluxio.thrift.KeyValueMasterClientService.renameStore_args
 
setNewStoreId(long) - Method in class alluxio.proto.journal.KeyValue.RenameStoreEntry.Builder
optional int64 new_store_id = 2;
setNextContainerId(long) - Method in class alluxio.master.block.BlockContainerIdGenerator
 
setNextContainerId(long) - Method in class alluxio.proto.journal.Block.BlockContainerIdGeneratorEntry.Builder
optional int64 next_container_id = 1;
setNextContinuationToken(String) - Method in class alluxio.proxy.s3.ListBucketResult
 
setNextSequenceNumber(long) - Method in class alluxio.master.journal.options.JournalReaderOptions
 
setNextSequenceNumber(long) - Method in class alluxio.master.journal.options.JournalWriterOptions
 
setNoCache(boolean) - Method in class alluxio.proto.dataserver.Protocol.OpenUfsBlockOptions.Builder
optional bool no_cache = 6;
setNumKeys(int) - Method in class alluxio.thrift.KeyValueWorkerClientService.getNextKeys_args
maximum number of keys to get
setNumKeysIsSet(boolean) - Method in class alluxio.thrift.KeyValueWorkerClientService.getNextKeys_args
 
setNumMasters(int) - Method in class alluxio.multi.process.MultiProcessCluster.Builder
 
setNumWorkers(int) - Method in class alluxio.multi.process.MultiProcessCluster.Builder
 
setOffset(long) - Method in class alluxio.client.block.options.LockBlockOptions
 
setOffset(long) - Method in class alluxio.proto.dataserver.Protocol.ReadRequest.Builder
optional int64 offset = 2;
setOffset(long) - Method in class alluxio.proto.dataserver.Protocol.WriteRequest.Builder
optional int64 offset = 3;
setOffset(long) - Method in class alluxio.thrift.FileBlockInfo
 
setOffset(long) - Method in class alluxio.thrift.LockBlockTOptions
 
setOffset(long) - Method in class alluxio.underfs.options.FileLocationOptions
Sets the offset for which locations are to be queried.
setOffset(long) - Method in class alluxio.underfs.options.OpenOptions
Sets the offset from the start of a file to be opened for reading.
setOffset(long) - Method in class alluxio.wire.FileBlockInfo
 
setOffsetInFile(long) - Method in class alluxio.proto.dataserver.Protocol.OpenUfsBlockOptions.Builder
optional int64 offset_in_file = 2;
setOffsetIsSet(boolean) - Method in class alluxio.thrift.FileBlockInfo
 
setOffsetIsSet(boolean) - Method in class alluxio.thrift.LockBlockTOptions
 
setOldPath(String) - Method in class alluxio.thrift.KeyValueMasterClientService.renameStore_args
the old path of the store
setOldPathIsSet(boolean) - Method in class alluxio.thrift.KeyValueMasterClientService.renameStore_args
 
setOldStoreId(long) - Method in class alluxio.proto.journal.KeyValue.RenameStoreEntry.Builder
optional int64 old_store_id = 1;
setOnlyReserveSpace(boolean) - Method in class alluxio.proto.dataserver.Protocol.LocalBlockCreateRequest.Builder
optional bool only_reserve_space = 5;
setOpenUfsBlockOptions(Protocol.OpenUfsBlockOptions) - Method in class alluxio.proto.dataserver.Protocol.AsyncCacheRequest.Builder
optional .alluxio.proto.dataserver.OpenUfsBlockOptions open_ufs_block_options = 4;
setOpenUfsBlockOptions(Protocol.OpenUfsBlockOptions.Builder) - Method in class alluxio.proto.dataserver.Protocol.AsyncCacheRequest.Builder
optional .alluxio.proto.dataserver.OpenUfsBlockOptions open_ufs_block_options = 4;
setOpenUfsBlockOptions(Protocol.OpenUfsBlockOptions) - Method in class alluxio.proto.dataserver.Protocol.ReadRequest.Builder
optional .alluxio.proto.dataserver.OpenUfsBlockOptions open_ufs_block_options = 6;
setOpenUfsBlockOptions(Protocol.OpenUfsBlockOptions.Builder) - Method in class alluxio.proto.dataserver.Protocol.ReadRequest.Builder
optional .alluxio.proto.dataserver.OpenUfsBlockOptions open_ufs_block_options = 6;
setOperationTimeMs(long) - Method in class alluxio.master.file.options.CompleteFileOptions
 
setOperationTimeMs(long) - Method in class alluxio.master.file.options.CreatePathOptions
 
setOperationTimeMs(long) - Method in class alluxio.master.file.options.RenameOptions
 
setOperationTimeMs(long) - Method in class alluxio.master.file.options.SetAttributeOptions
 
setOpTimeMs(long) - Method in class alluxio.proto.journal.File.CompleteFileEntry.Builder
optional int64 op_time_ms = 4;
setOpTimeMs(long) - Method in class alluxio.proto.journal.File.DeleteFileEntry.Builder
optional int64 op_time_ms = 3;
setOpTimeMs(long) - Method in class alluxio.proto.journal.File.PersistFileEntry.Builder
optional int64 op_time_ms = 3;
setOpTimeMs(long) - Method in class alluxio.proto.journal.File.RenameEntry.Builder
optional int64 op_time_ms = 3;
setOpTimeMs(long) - Method in class alluxio.proto.journal.File.SetAttributeEntry.Builder
optional int64 op_time_ms = 2;
setOption(String, String) - Method in class alluxio.AlluxioRemoteLogFilter
Deprecated.
Sets option value use key=value format. The log4j.properties file uses this to set options. See the log4j.properties for more details.
setOptions(GetServiceVersionTOptions) - Method in class alluxio.thrift.AlluxioService.getServiceVersion_args
the method options
setOptions(GetBlockInfoTOptions) - Method in class alluxio.thrift.BlockMasterClientService.getBlockInfo_args
the method options
setOptions(GetBlockMasterInfoTOptions) - Method in class alluxio.thrift.BlockMasterClientService.getBlockMasterInfo_args
the method options
setOptions(GetCapacityBytesTOptions) - Method in class alluxio.thrift.BlockMasterClientService.getCapacityBytes_args
the method options
setOptions(GetUsedBytesTOptions) - Method in class alluxio.thrift.BlockMasterClientService.getUsedBytes_args
the method options
setOptions(GetWorkerInfoListTOptions) - Method in class alluxio.thrift.BlockMasterClientService.getWorkerInfoList_args
the method options
setOptions(GetWorkerReportTOptions) - Method in class alluxio.thrift.BlockMasterClientService.getWorkerReport_args
the method options
setOptions(BlockHeartbeatTOptions) - Method in class alluxio.thrift.BlockMasterWorkerService.blockHeartbeat_args
the method options
setOptions(CommitBlockTOptions) - Method in class alluxio.thrift.BlockMasterWorkerService.commitBlock_args
the method options
setOptions(GetWorkerIdTOptions) - Method in class alluxio.thrift.BlockMasterWorkerService.getWorkerId_args
the method options
setOptions(RegisterWorkerTOptions) - Method in class alluxio.thrift.BlockMasterWorkerService.registerWorker_args
the method options
setOptions(AccessBlockTOptions) - Method in class alluxio.thrift.BlockWorkerClientService.accessBlock_args
the method options
setOptions(CacheBlockTOptions) - Method in class alluxio.thrift.BlockWorkerClientService.cacheBlock_args
the method options
setOptions(CancelBlockTOptions) - Method in class alluxio.thrift.BlockWorkerClientService.cancelBlock_args
the method options
setOptions(LockBlockTOptions) - Method in class alluxio.thrift.BlockWorkerClientService.lockBlock_args
the lock method options
setOptions(PromoteBlockTOptions) - Method in class alluxio.thrift.BlockWorkerClientService.promoteBlock_args
the method options
setOptions(RemoveBlockTOptions) - Method in class alluxio.thrift.BlockWorkerClientService.removeBlock_args
the method options
setOptions(RequestBlockLocationTOptions) - Method in class alluxio.thrift.BlockWorkerClientService.requestBlockLocation_args
the method options
setOptions(RequestSpaceTOptions) - Method in class alluxio.thrift.BlockWorkerClientService.requestSpace_args
the method options
setOptions(SessionBlockHeartbeatTOptions) - Method in class alluxio.thrift.BlockWorkerClientService.sessionBlockHeartbeat_args
the method options
setOptions(UnlockBlockTOptions) - Method in class alluxio.thrift.BlockWorkerClientService.unlockBlock_args
the method options
setOptions(CheckConsistencyTOptions) - Method in class alluxio.thrift.FileSystemMasterClientService.checkConsistency_args
the method options
setOptions(CompleteFileTOptions) - Method in class alluxio.thrift.FileSystemMasterClientService.completeFile_args
the method options
setOptions(CreateDirectoryTOptions) - Method in class alluxio.thrift.FileSystemMasterClientService.createDirectory_args
the method options
setOptions(CreateFileTOptions) - Method in class alluxio.thrift.FileSystemMasterClientService.createFile_args
the options for creating the file
setOptions(FreeTOptions) - Method in class alluxio.thrift.FileSystemMasterClientService.free_args
the options for freeing a path
setOptions(GetFilePathTOptions) - Method in class alluxio.thrift.FileSystemMasterClientService.getFilePath_args
the file id
setOptions(GetNewBlockIdForFileTOptions) - Method in class alluxio.thrift.FileSystemMasterClientService.getNewBlockIdForFile_args
the method options
setOptions(GetStatusTOptions) - Method in class alluxio.thrift.FileSystemMasterClientService.getStatus_args
the method options
setOptions(ListStatusTOptions) - Method in class alluxio.thrift.FileSystemMasterClientService.listStatus_args
listStatus options
setOptions(LoadMetadataTOptions) - Method in class alluxio.thrift.FileSystemMasterClientService.loadMetadata_args
the method options
setOptions(MountTOptions) - Method in class alluxio.thrift.FileSystemMasterClientService.mount_args
the options for creating the mount point
setOptions(DeleteTOptions) - Method in class alluxio.thrift.FileSystemMasterClientService.remove_args
the options for deleting the file
setOptions(RenameTOptions) - Method in class alluxio.thrift.FileSystemMasterClientService.rename_args
the method options
setOptions(ScheduleAsyncPersistenceTOptions) - Method in class alluxio.thrift.FileSystemMasterClientService.scheduleAsyncPersistence_args
the method options
setOptions(SetAttributeTOptions) - Method in class alluxio.thrift.FileSystemMasterClientService.setAttribute_args
the method options
setOptions(UnmountTOptions) - Method in class alluxio.thrift.FileSystemMasterClientService.unmount_args
the method options
setOptions(UpdateUfsModeTOptions) - Method in class alluxio.thrift.FileSystemMasterClientService.updateUfsMode_args
the method options
setOptions(FileSystemHeartbeatTOptions) - Method in class alluxio.thrift.FileSystemMasterWorkerService.fileSystemHeartbeat_args
the method options
setOptions(GetFileInfoTOptions) - Method in class alluxio.thrift.FileSystemMasterWorkerService.getFileInfo_args
the method options
setOptions(GetPinnedFileIdsTOptions) - Method in class alluxio.thrift.FileSystemMasterWorkerService.getPinnedFileIds_args
the method options
setOptions(GetUfsInfoTOptions) - Method in class alluxio.thrift.FileSystemMasterWorkerService.getUfsInfo_args
the method options
setOptions(CancelUfsFileTOptions) - Method in class alluxio.thrift.FileSystemWorkerClientService.cancelUfsFile_args
the options for canceling the file
setOptions(CloseUfsFileTOptions) - Method in class alluxio.thrift.FileSystemWorkerClientService.closeUfsFile_args
the options for closing the file
setOptions(CompleteUfsFileTOptions) - Method in class alluxio.thrift.FileSystemWorkerClientService.completeUfsFile_args
the options for completing the file
setOptions(CreateUfsFileTOptions) - Method in class alluxio.thrift.FileSystemWorkerClientService.createUfsFile_args
the options for creating the file
setOptions(OpenUfsFileTOptions) - Method in class alluxio.thrift.FileSystemWorkerClientService.openUfsFile_args
the options for opening the file
setOptions(SessionFileSystemHeartbeatTOptions) - Method in class alluxio.thrift.FileSystemWorkerClientService.sessionFileSystemHeartbeat_args
the method options
setOptions(CompletePartitionTOptions) - Method in class alluxio.thrift.KeyValueMasterClientService.completePartition_args
the method options
setOptions(CompleteStoreTOptions) - Method in class alluxio.thrift.KeyValueMasterClientService.completeStore_args
the method options
setOptions(CreateStoreTOptions) - Method in class alluxio.thrift.KeyValueMasterClientService.createStore_args
the method options
setOptions(DeleteStoreTOptions) - Method in class alluxio.thrift.KeyValueMasterClientService.deleteStore_args
the method options
setOptions(GetPartitionInfoTOptions) - Method in class alluxio.thrift.KeyValueMasterClientService.getPartitionInfo_args
the method options
setOptions(MergeStoreTOptions) - Method in class alluxio.thrift.KeyValueMasterClientService.mergeStore_args
the method options
setOptions(RenameStoreTOptions) - Method in class alluxio.thrift.KeyValueMasterClientService.renameStore_args
the method options
setOptions(GetTOptions) - Method in class alluxio.thrift.KeyValueWorkerClientService.get_args
the method options
setOptions(GetNextKeysTOptions) - Method in class alluxio.thrift.KeyValueWorkerClientService.getNextKeys_args
the method options
setOptions(GetSizeTOptions) - Method in class alluxio.thrift.KeyValueWorkerClientService.getSize_args
the method options
setOptions(CreateLineageTOptions) - Method in class alluxio.thrift.LineageMasterClientService.createLineage_args
the method options
setOptions(DeleteLineageTOptions) - Method in class alluxio.thrift.LineageMasterClientService.deleteLineage_args
the method options
setOptions(GetLineageInfoListTOptions) - Method in class alluxio.thrift.LineageMasterClientService.getLineageInfoList_args
the method options
setOptions(ReinitializeFileTOptions) - Method in class alluxio.thrift.LineageMasterClientService.reinitializeFile_args
the method options
setOptions(ReportLostFileTOptions) - Method in class alluxio.thrift.LineageMasterClientService.reportLostFile_args
the method options
setOptions(BackupTOptions) - Method in class alluxio.thrift.MetaMasterClientService.backup_args
the method options
setOptions(GetConfigReportTOptions) - Method in class alluxio.thrift.MetaMasterClientService.getConfigReport_args
the method options
setOptions(GetConfigurationTOptions) - Method in class alluxio.thrift.MetaMasterClientService.getConfiguration_args
the method options
setOptions(GetMasterInfoTOptions) - Method in class alluxio.thrift.MetaMasterClientService.getMasterInfo_args
the method options
setOptions(GetMetricsTOptions) - Method in class alluxio.thrift.MetaMasterClientService.getMetrics_args
the method options
setOptions(GetMasterIdTOptions) - Method in class alluxio.thrift.MetaMasterMasterService.getMasterId_args
the method options
setOptions(MasterHeartbeatTOptions) - Method in class alluxio.thrift.MetaMasterMasterService.masterHeartbeat_args
the method options
setOptions(RegisterMasterTOptions) - Method in class alluxio.thrift.MetaMasterMasterService.registerMaster_args
the method options
setOptions(MetricsHeartbeatTOptions) - Method in class alluxio.thrift.MetricsMasterClientService.metricsHeartbeat_args
the method options
setOptions(UnixMountInfo.Options) - Method in class alluxio.util.UnixMountInfo.Builder
 
setOptionsIsSet(boolean) - Method in class alluxio.thrift.AlluxioService.getServiceVersion_args
 
setOptionsIsSet(boolean) - Method in class alluxio.thrift.BlockMasterClientService.getBlockInfo_args
 
setOptionsIsSet(boolean) - Method in class alluxio.thrift.BlockMasterClientService.getBlockMasterInfo_args
 
setOptionsIsSet(boolean) - Method in class alluxio.thrift.BlockMasterClientService.getCapacityBytes_args
 
setOptionsIsSet(boolean) - Method in class alluxio.thrift.BlockMasterClientService.getUsedBytes_args
 
setOptionsIsSet(boolean) - Method in class alluxio.thrift.BlockMasterClientService.getWorkerInfoList_args
 
setOptionsIsSet(boolean) - Method in class alluxio.thrift.BlockMasterClientService.getWorkerReport_args
 
setOptionsIsSet(boolean) - Method in class alluxio.thrift.BlockMasterWorkerService.blockHeartbeat_args
 
setOptionsIsSet(boolean) - Method in class alluxio.thrift.BlockMasterWorkerService.commitBlock_args
 
setOptionsIsSet(boolean) - Method in class alluxio.thrift.BlockMasterWorkerService.getWorkerId_args
 
setOptionsIsSet(boolean) - Method in class alluxio.thrift.BlockMasterWorkerService.registerWorker_args
 
setOptionsIsSet(boolean) - Method in class alluxio.thrift.BlockWorkerClientService.accessBlock_args
 
setOptionsIsSet(boolean) - Method in class alluxio.thrift.BlockWorkerClientService.cacheBlock_args
 
setOptionsIsSet(boolean) - Method in class alluxio.thrift.BlockWorkerClientService.cancelBlock_args
 
setOptionsIsSet(boolean) - Method in class alluxio.thrift.BlockWorkerClientService.lockBlock_args
 
setOptionsIsSet(boolean) - Method in class alluxio.thrift.BlockWorkerClientService.promoteBlock_args
 
setOptionsIsSet(boolean) - Method in class alluxio.thrift.BlockWorkerClientService.removeBlock_args
 
setOptionsIsSet(boolean) - Method in class alluxio.thrift.BlockWorkerClientService.requestBlockLocation_args
 
setOptionsIsSet(boolean) - Method in class alluxio.thrift.BlockWorkerClientService.requestSpace_args
 
setOptionsIsSet(boolean) - Method in class alluxio.thrift.BlockWorkerClientService.sessionBlockHeartbeat_args
 
setOptionsIsSet(boolean) - Method in class alluxio.thrift.BlockWorkerClientService.unlockBlock_args
 
setOptionsIsSet(boolean) - Method in class alluxio.thrift.FileSystemMasterClientService.checkConsistency_args
 
setOptionsIsSet(boolean) - Method in class alluxio.thrift.FileSystemMasterClientService.completeFile_args
 
setOptionsIsSet(boolean) - Method in class alluxio.thrift.FileSystemMasterClientService.createDirectory_args
 
setOptionsIsSet(boolean) - Method in class alluxio.thrift.FileSystemMasterClientService.createFile_args
 
setOptionsIsSet(boolean) - Method in class alluxio.thrift.FileSystemMasterClientService.free_args
 
setOptionsIsSet(boolean) - Method in class alluxio.thrift.FileSystemMasterClientService.getFilePath_args
 
setOptionsIsSet(boolean) - Method in class alluxio.thrift.FileSystemMasterClientService.getNewBlockIdForFile_args
 
setOptionsIsSet(boolean) - Method in class alluxio.thrift.FileSystemMasterClientService.getStatus_args
 
setOptionsIsSet(boolean) - Method in class alluxio.thrift.FileSystemMasterClientService.listStatus_args
 
setOptionsIsSet(boolean) - Method in class alluxio.thrift.FileSystemMasterClientService.loadMetadata_args
 
setOptionsIsSet(boolean) - Method in class alluxio.thrift.FileSystemMasterClientService.mount_args
 
setOptionsIsSet(boolean) - Method in class alluxio.thrift.FileSystemMasterClientService.remove_args
 
setOptionsIsSet(boolean) - Method in class alluxio.thrift.FileSystemMasterClientService.rename_args
 
setOptionsIsSet(boolean) - Method in class alluxio.thrift.FileSystemMasterClientService.scheduleAsyncPersistence_args
 
setOptionsIsSet(boolean) - Method in class alluxio.thrift.FileSystemMasterClientService.setAttribute_args
 
setOptionsIsSet(boolean) - Method in class alluxio.thrift.FileSystemMasterClientService.unmount_args
 
setOptionsIsSet(boolean) - Method in class alluxio.thrift.FileSystemMasterClientService.updateUfsMode_args
 
setOptionsIsSet(boolean) - Method in class alluxio.thrift.FileSystemMasterWorkerService.fileSystemHeartbeat_args
 
setOptionsIsSet(boolean) - Method in class alluxio.thrift.FileSystemMasterWorkerService.getFileInfo_args
 
setOptionsIsSet(boolean) - Method in class alluxio.thrift.FileSystemMasterWorkerService.getPinnedFileIds_args
 
setOptionsIsSet(boolean) - Method in class alluxio.thrift.FileSystemMasterWorkerService.getUfsInfo_args
 
setOptionsIsSet(boolean) - Method in class alluxio.thrift.FileSystemWorkerClientService.cancelUfsFile_args
 
setOptionsIsSet(boolean) - Method in class alluxio.thrift.FileSystemWorkerClientService.closeUfsFile_args
 
setOptionsIsSet(boolean) - Method in class alluxio.thrift.FileSystemWorkerClientService.completeUfsFile_args
 
setOptionsIsSet(boolean) - Method in class alluxio.thrift.FileSystemWorkerClientService.createUfsFile_args
 
setOptionsIsSet(boolean) - Method in class alluxio.thrift.FileSystemWorkerClientService.openUfsFile_args
 
setOptionsIsSet(boolean) - Method in class alluxio.thrift.FileSystemWorkerClientService.sessionFileSystemHeartbeat_args
 
setOptionsIsSet(boolean) - Method in class alluxio.thrift.KeyValueMasterClientService.completePartition_args
 
setOptionsIsSet(boolean) - Method in class alluxio.thrift.KeyValueMasterClientService.completeStore_args
 
setOptionsIsSet(boolean) - Method in class alluxio.thrift.KeyValueMasterClientService.createStore_args
 
setOptionsIsSet(boolean) - Method in class alluxio.thrift.KeyValueMasterClientService.deleteStore_args
 
setOptionsIsSet(boolean) - Method in class alluxio.thrift.KeyValueMasterClientService.getPartitionInfo_args
 
setOptionsIsSet(boolean) - Method in class alluxio.thrift.KeyValueMasterClientService.mergeStore_args
 
setOptionsIsSet(boolean) - Method in class alluxio.thrift.KeyValueMasterClientService.renameStore_args
 
setOptionsIsSet(boolean) - Method in class alluxio.thrift.KeyValueWorkerClientService.get_args
 
setOptionsIsSet(boolean) - Method in class alluxio.thrift.KeyValueWorkerClientService.getNextKeys_args
 
setOptionsIsSet(boolean) - Method in class alluxio.thrift.KeyValueWorkerClientService.getSize_args
 
setOptionsIsSet(boolean) - Method in class alluxio.thrift.LineageMasterClientService.createLineage_args
 
setOptionsIsSet(boolean) - Method in class alluxio.thrift.LineageMasterClientService.deleteLineage_args
 
setOptionsIsSet(boolean) - Method in class alluxio.thrift.LineageMasterClientService.getLineageInfoList_args
 
setOptionsIsSet(boolean) - Method in class alluxio.thrift.LineageMasterClientService.reinitializeFile_args
 
setOptionsIsSet(boolean) - Method in class alluxio.thrift.LineageMasterClientService.reportLostFile_args
 
setOptionsIsSet(boolean) - Method in class alluxio.thrift.MetaMasterClientService.backup_args
 
setOptionsIsSet(boolean) - Method in class alluxio.thrift.MetaMasterClientService.getConfigReport_args
 
setOptionsIsSet(boolean) - Method in class alluxio.thrift.MetaMasterClientService.getConfiguration_args
 
setOptionsIsSet(boolean) - Method in class alluxio.thrift.MetaMasterClientService.getMasterInfo_args
 
setOptionsIsSet(boolean) - Method in class alluxio.thrift.MetaMasterClientService.getMetrics_args
 
setOptionsIsSet(boolean) - Method in class alluxio.thrift.MetaMasterMasterService.getMasterId_args
 
setOptionsIsSet(boolean) - Method in class alluxio.thrift.MetaMasterMasterService.masterHeartbeat_args
 
setOptionsIsSet(boolean) - Method in class alluxio.thrift.MetaMasterMasterService.registerMaster_args
 
setOptionsIsSet(boolean) - Method in class alluxio.thrift.MetricsMasterClientService.metricsHeartbeat_args
 
setOtherBits(Mode.Bits) - Method in class alluxio.security.authorization.Mode
Sets other bits.
setOutputFile(String) - Method in class alluxio.thrift.JobConfInfo
 
setOutputFile(String) - Method in class alluxio.wire.JobConfInfo
 
setOutputFileIds(int, long) - Method in class alluxio.proto.journal.Lineage.LineageEntry.Builder
repeated int64 output_file_ids = 3;
setOutputFileIsSet(boolean) - Method in class alluxio.thrift.JobConfInfo
 
setOutputFiles(List<String>) - Method in class alluxio.thrift.LineageInfo
 
setOutputFiles(List<String>) - Method in class alluxio.thrift.LineageMasterClientService.createLineage_args
the list of output files
setOutputFiles(List<String>) - Method in class alluxio.wire.LineageInfo
 
setOutputFilesIsSet(boolean) - Method in class alluxio.thrift.LineageInfo
 
setOutputFilesIsSet(boolean) - Method in class alluxio.thrift.LineageMasterClientService.createLineage_args
 
setOutputStream(OutputStream) - Method in class alluxio.worker.netty.UfsFileWriteRequestContext
 
setOwner(String) - Method in class alluxio.client.file.options.CompleteUfsFileOptions
 
setOwner(String) - Method in class alluxio.client.file.options.CreateUfsFileOptions
 
setOwner(String) - Method in class alluxio.client.file.options.OutStreamOptions
 
setOwner(String) - Method in class alluxio.client.file.options.SetAttributeOptions
 
setOwner(String) - Method in class alluxio.master.file.meta.Inode
 
setOwner(String) - Method in class alluxio.master.file.options.CreatePathOptions
 
setOwner(String) - Method in class alluxio.master.file.options.SetAttributeOptions
 
setOwner(String) - Method in class alluxio.proto.dataserver.Protocol.CreateUfsFileOptions.Builder
optional string owner = 2;
setOwner(String) - Method in class alluxio.proto.journal.File.InodeDirectoryEntry.Builder
optional string owner = 8;
setOwner(String) - Method in class alluxio.proto.journal.File.InodeFileEntry.Builder
optional string owner = 14;
setOwner(String) - Method in class alluxio.proto.journal.File.SetAttributeEntry.Builder
optional string owner = 6;
setOwner(String) - Method in class alluxio.thrift.CompleteUfsFileTOptions
 
setOwner(String) - Method in class alluxio.thrift.CreateUfsFileTOptions
 
setOwner(String) - Method in class alluxio.thrift.FileInfo
 
setOwner(String) - Method in class alluxio.thrift.SetAttributeTOptions
 
setOwner(String, String, String) - Method in class alluxio.underfs.cos.COSUnderFileSystem
 
setOwner(String, String, String) - Method in class alluxio.underfs.gcs.GCSUnderFileSystem
 
setOwner(String, String, String) - Method in class alluxio.underfs.hdfs.HdfsUnderFileSystem
 
setOwner(String, String, String) - Method in class alluxio.underfs.local.LocalUnderFileSystem
 
setOwner(String) - Method in class alluxio.underfs.options.CreateOptions
 
setOwner(String) - Method in class alluxio.underfs.options.MkdirsOptions
 
setOwner(String, String, String) - Method in class alluxio.underfs.oss.OSSUnderFileSystem
 
setOwner(String, String, String) - Method in class alluxio.underfs.s3a.S3AUnderFileSystem
 
setOwner(String, String, String) - Method in class alluxio.underfs.swift.SwiftUnderFileSystem
 
setOwner(String, String, String) - Method in interface alluxio.underfs.UnderFileSystem
Sets the user and group of the given path.
setOwner(String, String, String) - Method in class alluxio.underfs.UnderFileSystemWithLogging
 
setOwner(String) - Method in class alluxio.wire.FileInfo
 
setOwnerBits(Mode.Bits) - Method in class alluxio.security.authorization.Mode
Sets owner bits.
setOwnerBytes(ByteString) - Method in class alluxio.proto.dataserver.Protocol.CreateUfsFileOptions.Builder
optional string owner = 2;
setOwnerBytes(ByteString) - Method in class alluxio.proto.journal.File.InodeDirectoryEntry.Builder
optional string owner = 8;
setOwnerBytes(ByteString) - Method in class alluxio.proto.journal.File.InodeFileEntry.Builder
optional string owner = 14;
setOwnerBytes(ByteString) - Method in class alluxio.proto.journal.File.SetAttributeEntry.Builder
optional string owner = 6;
setOwnerIsSet(boolean) - Method in class alluxio.thrift.CompleteUfsFileTOptions
 
setOwnerIsSet(boolean) - Method in class alluxio.thrift.CreateUfsFileTOptions
 
setOwnerIsSet(boolean) - Method in class alluxio.thrift.FileInfo
 
setOwnerIsSet(boolean) - Method in class alluxio.thrift.SetAttributeTOptions
 
setPacketReaderActive(boolean) - Method in class alluxio.worker.netty.ReadRequestContext
 
setPacketSize(long) - Method in class alluxio.proto.dataserver.Protocol.ReadRequest.Builder
optional int64 packet_size = 5;
setPacketWriterActive(boolean) - Method in class alluxio.worker.netty.WriteRequestContext
 
setParentId(long) - Method in class alluxio.master.file.meta.Inode
 
setParentId(long) - Method in class alluxio.proto.journal.File.InodeDirectoryEntry.Builder
optional int64 parent_id = 2;
setParentId(long) - Method in class alluxio.proto.journal.File.InodeFileEntry.Builder
optional int64 parent_id = 2;
setParents(List<Long>) - Method in class alluxio.thrift.LineageInfo
 
setParents(List<Long>) - Method in class alluxio.wire.LineageInfo
 
setParentsIsSet(boolean) - Method in class alluxio.thrift.LineageInfo
 
setPartitionInfo(List<PartitionInfo>) - Method in class alluxio.thrift.GetPartitionInfoTResponse
 
setPartitionInfoIsSet(boolean) - Method in class alluxio.thrift.GetPartitionInfoTResponse
 
setPartNumber(int) - Method in class alluxio.proxy.s3.ListPartsResult.Part
 
setParts(List<ListPartsResult.Part>) - Method in class alluxio.proxy.s3.ListPartsResult
 
setPath(String) - Method in class alluxio.proto.dataserver.Protocol.LocalBlockCreateResponse.Builder
optional string path = 1;
setPath(String) - Method in class alluxio.proto.dataserver.Protocol.LocalBlockOpenResponse.Builder
optional string path = 1;
setPath(String) - Method in class alluxio.proto.journal.File.ReinitializeFileEntry.Builder
optional string path = 1;
setPath(String) - Method in class alluxio.thrift.FileInfo
 
setPath(String) - Method in class alluxio.thrift.FileSystemMasterClientService.checkConsistency_args
the root of the subtree to check
setPath(String) - Method in class alluxio.thrift.FileSystemMasterClientService.completeFile_args
the path of the file
setPath(String) - Method in class alluxio.thrift.FileSystemMasterClientService.createDirectory_args
the path of the directory
setPath(String) - Method in class alluxio.thrift.FileSystemMasterClientService.createFile_args
the path of the file
setPath(String) - Method in class alluxio.thrift.FileSystemMasterClientService.free_args
the path of the file or directory
setPath(String) - Method in class alluxio.thrift.FileSystemMasterClientService.getNewBlockIdForFile_args
the path of the file
setPath(String) - Method in class alluxio.thrift.FileSystemMasterClientService.getStatus_args
the path of the file or directory
setPath(String) - Method in class alluxio.thrift.FileSystemMasterClientService.listStatus_args
the path of the file or directory
setPath(String) - Method in class alluxio.thrift.FileSystemMasterClientService.remove_args
the path of the file or directory
setPath(String) - Method in class alluxio.thrift.FileSystemMasterClientService.rename_args
the source path of the file or directory
setPath(String) - Method in class alluxio.thrift.FileSystemMasterClientService.scheduleAsyncPersistence_args
the path of the file
setPath(String) - Method in class alluxio.thrift.FileSystemMasterClientService.setAttribute_args
the path of the file or directory
setPath(String) - Method in class alluxio.thrift.GetFilePathTResponse
 
setPath(String) - Method in class alluxio.thrift.KeyValueMasterClientService.completePartition_args
the path of the store
setPath(String) - Method in class alluxio.thrift.KeyValueMasterClientService.completeStore_args
the path of the store
setPath(String) - Method in class alluxio.thrift.KeyValueMasterClientService.createStore_args
the path of the store
setPath(String) - Method in class alluxio.thrift.KeyValueMasterClientService.deleteStore_args
the path of the store
setPath(String) - Method in class alluxio.thrift.KeyValueMasterClientService.getPartitionInfo_args
the path of the store
setPath(String) - Method in class alluxio.thrift.LineageMasterClientService.reinitializeFile_args
the path of the file
setPath(String) - Method in class alluxio.thrift.LineageMasterClientService.reportLostFile_args
the path of the file
setPath(String) - Method in class alluxio.wire.FileInfo
 
setPathBytes(ByteString) - Method in class alluxio.proto.dataserver.Protocol.LocalBlockCreateResponse.Builder
optional string path = 1;
setPathBytes(ByteString) - Method in class alluxio.proto.dataserver.Protocol.LocalBlockOpenResponse.Builder
optional string path = 1;
setPathBytes(ByteString) - Method in class alluxio.proto.journal.File.ReinitializeFileEntry.Builder
optional string path = 1;
setPathIsSet(boolean) - Method in class alluxio.thrift.FileInfo
 
setPathIsSet(boolean) - Method in class alluxio.thrift.FileSystemMasterClientService.checkConsistency_args
 
setPathIsSet(boolean) - Method in class alluxio.thrift.FileSystemMasterClientService.completeFile_args
 
setPathIsSet(boolean) - Method in class alluxio.thrift.FileSystemMasterClientService.createDirectory_args
 
setPathIsSet(boolean) - Method in class alluxio.thrift.FileSystemMasterClientService.createFile_args
 
setPathIsSet(boolean) - Method in class alluxio.thrift.FileSystemMasterClientService.free_args
 
setPathIsSet(boolean) - Method in class alluxio.thrift.FileSystemMasterClientService.getNewBlockIdForFile_args
 
setPathIsSet(boolean) - Method in class alluxio.thrift.FileSystemMasterClientService.getStatus_args
 
setPathIsSet(boolean) - Method in class alluxio.thrift.FileSystemMasterClientService.listStatus_args
 
setPathIsSet(boolean) - Method in class alluxio.thrift.FileSystemMasterClientService.remove_args
 
setPathIsSet(boolean) - Method in class alluxio.thrift.FileSystemMasterClientService.rename_args
 
setPathIsSet(boolean) - Method in class alluxio.thrift.FileSystemMasterClientService.scheduleAsyncPersistence_args
 
setPathIsSet(boolean) - Method in class alluxio.thrift.FileSystemMasterClientService.setAttribute_args
 
setPathIsSet(boolean) - Method in class alluxio.thrift.GetFilePathTResponse
 
setPathIsSet(boolean) - Method in class alluxio.thrift.KeyValueMasterClientService.completePartition_args
 
setPathIsSet(boolean) - Method in class alluxio.thrift.KeyValueMasterClientService.completeStore_args
 
setPathIsSet(boolean) - Method in class alluxio.thrift.KeyValueMasterClientService.createStore_args
 
setPathIsSet(boolean) - Method in class alluxio.thrift.KeyValueMasterClientService.deleteStore_args
 
setPathIsSet(boolean) - Method in class alluxio.thrift.KeyValueMasterClientService.getPartitionInfo_args
 
setPathIsSet(boolean) - Method in class alluxio.thrift.LineageMasterClientService.reinitializeFile_args
 
setPathIsSet(boolean) - Method in class alluxio.thrift.LineageMasterClientService.reportLostFile_args
 
setPermission(int) - Method in class alluxio.proto.journal.File.SetAttributeEntry.Builder
optional int32 permission = 8;
setPersistDirectory(File.PersistDirectoryEntry) - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
optional .alluxio.proto.journal.PersistDirectoryEntry persist_directory = 15;
setPersistDirectory(File.PersistDirectoryEntry.Builder) - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
optional .alluxio.proto.journal.PersistDirectoryEntry persist_directory = 15;
setPersisted(boolean) - Method in class alluxio.client.file.options.SetAttributeOptions
Deprecated.
the persisted attribute is deprecated since version 1.4 and will be removed in 2.0
setPersisted(boolean) - Method in class alluxio.master.file.options.CreatePathOptions
 
setPersisted(boolean) - Method in class alluxio.master.file.options.SetAttributeOptions
 
setPersisted(boolean) - Method in class alluxio.proto.journal.File.SetAttributeEntry.Builder
optional bool persisted = 5;
setPersisted(boolean) - Method in class alluxio.thrift.CreateDirectoryTOptions
 
setPersisted(boolean) - Method in class alluxio.thrift.CreateFileTOptions
 
setPersisted(boolean) - Method in class alluxio.thrift.FileInfo
 
setPersisted(boolean) - Method in class alluxio.thrift.SetAttributeTOptions
 
setPersisted(boolean) - Method in class alluxio.wire.FileInfo
 
setPersistedFileFingerprints(List<String>) - Method in class alluxio.thrift.FileSystemHeartbeatTOptions
 
setPersistedFileFingerprintsIsSet(boolean) - Method in class alluxio.thrift.FileSystemHeartbeatTOptions
 
setPersistedFiles(List<Long>) - Method in class alluxio.thrift.FileSystemMasterWorkerService.fileSystemHeartbeat_args
the list of persisted files
setPersistedFilesIsSet(boolean) - Method in class alluxio.thrift.FileSystemMasterWorkerService.fileSystemHeartbeat_args
 
setPersistedIsSet(boolean) - Method in class alluxio.thrift.CreateDirectoryTOptions
 
setPersistedIsSet(boolean) - Method in class alluxio.thrift.CreateFileTOptions
 
setPersistedIsSet(boolean) - Method in class alluxio.thrift.FileInfo
 
setPersistedIsSet(boolean) - Method in class alluxio.thrift.SetAttributeTOptions
 
setPersistedUfsFingerprintList(List<String>) - Method in class alluxio.master.file.options.WorkerHeartbeatOptions
 
setPersistenceState(PersistenceState) - Method in class alluxio.master.file.meta.Inode
 
setPersistenceState(String) - Method in class alluxio.proto.journal.File.InodeDirectoryEntry.Builder
optional string persistence_state = 4;
setPersistenceState(String) - Method in class alluxio.proto.journal.File.InodeFileEntry.Builder
optional string persistence_state = 4;
setPersistenceState(String) - Method in class alluxio.thrift.FileInfo
 
setPersistenceState(String) - Method in class alluxio.wire.FileInfo
 
setPersistenceStateBytes(ByteString) - Method in class alluxio.proto.journal.File.InodeDirectoryEntry.Builder
optional string persistence_state = 4;
setPersistenceStateBytes(ByteString) - Method in class alluxio.proto.journal.File.InodeFileEntry.Builder
optional string persistence_state = 4;
setPersistenceStateIsSet(boolean) - Method in class alluxio.thrift.FileInfo
 
setPersistFiles(List<PersistFile>) - Method in class alluxio.thrift.PersistCommandOptions
 
setPersistFilesIsSet(boolean) - Method in class alluxio.thrift.PersistCommandOptions
 
setPersistOptions(PersistCommandOptions) - Method in class alluxio.thrift.FileSystemCommandOptions
 
setPinned(FileSystem, AlluxioURI, boolean) - Static method in class alluxio.cli.fs.command.FileSystemCommandUtils
Sets pin state for the input path.
setPinned(boolean) - Method in class alluxio.client.file.options.SetAttributeOptions
 
setPinned(boolean) - Method in class alluxio.master.file.meta.Inode
 
setPinned(LockedInodePath, boolean, long) - Method in class alluxio.master.file.meta.InodeTree
Sets the pinned state of an inode.
setPinned(LockedInodePath, boolean) - Method in class alluxio.master.file.meta.InodeTree
Sets the pinned state of an inode.
setPinned(boolean) - Method in class alluxio.master.file.options.SetAttributeOptions
 
setPinned(boolean) - Method in class alluxio.proto.journal.File.InodeDirectoryEntry.Builder
optional bool pinned = 5;
setPinned(boolean) - Method in class alluxio.proto.journal.File.InodeFileEntry.Builder
optional bool pinned = 5;
setPinned(boolean) - Method in class alluxio.proto.journal.File.SetAttributeEntry.Builder
optional bool pinned = 3;
setPinned(boolean) - Method in class alluxio.thrift.FileInfo
 
setPinned(boolean) - Method in class alluxio.thrift.SetAttributeTOptions
 
setPinned(boolean) - Method in class alluxio.wire.FileInfo
 
setPinnedFileIds(Set<Long>) - Method in class alluxio.thrift.GetPinnedFileIdsTResponse
 
setPinnedFileIdsIsSet(boolean) - Method in class alluxio.thrift.GetPinnedFileIdsTResponse
 
setPinnedIsSet(boolean) - Method in class alluxio.thrift.FileInfo
 
setPinnedIsSet(boolean) - Method in class alluxio.thrift.SetAttributeTOptions
 
setPosToQueue(long) - Method in class alluxio.worker.netty.ReadRequestContext
 
setPosToQueue(long) - Method in class alluxio.worker.netty.WriteRequestContext
 
setPosToWrite(long) - Method in class alluxio.worker.netty.ReadRequestContext
 
setPosToWrite(long) - Method in class alluxio.worker.netty.WriteRequestContext
 
setPreferredRegion(String) - Method in class alluxio.underfs.swift.KeystoneV3Access
 
setPrefix(String) - Method in class alluxio.proxy.s3.ListBucketOptions
 
setPrefix(String) - Method in class alluxio.proxy.s3.ListBucketResult
 
setPrimary(boolean) - Method in class alluxio.master.journal.options.JournalReaderOptions
 
setPrimary(boolean) - Method in class alluxio.master.journal.options.JournalWriterOptions
 
setProcessType(String) - Method in class alluxio.AlluxioRemoteLogFilter
Sets mProcessType to be the type of the process generating this log message.
setPromote(boolean) - Method in class alluxio.proto.dataserver.Protocol.LocalBlockOpenRequest.Builder
optional bool promote = 2;
setPromote(boolean) - Method in class alluxio.proto.dataserver.Protocol.ReadRequest.Builder
optional bool promote = 7;
setPromoted(boolean) - Method in class alluxio.thrift.PromoteBlockTResponse
 
setPromotedIsSet(boolean) - Method in class alluxio.thrift.PromoteBlockTResponse
 
setProperties(Map<String, String>) - Method in class alluxio.client.file.options.MountOptions
 
setProperties(Map<String, String>) - Method in class alluxio.master.file.options.MountOptions
 
setProperties(int, File.StringPairEntry) - Method in class alluxio.proto.journal.File.AddMountPointEntry.Builder
repeated .alluxio.proto.journal.StringPairEntry properties = 4;
setProperties(int, File.StringPairEntry.Builder) - Method in class alluxio.proto.journal.File.AddMountPointEntry.Builder
repeated .alluxio.proto.journal.StringPairEntry properties = 4;
setProperties(Map<String, String>) - Method in class alluxio.thrift.MountPointInfo
 
setProperties(Map<String, String>) - Method in class alluxio.thrift.MountTOptions
 
setProperties(MountTOptions) - Method in class alluxio.thrift.UfsInfo
 
setProperties(Map<String, String>) - Method in class alluxio.wire.MountPointInfo
 
setPropertiesIsSet(boolean) - Method in class alluxio.thrift.MountPointInfo
 
setPropertiesIsSet(boolean) - Method in class alluxio.thrift.MountTOptions
 
setPropertiesIsSet(boolean) - Method in class alluxio.thrift.UfsInfo
 
setQuietTimeMs(long) - Method in class alluxio.master.journal.JournalSystem.Builder
 
setRawValue(boolean) - Method in class alluxio.thrift.GetConfigurationTOptions
 
setRawValue(boolean) - Method in class alluxio.wire.GetConfigurationOptions
 
setRawValueIsSet(boolean) - Method in class alluxio.thrift.GetConfigurationTOptions
 
setReadOnly(boolean) - Method in class alluxio.client.file.options.MountOptions
Sets the readonly flag.
setReadOnly(boolean) - Method in class alluxio.master.file.options.MountOptions
 
setReadOnly(boolean) - Method in class alluxio.proto.journal.File.AddMountPointEntry.Builder
optional bool readOnly = 3;
setReadOnly(boolean) - Method in class alluxio.thrift.MountPointInfo
 
setReadOnly(boolean) - Method in class alluxio.thrift.MountTOptions
 
setReadOnly(boolean) - Method in class alluxio.underfs.UnderFileSystemConfiguration
 
setReadOnly(boolean) - Method in class alluxio.wire.MountPointInfo
 
setReadOnlyIsSet(boolean) - Method in class alluxio.thrift.MountPointInfo
 
setReadOnlyIsSet(boolean) - Method in class alluxio.thrift.MountTOptions
 
setReadType(ReadType) - Method in class alluxio.client.file.options.OpenFileOptions
 
setRecoverFailedOpen(boolean) - Method in class alluxio.underfs.options.OpenOptions
 
setRecursive(boolean) - Method in class alluxio.client.file.options.CreateDirectoryOptions
 
setRecursive(boolean) - Method in class alluxio.client.file.options.CreateFileOptions
 
setRecursive(boolean) - Method in class alluxio.client.file.options.DeleteOptions
 
setRecursive(boolean) - Method in class alluxio.client.file.options.FreeOptions
Sets the recursive flag.
setRecursive(boolean) - Method in class alluxio.client.file.options.ListStatusOptions
 
setRecursive(boolean) - Method in class alluxio.client.file.options.LoadMetadataOptions
Deprecated.
Sets the recursive flag.
setRecursive(boolean) - Method in class alluxio.client.file.options.SetAttributeOptions
Sets the recursive flag.
setRecursive(boolean) - Method in class alluxio.master.file.options.CreatePathOptions
 
setRecursive(boolean) - Method in class alluxio.master.file.options.DeleteOptions
 
setRecursive(boolean) - Method in class alluxio.master.file.options.FreeOptions
Sets the recursive flag.
setRecursive(boolean) - Method in class alluxio.master.file.options.ListStatusOptions
setRecursive(boolean) - Method in class alluxio.master.file.options.SetAttributeOptions
 
setRecursive(boolean) - Method in class alluxio.proto.journal.File.DeleteFileEntry.Builder
optional bool recursive = 2;
setRecursive(boolean) - Method in class alluxio.thrift.CreateDirectoryTOptions
 
setRecursive(boolean) - Method in class alluxio.thrift.CreateFileTOptions
 
setRecursive(boolean) - Method in class alluxio.thrift.DeleteTOptions
 
setRecursive(boolean) - Method in class alluxio.thrift.FileSystemMasterClientService.free_args
whether to free recursively
setRecursive(boolean) - Method in class alluxio.thrift.FileSystemMasterClientService.loadMetadata_args
whether to load metadata recursively
setRecursive(boolean) - Method in class alluxio.thrift.FileSystemMasterClientService.remove_args
whether to remove recursively
setRecursive(boolean) - Method in class alluxio.thrift.FreeTOptions
 
setRecursive(boolean) - Method in class alluxio.thrift.ListStatusTOptions
 
setRecursive(boolean) - Method in class alluxio.thrift.SetAttributeTOptions
 
setRecursive(boolean) - Method in class alluxio.underfs.options.DeleteOptions
Sets recursive delete.
setRecursive(boolean) - Method in class alluxio.underfs.options.ListOptions
Sets recursive list.
setRecursiveIsSet(boolean) - Method in class alluxio.thrift.CreateDirectoryTOptions
 
setRecursiveIsSet(boolean) - Method in class alluxio.thrift.CreateFileTOptions
 
setRecursiveIsSet(boolean) - Method in class alluxio.thrift.DeleteTOptions
 
setRecursiveIsSet(boolean) - Method in class alluxio.thrift.FileSystemMasterClientService.free_args
 
setRecursiveIsSet(boolean) - Method in class alluxio.thrift.FileSystemMasterClientService.loadMetadata_args
 
setRecursiveIsSet(boolean) - Method in class alluxio.thrift.FileSystemMasterClientService.remove_args
 
setRecursiveIsSet(boolean) - Method in class alluxio.thrift.FreeTOptions
 
setRecursiveIsSet(boolean) - Method in class alluxio.thrift.ListStatusTOptions
 
setRecursiveIsSet(boolean) - Method in class alluxio.thrift.SetAttributeTOptions
 
setReinitializeFile(File.ReinitializeFileEntry) - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
optional .alluxio.proto.journal.ReinitializeFileEntry reinitialize_file = 18;
setReinitializeFile(File.ReinitializeFileEntry.Builder) - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
optional .alluxio.proto.journal.ReinitializeFileEntry reinitialize_file = 18;
setRemovedBlockIds(List<Long>) - Method in class alluxio.thrift.BlockMasterWorkerService.blockHeartbeat_args
the list of removed block ids
setRemovedBlockIdsIsSet(boolean) - Method in class alluxio.thrift.BlockMasterWorkerService.blockHeartbeat_args
 
setRename(File.RenameEntry) - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
optional .alluxio.proto.journal.RenameEntry rename = 19;
setRename(File.RenameEntry.Builder) - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
optional .alluxio.proto.journal.RenameEntry rename = 19;
setRenameStore(KeyValue.RenameStoreEntry) - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
optional .alluxio.proto.journal.RenameStoreEntry rename_store = 28;
setRenameStore(KeyValue.RenameStoreEntry.Builder) - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
optional .alluxio.proto.journal.RenameStoreEntry rename_store = 28;
setReport(ConfigCheckReport) - Method in class alluxio.thrift.GetConfigReportTResponse
 
setReportIsSet(boolean) - Method in class alluxio.thrift.GetConfigReportTResponse
 
setRequestBytes(long) - Method in class alluxio.thrift.BlockWorkerClientService.requestSpace_args
the number of bytes requested
setRequestBytesIsSet(boolean) - Method in class alluxio.thrift.BlockWorkerClientService.requestSpace_args
 
setRequestId(String) - Method in class alluxio.proxy.s3.S3Error
 
setResource(String) - Method in class alluxio.proxy.s3.S3Error
 
setRpcAddress(String) - Method in class alluxio.wire.AlluxioMasterInfo
 
setRpcAddress(String) - Method in class alluxio.wire.AlluxioWorkerInfo
 
setRpcPort(int) - Method in class alluxio.thrift.MasterInfo
 
setRpcPort(int) - Method in class alluxio.thrift.MasterNetAddress
 
setRpcPort(int) - Method in class alluxio.thrift.WorkerNetAddress
 
setRpcPort(int) - Method in class alluxio.wire.Address
 
setRpcPort(int) - Method in class alluxio.wire.MasterInfo
 
setRpcPort(int) - Method in class alluxio.wire.WorkerNetAddress
 
setRpcPortIsSet(boolean) - Method in class alluxio.thrift.MasterInfo
 
setRpcPortIsSet(boolean) - Method in class alluxio.thrift.MasterNetAddress
 
setRpcPortIsSet(boolean) - Method in class alluxio.thrift.WorkerNetAddress
 
setSafeMode(boolean) - Method in class alluxio.thrift.MasterInfo
 
setSafeMode(boolean) - Method in class alluxio.wire.MasterInfo
 
setSafeModeIsSet(boolean) - Method in class alluxio.thrift.MasterInfo
 
setScope(Scope) - Method in class alluxio.PropertyKey.Builder
 
setSecond(T2) - Method in class alluxio.collections.Pair
Set the second value.
setSecond(LockedInodePath) - Method in class alluxio.master.file.meta.InodePathPair
 
setSequenceNumber(long) - Method in class alluxio.proto.journal.File.InodeDirectoryIdGeneratorEntry.Builder
optional int64 sequence_number = 2;
setSequenceNumber(long) - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
optional int64 sequence_number = 1;
setSequenceNumber(long) - Method in class alluxio.proto.journal.Lineage.LineageIdGeneratorEntry.Builder
optional int64 sequence_number = 1;
setSessionId(long) - Method in class alluxio.thrift.BlockWorkerClientService.cacheBlock_args
the id of the current session
setSessionId(long) - Method in class alluxio.thrift.BlockWorkerClientService.cancelBlock_args
the id of the current session
setSessionId(long) - Method in class alluxio.thrift.BlockWorkerClientService.lockBlock_args
the id of the current session
setSessionId(long) - Method in class alluxio.thrift.BlockWorkerClientService.requestBlockLocation_args
the id of the current session
setSessionId(long) - Method in class alluxio.thrift.BlockWorkerClientService.requestSpace_args
the id of the current session
setSessionId(long) - Method in class alluxio.thrift.BlockWorkerClientService.sessionBlockHeartbeat_args
the id of the current session
setSessionId(long) - Method in class alluxio.thrift.BlockWorkerClientService.unlockBlock_args
the id of the current session
setSessionId(long) - Method in class alluxio.thrift.FileSystemWorkerClientService.cancelUfsFile_args
the id of the current session
setSessionId(long) - Method in class alluxio.thrift.FileSystemWorkerClientService.closeUfsFile_args
the id of the current session
setSessionId(long) - Method in class alluxio.thrift.FileSystemWorkerClientService.completeUfsFile_args
the id of the current session
setSessionId(long) - Method in class alluxio.thrift.FileSystemWorkerClientService.createUfsFile_args
the id of the current session
setSessionId(long) - Method in class alluxio.thrift.FileSystemWorkerClientService.openUfsFile_args
the id of the current session
setSessionId(long) - Method in class alluxio.thrift.FileSystemWorkerClientService.sessionFileSystemHeartbeat_args
the id of the current session
setSessionIdIsSet(boolean) - Method in class alluxio.thrift.BlockWorkerClientService.cacheBlock_args
 
setSessionIdIsSet(boolean) - Method in class alluxio.thrift.BlockWorkerClientService.cancelBlock_args
 
setSessionIdIsSet(boolean) - Method in class alluxio.thrift.BlockWorkerClientService.lockBlock_args
 
setSessionIdIsSet(boolean) - Method in class alluxio.thrift.BlockWorkerClientService.requestBlockLocation_args
 
setSessionIdIsSet(boolean) - Method in class alluxio.thrift.BlockWorkerClientService.requestSpace_args
 
setSessionIdIsSet(boolean) - Method in class alluxio.thrift.BlockWorkerClientService.sessionBlockHeartbeat_args
 
setSessionIdIsSet(boolean) - Method in class alluxio.thrift.BlockWorkerClientService.unlockBlock_args
 
setSessionIdIsSet(boolean) - Method in class alluxio.thrift.FileSystemWorkerClientService.cancelUfsFile_args
 
setSessionIdIsSet(boolean) - Method in class alluxio.thrift.FileSystemWorkerClientService.closeUfsFile_args
 
setSessionIdIsSet(boolean) - Method in class alluxio.thrift.FileSystemWorkerClientService.completeUfsFile_args
 
setSessionIdIsSet(boolean) - Method in class alluxio.thrift.FileSystemWorkerClientService.createUfsFile_args
 
setSessionIdIsSet(boolean) - Method in class alluxio.thrift.FileSystemWorkerClientService.openUfsFile_args
 
setSessionIdIsSet(boolean) - Method in class alluxio.thrift.FileSystemWorkerClientService.sessionFileSystemHeartbeat_args
 
setSetAttribute(File.SetAttributeEntry) - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
optional .alluxio.proto.journal.SetAttributeEntry set_attribute = 27;
setSetAttribute(File.SetAttributeEntry.Builder) - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
optional .alluxio.proto.journal.SetAttributeEntry set_attribute = 27;
setShared(boolean) - Method in class alluxio.client.file.options.MountOptions
 
setShared(boolean) - Method in class alluxio.master.file.options.MountOptions
 
setShared(boolean) - Method in class alluxio.proto.journal.File.AddMountPointEntry.Builder
optional bool shared = 5;
setShared(boolean) - Method in class alluxio.thrift.MountPointInfo
 
setShared(boolean) - Method in class alluxio.thrift.MountTOptions
 
setShared(boolean) - Method in class alluxio.underfs.UnderFileSystemConfiguration
 
setShared(boolean) - Method in class alluxio.wire.MountPointInfo
 
setSharedIsSet(boolean) - Method in class alluxio.thrift.MountPointInfo
 
setSharedIsSet(boolean) - Method in class alluxio.thrift.MountTOptions
 
setSize(String) - Method in class alluxio.proxy.s3.ListBucketResult.Content
 
setSize(long) - Method in class alluxio.proxy.s3.ListPartsResult.Part
 
setSize(int) - Method in class alluxio.thrift.GetSizeTResponse
 
setSize(Long) - Method in class alluxio.util.UnixMountInfo.Options.Builder
 
setSizeIsSet(boolean) - Method in class alluxio.thrift.GetSizeTResponse
 
setSource(PropertyKey, Source) - Method in class alluxio.conf.AlluxioProperties
Sets the source for a given key.
setSource(String) - Method in class alluxio.master.meta.checkconf.ConfigRecord
 
setSource(String) - Method in class alluxio.thrift.ConfigProperty
 
setSource(String) - Method in class alluxio.wire.ConfigProperty
 
setSourceHost(String) - Method in class alluxio.proto.dataserver.Protocol.AsyncCacheRequest.Builder
optional string source_host = 2;
setSourceHostBytes(ByteString) - Method in class alluxio.proto.dataserver.Protocol.AsyncCacheRequest.Builder
optional string source_host = 2;
setSourceIsSet(boolean) - Method in class alluxio.thrift.ConfigProperty
 
setSourcePort(int) - Method in class alluxio.proto.dataserver.Protocol.AsyncCacheRequest.Builder
optional int32 source_port = 3;
setSpaceToReserve(long) - Method in class alluxio.proto.dataserver.Protocol.LocalBlockCreateRequest.Builder
optional int64 space_to_reserve = 4;
setSrcInode(Inode) - Method in class alluxio.master.file.FileSystemMasterAuditContext
Sets mSrcInode field.
setSrcPath(AlluxioURI) - Method in class alluxio.master.file.FileSystemMasterAuditContext
Sets mSrcPath field.
setStartTimeMs(long) - Method in class alluxio.thrift.MasterInfo
 
setStartTimeMs(long) - Method in class alluxio.thrift.WorkerInfo
 
setStartTimeMs(long) - Method in class alluxio.wire.AlluxioMasterInfo
 
setStartTimeMs(long) - Method in class alluxio.wire.AlluxioProxyInfo
 
setStartTimeMs(long) - Method in class alluxio.wire.AlluxioWorkerInfo
 
setStartTimeMs(long) - Method in class alluxio.wire.MasterInfo
 
setStartTimeMs(long) - Method in class alluxio.wire.WorkerInfo
 
setStartTimeMsIsSet(boolean) - Method in class alluxio.thrift.MasterInfo
 
setStartTimeMsIsSet(boolean) - Method in class alluxio.thrift.WorkerInfo
 
setStartupConsistencyCheck(StartupConsistencyCheck) - Method in class alluxio.wire.AlluxioMasterInfo
 
setState(PrimarySelector.State) - Method in class alluxio.master.AbstractPrimarySelector
 
setState(String) - Method in class alluxio.thrift.WorkerInfo
 
setState(String) - Method in class alluxio.wire.WorkerInfo
 
setStateIsSet(boolean) - Method in class alluxio.thrift.WorkerInfo
 
setStatus(Status.PStatus) - Method in class alluxio.proto.dataserver.Protocol.Response.Builder
optional .alluxio.proto.status.PStatus status = 1;
setStatus(TStatus) - Method in exception alluxio.thrift.AlluxioTException
 
setStatus(ConfigStatus) - Method in class alluxio.thrift.ConfigCheckReport
 
setStatus(String) - Method in class alluxio.wire.StartupConsistencyCheck
 
setStatusIsSet(boolean) - Method in exception alluxio.thrift.AlluxioTException
 
setStatusIsSet(boolean) - Method in class alluxio.thrift.ConfigCheckReport
 
setStorageClass(String) - Method in class alluxio.proxy.s3.ListBucketResult.Content
 
setStorageClass(String) - Method in class alluxio.proxy.s3.ListPartsResult
 
setStorageTiers(List<String>) - Method in class alluxio.thrift.BlockMasterWorkerService.registerWorker_args
the list of storage tiers
setStorageTiersIsSet(boolean) - Method in class alluxio.thrift.BlockMasterWorkerService.registerWorker_args
 
setStoreId(long) - Method in class alluxio.proto.journal.KeyValue.CompletePartitionEntry.Builder
optional int64 store_id = 1;
setStoreId(long) - Method in class alluxio.proto.journal.KeyValue.CompleteStoreEntry.Builder
optional int64 store_id = 1;
setStoreId(long) - Method in class alluxio.proto.journal.KeyValue.CreateStoreEntry.Builder
optional int64 store_id = 1;
setStoreId(long) - Method in class alluxio.proto.journal.KeyValue.DeleteStoreEntry.Builder
optional int64 store_id = 1;
setSucceeded(boolean) - Method in interface alluxio.master.audit.AuditContext
Set to true if the operration associated with this AuditContext is allowed and succeeds.
setSucceeded(boolean) - Method in class alluxio.master.file.FileSystemMasterAuditContext
 
setSuccess(GetServiceVersionTResponse) - Method in class alluxio.thrift.AlluxioService.getServiceVersion_result
 
setSuccess(GetBlockInfoTResponse) - Method in class alluxio.thrift.BlockMasterClientService.getBlockInfo_result
 
setSuccess(GetBlockMasterInfoTResponse) - Method in class alluxio.thrift.BlockMasterClientService.getBlockMasterInfo_result
 
setSuccess(GetCapacityBytesTResponse) - Method in class alluxio.thrift.BlockMasterClientService.getCapacityBytes_result
 
setSuccess(GetUsedBytesTResponse) - Method in class alluxio.thrift.BlockMasterClientService.getUsedBytes_result
 
setSuccess(GetWorkerInfoListTResponse) - Method in class alluxio.thrift.BlockMasterClientService.getWorkerInfoList_result
 
setSuccess(GetWorkerInfoListTResponse) - Method in class alluxio.thrift.BlockMasterClientService.getWorkerReport_result
 
setSuccess(BlockHeartbeatTResponse) - Method in class alluxio.thrift.BlockMasterWorkerService.blockHeartbeat_result
 
setSuccess(CommitBlockTResponse) - Method in class alluxio.thrift.BlockMasterWorkerService.commitBlock_result
 
setSuccess(GetWorkerIdTResponse) - Method in class alluxio.thrift.BlockMasterWorkerService.getWorkerId_result
 
setSuccess(RegisterWorkerTResponse) - Method in class alluxio.thrift.BlockMasterWorkerService.registerWorker_result
 
setSuccess(AccessBlockTResponse) - Method in class alluxio.thrift.BlockWorkerClientService.accessBlock_result
 
setSuccess(CacheBlockTResponse) - Method in class alluxio.thrift.BlockWorkerClientService.cacheBlock_result
 
setSuccess(CancelBlockTResponse) - Method in class alluxio.thrift.BlockWorkerClientService.cancelBlock_result
 
setSuccess(LockBlockTResponse) - Method in class alluxio.thrift.BlockWorkerClientService.lockBlock_result
 
setSuccess(PromoteBlockTResponse) - Method in class alluxio.thrift.BlockWorkerClientService.promoteBlock_result
 
setSuccess(RemoveBlockTResponse) - Method in class alluxio.thrift.BlockWorkerClientService.removeBlock_result
 
setSuccess(RequestBlockLocationTResponse) - Method in class alluxio.thrift.BlockWorkerClientService.requestBlockLocation_result
 
setSuccess(RequestSpaceTResponse) - Method in class alluxio.thrift.BlockWorkerClientService.requestSpace_result
 
setSuccess(SessionBlockHeartbeatTResponse) - Method in class alluxio.thrift.BlockWorkerClientService.sessionBlockHeartbeat_result
 
setSuccess(UnlockBlockTResponse) - Method in class alluxio.thrift.BlockWorkerClientService.unlockBlock_result
 
setSuccess(boolean) - Method in class alluxio.thrift.DeleteLineageTResponse
 
setSuccess(CheckConsistencyTResponse) - Method in class alluxio.thrift.FileSystemMasterClientService.checkConsistency_result
 
setSuccess(CompleteFileTResponse) - Method in class alluxio.thrift.FileSystemMasterClientService.completeFile_result
 
setSuccess(CreateDirectoryTResponse) - Method in class alluxio.thrift.FileSystemMasterClientService.createDirectory_result
 
setSuccess(CreateFileTResponse) - Method in class alluxio.thrift.FileSystemMasterClientService.createFile_result
 
setSuccess(FreeTResponse) - Method in class alluxio.thrift.FileSystemMasterClientService.free_result
 
setSuccess(GetFilePathTResponse) - Method in class alluxio.thrift.FileSystemMasterClientService.getFilePath_result
 
setSuccess(GetMountTableTResponse) - Method in class alluxio.thrift.FileSystemMasterClientService.getMountTable_result
 
setSuccess(GetNewBlockIdForFileTResponse) - Method in class alluxio.thrift.FileSystemMasterClientService.getNewBlockIdForFile_result
 
setSuccess(GetStatusTResponse) - Method in class alluxio.thrift.FileSystemMasterClientService.getStatus_result
 
setSuccess(ListStatusTResponse) - Method in class alluxio.thrift.FileSystemMasterClientService.listStatus_result
 
setSuccess(LoadMetadataTResponse) - Method in class alluxio.thrift.FileSystemMasterClientService.loadMetadata_result
 
setSuccess(MountTResponse) - Method in class alluxio.thrift.FileSystemMasterClientService.mount_result
 
setSuccess(DeleteTResponse) - Method in class alluxio.thrift.FileSystemMasterClientService.remove_result
 
setSuccess(RenameTResponse) - Method in class alluxio.thrift.FileSystemMasterClientService.rename_result
 
setSuccess(ScheduleAsyncPersistenceTResponse) - Method in class alluxio.thrift.FileSystemMasterClientService.scheduleAsyncPersistence_result
 
setSuccess(SetAttributeTResponse) - Method in class alluxio.thrift.FileSystemMasterClientService.setAttribute_result
 
setSuccess(UnmountTResponse) - Method in class alluxio.thrift.FileSystemMasterClientService.unmount_result
 
setSuccess(UpdateUfsModeTResponse) - Method in class alluxio.thrift.FileSystemMasterClientService.updateUfsMode_result
 
setSuccess(FileSystemHeartbeatTResponse) - Method in class alluxio.thrift.FileSystemMasterWorkerService.fileSystemHeartbeat_result
 
setSuccess(GetFileInfoTResponse) - Method in class alluxio.thrift.FileSystemMasterWorkerService.getFileInfo_result
 
setSuccess(GetPinnedFileIdsTResponse) - Method in class alluxio.thrift.FileSystemMasterWorkerService.getPinnedFileIds_result
 
setSuccess(GetUfsInfoTResponse) - Method in class alluxio.thrift.FileSystemMasterWorkerService.getUfsInfo_result
 
setSuccess(CancelUfsFileTResponse) - Method in class alluxio.thrift.FileSystemWorkerClientService.cancelUfsFile_result
 
setSuccess(CloseUfsFileTResponse) - Method in class alluxio.thrift.FileSystemWorkerClientService.closeUfsFile_result
 
setSuccess(CompleteUfsFileTReponse) - Method in class alluxio.thrift.FileSystemWorkerClientService.completeUfsFile_result
 
setSuccess(CreateUfsFileTResponse) - Method in class alluxio.thrift.FileSystemWorkerClientService.createUfsFile_result
 
setSuccess(OpenUfsFileTResponse) - Method in class alluxio.thrift.FileSystemWorkerClientService.openUfsFile_result
 
setSuccess(SessionFileSystemHeartbeatTResponse) - Method in class alluxio.thrift.FileSystemWorkerClientService.sessionFileSystemHeartbeat_result
 
setSuccess(CompletePartitionTResponse) - Method in class alluxio.thrift.KeyValueMasterClientService.completePartition_result
 
setSuccess(CompleteStoreTResponse) - Method in class alluxio.thrift.KeyValueMasterClientService.completeStore_result
 
setSuccess(CreateStoreTResponse) - Method in class alluxio.thrift.KeyValueMasterClientService.createStore_result
 
setSuccess(DeleteStoreTResponse) - Method in class alluxio.thrift.KeyValueMasterClientService.deleteStore_result
 
setSuccess(GetPartitionInfoTResponse) - Method in class alluxio.thrift.KeyValueMasterClientService.getPartitionInfo_result
 
setSuccess(MergeStoreTResponse) - Method in class alluxio.thrift.KeyValueMasterClientService.mergeStore_result
 
setSuccess(RenameStoreTResponse) - Method in class alluxio.thrift.KeyValueMasterClientService.renameStore_result
 
setSuccess(GetTResponse) - Method in class alluxio.thrift.KeyValueWorkerClientService.get_result
 
setSuccess(GetNextKeysTResponse) - Method in class alluxio.thrift.KeyValueWorkerClientService.getNextKeys_result
 
setSuccess(GetSizeTResponse) - Method in class alluxio.thrift.KeyValueWorkerClientService.getSize_result
 
setSuccess(CreateLineageTResponse) - Method in class alluxio.thrift.LineageMasterClientService.createLineage_result
 
setSuccess(DeleteLineageTResponse) - Method in class alluxio.thrift.LineageMasterClientService.deleteLineage_result
 
setSuccess(GetLineageInfoListTResponse) - Method in class alluxio.thrift.LineageMasterClientService.getLineageInfoList_result
 
setSuccess(ReinitializeFileTResponse) - Method in class alluxio.thrift.LineageMasterClientService.reinitializeFile_result
 
setSuccess(ReportLostFileTResponse) - Method in class alluxio.thrift.LineageMasterClientService.reportLostFile_result
 
setSuccess(BackupTResponse) - Method in class alluxio.thrift.MetaMasterClientService.backup_result
 
setSuccess(GetConfigReportTResponse) - Method in class alluxio.thrift.MetaMasterClientService.getConfigReport_result
 
setSuccess(GetConfigurationTResponse) - Method in class alluxio.thrift.MetaMasterClientService.getConfiguration_result
 
setSuccess(GetMasterInfoTResponse) - Method in class alluxio.thrift.MetaMasterClientService.getMasterInfo_result
 
setSuccess(GetMetricsTResponse) - Method in class alluxio.thrift.MetaMasterClientService.getMetrics_result
 
setSuccess(GetMasterIdTResponse) - Method in class alluxio.thrift.MetaMasterMasterService.getMasterId_result
 
setSuccess(MasterHeartbeatTResponse) - Method in class alluxio.thrift.MetaMasterMasterService.masterHeartbeat_result
 
setSuccess(RegisterMasterTResponse) - Method in class alluxio.thrift.MetaMasterMasterService.registerMaster_result
 
setSuccess(MetricsHeartbeatTResponse) - Method in class alluxio.thrift.MetricsMasterClientService.metricsHeartbeat_result
 
setSuccess(boolean) - Method in class alluxio.thrift.RequestSpaceTResponse
 
setSuccess(boolean) - Method in class alluxio.thrift.UnlockBlockTResponse
 
setSuccessIsSet(boolean) - Method in class alluxio.thrift.AlluxioService.getServiceVersion_result
 
setSuccessIsSet(boolean) - Method in class alluxio.thrift.BlockMasterClientService.getBlockInfo_result
 
setSuccessIsSet(boolean) - Method in class alluxio.thrift.BlockMasterClientService.getBlockMasterInfo_result
 
setSuccessIsSet(boolean) - Method in class alluxio.thrift.BlockMasterClientService.getCapacityBytes_result
 
setSuccessIsSet(boolean) - Method in class alluxio.thrift.BlockMasterClientService.getUsedBytes_result
 
setSuccessIsSet(boolean) - Method in class alluxio.thrift.BlockMasterClientService.getWorkerInfoList_result
 
setSuccessIsSet(boolean) - Method in class alluxio.thrift.BlockMasterClientService.getWorkerReport_result
 
setSuccessIsSet(boolean) - Method in class alluxio.thrift.BlockMasterWorkerService.blockHeartbeat_result
 
setSuccessIsSet(boolean) - Method in class alluxio.thrift.BlockMasterWorkerService.commitBlock_result
 
setSuccessIsSet(boolean) - Method in class alluxio.thrift.BlockMasterWorkerService.getWorkerId_result
 
setSuccessIsSet(boolean) - Method in class alluxio.thrift.BlockMasterWorkerService.registerWorker_result
 
setSuccessIsSet(boolean) - Method in class alluxio.thrift.BlockWorkerClientService.accessBlock_result
 
setSuccessIsSet(boolean) - Method in class alluxio.thrift.BlockWorkerClientService.cacheBlock_result
 
setSuccessIsSet(boolean) - Method in class alluxio.thrift.BlockWorkerClientService.cancelBlock_result
 
setSuccessIsSet(boolean) - Method in class alluxio.thrift.BlockWorkerClientService.lockBlock_result
 
setSuccessIsSet(boolean) - Method in class alluxio.thrift.BlockWorkerClientService.promoteBlock_result
 
setSuccessIsSet(boolean) - Method in class alluxio.thrift.BlockWorkerClientService.removeBlock_result
 
setSuccessIsSet(boolean) - Method in class alluxio.thrift.BlockWorkerClientService.requestBlockLocation_result
 
setSuccessIsSet(boolean) - Method in class alluxio.thrift.BlockWorkerClientService.requestSpace_result
 
setSuccessIsSet(boolean) - Method in class alluxio.thrift.BlockWorkerClientService.sessionBlockHeartbeat_result
 
setSuccessIsSet(boolean) - Method in class alluxio.thrift.BlockWorkerClientService.unlockBlock_result
 
setSuccessIsSet(boolean) - Method in class alluxio.thrift.DeleteLineageTResponse
 
setSuccessIsSet(boolean) - Method in class alluxio.thrift.FileSystemMasterClientService.checkConsistency_result
 
setSuccessIsSet(boolean) - Method in class alluxio.thrift.FileSystemMasterClientService.completeFile_result
 
setSuccessIsSet(boolean) - Method in class alluxio.thrift.FileSystemMasterClientService.createDirectory_result
 
setSuccessIsSet(boolean) - Method in class alluxio.thrift.FileSystemMasterClientService.createFile_result
 
setSuccessIsSet(boolean) - Method in class alluxio.thrift.FileSystemMasterClientService.free_result
 
setSuccessIsSet(boolean) - Method in class alluxio.thrift.FileSystemMasterClientService.getFilePath_result
 
setSuccessIsSet(boolean) - Method in class alluxio.thrift.FileSystemMasterClientService.getMountTable_result
 
setSuccessIsSet(boolean) - Method in class alluxio.thrift.FileSystemMasterClientService.getNewBlockIdForFile_result
 
setSuccessIsSet(boolean) - Method in class alluxio.thrift.FileSystemMasterClientService.getStatus_result
 
setSuccessIsSet(boolean) - Method in class alluxio.thrift.FileSystemMasterClientService.listStatus_result
 
setSuccessIsSet(boolean) - Method in class alluxio.thrift.FileSystemMasterClientService.loadMetadata_result
 
setSuccessIsSet(boolean) - Method in class alluxio.thrift.FileSystemMasterClientService.mount_result
 
setSuccessIsSet(boolean) - Method in class alluxio.thrift.FileSystemMasterClientService.remove_result
 
setSuccessIsSet(boolean) - Method in class alluxio.thrift.FileSystemMasterClientService.rename_result
 
setSuccessIsSet(boolean) - Method in class alluxio.thrift.FileSystemMasterClientService.scheduleAsyncPersistence_result
 
setSuccessIsSet(boolean) - Method in class alluxio.thrift.FileSystemMasterClientService.setAttribute_result
 
setSuccessIsSet(boolean) - Method in class alluxio.thrift.FileSystemMasterClientService.unmount_result
 
setSuccessIsSet(boolean) - Method in class alluxio.thrift.FileSystemMasterClientService.updateUfsMode_result
 
setSuccessIsSet(boolean) - Method in class alluxio.thrift.FileSystemMasterWorkerService.fileSystemHeartbeat_result
 
setSuccessIsSet(boolean) - Method in class alluxio.thrift.FileSystemMasterWorkerService.getFileInfo_result
 
setSuccessIsSet(boolean) - Method in class alluxio.thrift.FileSystemMasterWorkerService.getPinnedFileIds_result
 
setSuccessIsSet(boolean) - Method in class alluxio.thrift.FileSystemMasterWorkerService.getUfsInfo_result
 
setSuccessIsSet(boolean) - Method in class alluxio.thrift.FileSystemWorkerClientService.cancelUfsFile_result
 
setSuccessIsSet(boolean) - Method in class alluxio.thrift.FileSystemWorkerClientService.closeUfsFile_result
 
setSuccessIsSet(boolean) - Method in class alluxio.thrift.FileSystemWorkerClientService.completeUfsFile_result
 
setSuccessIsSet(boolean) - Method in class alluxio.thrift.FileSystemWorkerClientService.createUfsFile_result
 
setSuccessIsSet(boolean) - Method in class alluxio.thrift.FileSystemWorkerClientService.openUfsFile_result
 
setSuccessIsSet(boolean) - Method in class alluxio.thrift.FileSystemWorkerClientService.sessionFileSystemHeartbeat_result
 
setSuccessIsSet(boolean) - Method in class alluxio.thrift.KeyValueMasterClientService.completePartition_result
 
setSuccessIsSet(boolean) - Method in class alluxio.thrift.KeyValueMasterClientService.completeStore_result
 
setSuccessIsSet(boolean) - Method in class alluxio.thrift.KeyValueMasterClientService.createStore_result
 
setSuccessIsSet(boolean) - Method in class alluxio.thrift.KeyValueMasterClientService.deleteStore_result
 
setSuccessIsSet(boolean) - Method in class alluxio.thrift.KeyValueMasterClientService.getPartitionInfo_result
 
setSuccessIsSet(boolean) - Method in class alluxio.thrift.KeyValueMasterClientService.mergeStore_result
 
setSuccessIsSet(boolean) - Method in class alluxio.thrift.KeyValueMasterClientService.renameStore_result
 
setSuccessIsSet(boolean) - Method in class alluxio.thrift.KeyValueWorkerClientService.get_result
 
setSuccessIsSet(boolean) - Method in class alluxio.thrift.KeyValueWorkerClientService.getNextKeys_result
 
setSuccessIsSet(boolean) - Method in class alluxio.thrift.KeyValueWorkerClientService.getSize_result
 
setSuccessIsSet(boolean) - Method in class alluxio.thrift.LineageMasterClientService.createLineage_result
 
setSuccessIsSet(boolean) - Method in class alluxio.thrift.LineageMasterClientService.deleteLineage_result
 
setSuccessIsSet(boolean) - Method in class alluxio.thrift.LineageMasterClientService.getLineageInfoList_result
 
setSuccessIsSet(boolean) - Method in class alluxio.thrift.LineageMasterClientService.reinitializeFile_result
 
setSuccessIsSet(boolean) - Method in class alluxio.thrift.LineageMasterClientService.reportLostFile_result
 
setSuccessIsSet(boolean) - Method in class alluxio.thrift.MetaMasterClientService.backup_result
 
setSuccessIsSet(boolean) - Method in class alluxio.thrift.MetaMasterClientService.getConfigReport_result
 
setSuccessIsSet(boolean) - Method in class alluxio.thrift.MetaMasterClientService.getConfiguration_result
 
setSuccessIsSet(boolean) - Method in class alluxio.thrift.MetaMasterClientService.getMasterInfo_result
 
setSuccessIsSet(boolean) - Method in class alluxio.thrift.MetaMasterClientService.getMetrics_result
 
setSuccessIsSet(boolean) - Method in class alluxio.thrift.MetaMasterMasterService.getMasterId_result
 
setSuccessIsSet(boolean) - Method in class alluxio.thrift.MetaMasterMasterService.masterHeartbeat_result
 
setSuccessIsSet(boolean) - Method in class alluxio.thrift.MetaMasterMasterService.registerMaster_result
 
setSuccessIsSet(boolean) - Method in class alluxio.thrift.MetricsMasterClientService.metricsHeartbeat_result
 
setSuccessIsSet(boolean) - Method in class alluxio.thrift.RequestSpaceTResponse
 
setSuccessIsSet(boolean) - Method in class alluxio.thrift.UnlockBlockTResponse
 
setSynced(boolean) - Method in class alluxio.thrift.SyncMetadataTResponse
 
setSyncedIsSet(boolean) - Method in class alluxio.thrift.SyncMetadataTResponse
 
setSyncIntervalMs(long) - Method in class alluxio.thrift.FileSystemMasterCommonTOptions
 
setSyncIntervalMs(long) - Method in class alluxio.wire.CommonOptions
 
setSyncIntervalMsIsSet(boolean) - Method in class alluxio.thrift.FileSystemMasterCommonTOptions
 
setTags(Map<String, String>) - Method in class alluxio.thrift.Metric
 
setTagsIsSet(boolean) - Method in class alluxio.thrift.Metric
 
setTargetDirectory(String) - Method in class alluxio.thrift.BackupTOptions
 
setTargetDirectoryIsSet(boolean) - Method in class alluxio.thrift.BackupTOptions
 
setTempUfsFileId(long) - Method in class alluxio.thrift.FileSystemWorkerClientService.cancelUfsFile_args
the worker specific file id of the ufs file
setTempUfsFileId(long) - Method in class alluxio.thrift.FileSystemWorkerClientService.closeUfsFile_args
the worker specific file id of the ufs file
setTempUfsFileId(long) - Method in class alluxio.thrift.FileSystemWorkerClientService.completeUfsFile_args
the worker specific file id of the ufs file
setTempUfsFileIdIsSet(boolean) - Method in class alluxio.thrift.FileSystemWorkerClientService.cancelUfsFile_args
 
setTempUfsFileIdIsSet(boolean) - Method in class alluxio.thrift.FileSystemWorkerClientService.closeUfsFile_args
 
setTempUfsFileIdIsSet(boolean) - Method in class alluxio.thrift.FileSystemWorkerClientService.completeUfsFile_args
 
setThrowOnTimeout(boolean) - Method in class alluxio.util.WaitForOptions
 
setTier(int) - Method in class alluxio.proto.dataserver.Protocol.LocalBlockCreateRequest.Builder
optional int32 tier = 3;
setTier(int) - Method in class alluxio.proto.dataserver.Protocol.WriteRequest.Builder
optional int32 tier = 4;
setTierAlias(String) - Method in class alluxio.thrift.BlockLocation
 
setTierAlias(String) - Method in class alluxio.thrift.BlockMasterWorkerService.commitBlock_args
the alias of the target tier
setTierAlias(String) - Method in class alluxio.wire.BlockLocation
 
setTierAliasIsSet(boolean) - Method in class alluxio.thrift.BlockLocation
 
setTierAliasIsSet(boolean) - Method in class alluxio.thrift.BlockMasterWorkerService.commitBlock_args
 
setTierCapacity(Map<String, Capacity>) - Method in class alluxio.wire.AlluxioMasterInfo
 
setTierCapacity(Map<String, Capacity>) - Method in class alluxio.wire.AlluxioWorkerInfo
 
setTieredIdentity(TieredIdentity) - Method in class alluxio.thrift.WorkerNetAddress
 
setTieredIdentity(TieredIdentity) - Method in class alluxio.wire.WorkerNetAddress
 
setTieredIdentityIsSet(boolean) - Method in class alluxio.thrift.WorkerNetAddress
 
setTierName(String) - Method in class alluxio.thrift.LocalityTier
 
setTierNameIsSet(boolean) - Method in class alluxio.thrift.LocalityTier
 
setTierPaths(Map<String, List<String>>) - Method in class alluxio.wire.AlluxioWorkerInfo
 
setTiers(List<LocalityTier>) - Method in class alluxio.thrift.TieredIdentity
 
setTiersIsSet(boolean) - Method in class alluxio.thrift.TieredIdentity
 
setTimeout(long) - Method in class alluxio.network.netty.NettyRPCContext
 
setTimeoutMs(int) - Method in class alluxio.util.WaitForOptions
 
setToPath(String) - Method in class alluxio.thrift.KeyValueMasterClientService.mergeStore_args
the path of the store to be merged to
setToPathIsSet(boolean) - Method in class alluxio.thrift.KeyValueMasterClientService.mergeStore_args
 
setToStoreId(long) - Method in class alluxio.proto.journal.KeyValue.MergeStoreEntry.Builder
optional int64 to_store_id = 2;
setTotal(long) - Method in class alluxio.wire.Capacity
 
setTotalBytesOnTiers(Map<String, Long>) - Method in class alluxio.thrift.BlockMasterWorkerService.registerWorker_args
the map of total bytes on each tier
setTotalBytesOnTiersIsSet(boolean) - Method in class alluxio.thrift.BlockMasterWorkerService.registerWorker_args
 
setTtl(FileSystem, AlluxioURI, long, TtlAction) - Static method in class alluxio.cli.fs.command.FileSystemCommandUtils
Sets a new TTL value or unsets an existing TTL value for file at path.
setTtl(long) - Method in class alluxio.client.file.options.CreateDirectoryOptions
 
setTtl(long) - Method in class alluxio.client.file.options.CreateFileOptions
 
setTtl(long) - Method in class alluxio.client.file.options.OutStreamOptions
Sets the time to live.
setTtl(long) - Method in class alluxio.client.file.options.SetAttributeOptions
 
setTtl(long) - Method in class alluxio.master.file.meta.Inode
 
setTtl(long) - Method in class alluxio.master.file.options.CreateDirectoryOptions
 
setTtl(long) - Method in class alluxio.master.file.options.CreateFileOptions
 
setTtl(long) - Method in class alluxio.master.file.options.SetAttributeOptions
 
setTtl(long) - Method in class alluxio.proto.journal.File.InodeDirectoryEntry.Builder
optional int64 ttl = 13;
setTtl(long) - Method in class alluxio.proto.journal.File.InodeFileEntry.Builder
optional int64 ttl = 13;
setTtl(long) - Method in class alluxio.proto.journal.File.ReinitializeFileEntry.Builder
optional int64 ttl = 3;
setTtl(long) - Method in class alluxio.proto.journal.File.SetAttributeEntry.Builder
optional int64 ttl = 4;
setTtl(long) - Method in class alluxio.thrift.CreateDirectoryTOptions
 
setTtl(long) - Method in class alluxio.thrift.CreateFileTOptions
 
setTtl(long) - Method in class alluxio.thrift.FileInfo
 
setTtl(long) - Method in class alluxio.thrift.LineageMasterClientService.reinitializeFile_args
time to live
setTtl(long) - Method in class alluxio.thrift.SetAttributeTOptions
 
setTtl(long) - Method in class alluxio.wire.FileInfo
 
setTtlAction(TtlAction) - Method in class alluxio.client.file.options.CreateDirectoryOptions
 
setTtlAction(TtlAction) - Method in class alluxio.client.file.options.CreateFileOptions
 
setTtlAction(TtlAction) - Method in class alluxio.client.file.options.OutStreamOptions
 
setTtlAction(TtlAction) - Method in class alluxio.client.file.options.SetAttributeOptions
 
setTtlAction(TtlAction) - Method in class alluxio.master.file.meta.Inode
 
setTtlAction(TtlAction) - Method in class alluxio.master.file.options.CreateDirectoryOptions
 
setTtlAction(TtlAction) - Method in class alluxio.master.file.options.CreateFileOptions
 
setTtlAction(TtlAction) - Method in class alluxio.master.file.options.SetAttributeOptions
 
setTtlAction(File.PTtlAction) - Method in class alluxio.proto.journal.File.InodeDirectoryEntry.Builder
optional .alluxio.proto.journal.PTtlAction ttlAction = 14 [default = DELETE];
setTtlAction(File.PTtlAction) - Method in class alluxio.proto.journal.File.InodeFileEntry.Builder
optional .alluxio.proto.journal.PTtlAction ttlAction = 17 [default = DELETE];
setTtlAction(File.PTtlAction) - Method in class alluxio.proto.journal.File.ReinitializeFileEntry.Builder
optional .alluxio.proto.journal.PTtlAction ttlAction = 4 [default = DELETE];
setTtlAction(File.PTtlAction) - Method in class alluxio.proto.journal.File.SetAttributeEntry.Builder
optional .alluxio.proto.journal.PTtlAction ttlAction = 9 [default = DELETE];
setTtlAction(TTtlAction) - Method in class alluxio.thrift.CreateDirectoryTOptions
 
setTtlAction(TTtlAction) - Method in class alluxio.thrift.CreateFileTOptions
 
setTtlAction(TTtlAction) - Method in class alluxio.thrift.FileInfo
 
setTtlAction(TTtlAction) - Method in class alluxio.thrift.LineageMasterClientService.reinitializeFile_args
expiry action
setTtlAction(TTtlAction) - Method in class alluxio.thrift.SetAttributeTOptions
 
setTtlAction(TtlAction) - Method in class alluxio.wire.FileInfo
 
setTtlActionIsSet(boolean) - Method in class alluxio.thrift.CreateDirectoryTOptions
 
setTtlActionIsSet(boolean) - Method in class alluxio.thrift.CreateFileTOptions
 
setTtlActionIsSet(boolean) - Method in class alluxio.thrift.FileInfo
 
setTtlActionIsSet(boolean) - Method in class alluxio.thrift.LineageMasterClientService.reinitializeFile_args
 
setTtlActionIsSet(boolean) - Method in class alluxio.thrift.SetAttributeTOptions
 
SetTtlCommand - Class in alluxio.cli.fs.command
Sets a new TTL value for the file at path both of the TTL value and the path are specified by args.
SetTtlCommand(FileSystem) - Constructor for class alluxio.cli.fs.command.SetTtlCommand
 
setTtlIsSet(boolean) - Method in class alluxio.thrift.CreateDirectoryTOptions
 
setTtlIsSet(boolean) - Method in class alluxio.thrift.CreateFileTOptions
 
setTtlIsSet(boolean) - Method in class alluxio.thrift.FileInfo
 
setTtlIsSet(boolean) - Method in class alluxio.thrift.LineageMasterClientService.reinitializeFile_args
 
setTtlIsSet(boolean) - Method in class alluxio.thrift.SetAttributeTOptions
 
setType(Protocol.ReadResponse.Type) - Method in class alluxio.proto.dataserver.Protocol.ReadResponse.Builder
optional .alluxio.proto.dataserver.ReadResponse.Type type = 1;
setType(Protocol.RequestType) - Method in class alluxio.proto.dataserver.Protocol.WriteRequest.Builder
optional .alluxio.proto.dataserver.RequestType type = 1;
setUfsCapacity(Capacity) - Method in class alluxio.wire.AlluxioMasterInfo
 
setUfsCapacityBytes(long) - Method in class alluxio.thrift.MountPointInfo
 
setUfsCapacityBytes(long) - Method in class alluxio.wire.MountPointInfo
 
setUfsCapacityBytesIsSet(boolean) - Method in class alluxio.thrift.MountPointInfo
 
setUfsFingerprint(String) - Method in class alluxio.master.file.meta.Inode
 
setUfsFingerprint(String) - Method in class alluxio.master.file.options.SetAttributeOptions
 
setUfsFingerprint(String) - Method in class alluxio.proto.journal.File.CompleteFileEntry.Builder
optional string ufs_fingerprint = 5;
setUfsFingerprint(String) - Method in class alluxio.proto.journal.File.InodeFileEntry.Builder
optional string ufs_fingerprint = 18;
setUfsFingerprint(String) - Method in class alluxio.proto.journal.File.SetAttributeEntry.Builder
optional string ufs_fingerprint = 10;
setUfsFingerprint(String) - Method in class alluxio.thrift.FileInfo
 
setUfsFingerprint(String) - Method in class alluxio.wire.FileInfo
 
setUfsFingerprintBytes(ByteString) - Method in class alluxio.proto.journal.File.CompleteFileEntry.Builder
optional string ufs_fingerprint = 5;
setUfsFingerprintBytes(ByteString) - Method in class alluxio.proto.journal.File.InodeFileEntry.Builder
optional string ufs_fingerprint = 18;
setUfsFingerprintBytes(ByteString) - Method in class alluxio.proto.journal.File.SetAttributeEntry.Builder
optional string ufs_fingerprint = 10;
setUfsFingerprintIsSet(boolean) - Method in class alluxio.thrift.FileInfo
 
setUfsInfo(UfsInfo) - Method in class alluxio.thrift.GetUfsInfoTResponse
 
setUfsInfoIsSet(boolean) - Method in class alluxio.thrift.GetUfsInfoTResponse
 
setUfsLength(long) - Method in class alluxio.client.file.options.CompleteFileOptions
 
setUfsLength(long) - Method in class alluxio.master.file.options.CompleteFileOptions
 
setUfsLength(long) - Method in class alluxio.thrift.CompleteFileTOptions
 
setUfsLengthIsSet(boolean) - Method in class alluxio.thrift.CompleteFileTOptions
 
setUfsLocations(List<WorkerNetAddress>) - Method in class alluxio.thrift.FileBlockInfo
 
setUfsLocations(List<String>) - Method in class alluxio.wire.FileBlockInfo
 
setUfsLocationsIsSet(boolean) - Method in class alluxio.thrift.FileBlockInfo
 
setUfsMode(UnderFileSystem.UfsMode) - Method in class alluxio.client.file.options.UpdateUfsModeOptions
 
setUfsMode(File.UfsMode) - Method in class alluxio.proto.journal.File.UpdateUfsModeEntry.Builder
optional .alluxio.proto.journal.UfsMode ufsMode = 2 [default = READ_WRITE];
setUfsMode(UfsMode) - Method in class alluxio.thrift.UpdateUfsModeTOptions
 
setUfsMode(AlluxioURI, UnderFileSystem.UfsMode, RpcContext) - Method in class alluxio.underfs.MasterUfsManager
Set the operation mode the given physical ufs.
setUfsModeIsSet(boolean) - Method in class alluxio.thrift.UpdateUfsModeTOptions
 
setUfsPath(String) - Method in class alluxio.client.block.options.LockBlockOptions
 
setUfsPath(String) - Method in class alluxio.client.file.options.OutStreamOptions
 
setUfsPath(String) - Method in class alluxio.proto.dataserver.Protocol.CreateUfsFileOptions.Builder
optional string ufs_path = 1;
setUfsPath(String) - Method in class alluxio.proto.dataserver.Protocol.OpenUfsBlockOptions.Builder
optional string ufs_path = 1;
setUfsPath(String) - Method in class alluxio.proto.journal.File.AddMountPointEntry.Builder
optional string ufs_path = 2;
setUfsPath(String) - Method in class alluxio.proto.journal.File.UpdateUfsModeEntry.Builder
optional string ufsPath = 1;
setUfsPath(String) - Method in class alluxio.thrift.FileInfo
 
setUfsPath(String) - Method in class alluxio.thrift.FileSystemMasterClientService.loadMetadata_args
the path of the under file system
setUfsPath(String) - Method in class alluxio.thrift.FileSystemMasterClientService.mount_args
the path of the under file system
setUfsPath(String) - Method in class alluxio.thrift.FileSystemMasterClientService.updateUfsMode_args
the ufs path
setUfsPath(String) - Method in class alluxio.thrift.FileSystemWorkerClientService.createUfsFile_args
the path of the file in the ufs
setUfsPath(String) - Method in class alluxio.thrift.FileSystemWorkerClientService.openUfsFile_args
the path of the file in the ufs
setUfsPath(String) - Method in class alluxio.thrift.LockBlockTOptions
 
setUfsPath(String) - Method in class alluxio.wire.FileInfo
 
setUfsPathBytes(ByteString) - Method in class alluxio.proto.dataserver.Protocol.CreateUfsFileOptions.Builder
optional string ufs_path = 1;
setUfsPathBytes(ByteString) - Method in class alluxio.proto.dataserver.Protocol.OpenUfsBlockOptions.Builder
optional string ufs_path = 1;
setUfsPathBytes(ByteString) - Method in class alluxio.proto.journal.File.AddMountPointEntry.Builder
optional string ufs_path = 2;
setUfsPathBytes(ByteString) - Method in class alluxio.proto.journal.File.UpdateUfsModeEntry.Builder
optional string ufsPath = 1;
setUfsPathIsSet(boolean) - Method in class alluxio.thrift.FileInfo
 
setUfsPathIsSet(boolean) - Method in class alluxio.thrift.FileSystemMasterClientService.loadMetadata_args
 
setUfsPathIsSet(boolean) - Method in class alluxio.thrift.FileSystemMasterClientService.mount_args
 
setUfsPathIsSet(boolean) - Method in class alluxio.thrift.FileSystemMasterClientService.updateUfsMode_args
 
setUfsPathIsSet(boolean) - Method in class alluxio.thrift.FileSystemWorkerClientService.createUfsFile_args
 
setUfsPathIsSet(boolean) - Method in class alluxio.thrift.FileSystemWorkerClientService.openUfsFile_args
 
setUfsPathIsSet(boolean) - Method in class alluxio.thrift.LockBlockTOptions
 
setUfsReadLocationPolicy(BlockLocationPolicy) - Method in class alluxio.client.file.options.OpenFileOptions
 
setUfsReadLocationPolicyClass(String) - Method in class alluxio.client.file.options.OpenFileOptions
 
setUfsResource(CloseableResource<UnderFileSystem>) - Method in class alluxio.worker.netty.UfsFileWriteRequestContext
 
setUfsStatus(UfsStatus) - Method in class alluxio.master.file.options.CompleteFileOptions
 
setUfsStatus(UfsStatus) - Method in class alluxio.master.file.options.CreateDirectoryOptions
 
setUfsStatus(UfsStatus) - Method in class alluxio.master.file.options.LoadMetadataOptions
Sets the UFS status of path.
setUfsStringLocations(List<String>) - Method in class alluxio.thrift.FileBlockInfo
 
setUfsStringLocationsIsSet(boolean) - Method in class alluxio.thrift.FileBlockInfo
 
setUfsType(String) - Method in class alluxio.thrift.MountPointInfo
 
setUfsType(String) - Method in class alluxio.wire.MountPointInfo
 
setUfsTypeIsSet(boolean) - Method in class alluxio.thrift.MountPointInfo
 
setUfsUri(String) - Method in class alluxio.thrift.MountPointInfo
 
setUfsUri(String) - Method in class alluxio.wire.MountPointInfo
 
setUfsUriIsSet(boolean) - Method in class alluxio.thrift.MountPointInfo
 
setUfsUsedBytes(long) - Method in class alluxio.thrift.MountPointInfo
 
setUfsUsedBytes(long) - Method in class alluxio.wire.MountPointInfo
 
setUfsUsedBytesIsSet(boolean) - Method in class alluxio.thrift.MountPointInfo
 
setUgi(String) - Method in class alluxio.master.file.FileSystemMasterAuditContext
Sets mUgi field.
setUnchecked(boolean) - Method in class alluxio.client.file.options.DeleteOptions
 
setUnchecked(boolean) - Method in class alluxio.master.file.options.DeleteOptions
 
setUnchecked(boolean) - Method in class alluxio.thrift.DeleteTOptions
 
setUncheckedIsSet(boolean) - Method in class alluxio.thrift.DeleteTOptions
 
setUpdateUfsMode(File.UpdateUfsModeEntry) - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
optional .alluxio.proto.journal.UpdateUfsModeEntry update_ufs_mode = 30;
setUpdateUfsMode(File.UpdateUfsModeEntry.Builder) - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
optional .alluxio.proto.journal.UpdateUfsModeEntry update_ufs_mode = 30;
setUploadId(String) - Method in class alluxio.proxy.s3.InitiateMultipartUploadResult
 
setUploadId(String) - Method in class alluxio.proxy.s3.ListPartsResult
 
setupTest() - Method in class alluxio.master.AbstractLocalAlluxioCluster
Sets up corresponding directories for tests.
setUpTimeMs(long) - Method in class alluxio.thrift.MasterInfo
 
setUptimeMs(long) - Method in class alluxio.wire.AlluxioMasterInfo
 
setUptimeMs(long) - Method in class alluxio.wire.AlluxioProxyInfo
 
setUptimeMs(long) - Method in class alluxio.wire.AlluxioWorkerInfo
 
setUpTimeMs(long) - Method in class alluxio.wire.MasterInfo
 
setUpTimeMsIsSet(boolean) - Method in class alluxio.thrift.MasterInfo
 
setUri(String) - Method in class alluxio.thrift.UfsInfo
 
setUriIsSet(boolean) - Method in class alluxio.thrift.UfsInfo
 
setUsed(long) - Method in class alluxio.wire.Capacity
 
setUsedBytes(long) - Method in class alluxio.thrift.BlockMasterInfo
 
setUsedBytes(long) - Method in class alluxio.thrift.WorkerInfo
 
setUsedBytes(long) - Method in class alluxio.wire.BlockMasterInfo
 
setUsedBytes(long) - Method in class alluxio.wire.WorkerInfo
 
setUsedBytesIsSet(boolean) - Method in class alluxio.thrift.BlockMasterInfo
 
setUsedBytesIsSet(boolean) - Method in class alluxio.thrift.WorkerInfo
 
setUsedBytesOnTier(long) - Method in class alluxio.thrift.BlockMasterWorkerService.commitBlock_args
the space used in bytes on the target tier
setUsedBytesOnTierIsSet(boolean) - Method in class alluxio.thrift.BlockMasterWorkerService.commitBlock_args
 
setUsedBytesOnTiers(Map<String, Long>) - Method in class alluxio.thrift.BlockMasterInfo
 
setUsedBytesOnTiers(Map<String, Long>) - Method in class alluxio.thrift.BlockMasterWorkerService.blockHeartbeat_args
the map of space used in bytes on all tiers
setUsedBytesOnTiers(Map<String, Long>) - Method in class alluxio.thrift.BlockMasterWorkerService.registerWorker_args
the map of used bytes on each tier
setUsedBytesOnTiers(Map<String, Long>) - Method in class alluxio.thrift.WorkerInfo
 
setUsedBytesOnTiers(Map<String, Long>) - Method in class alluxio.wire.BlockMasterInfo
 
setUsedBytesOnTiers(Map<String, Long>) - Method in class alluxio.wire.WorkerInfo
 
setUsedBytesOnTiersIsSet(boolean) - Method in class alluxio.thrift.BlockMasterInfo
 
setUsedBytesOnTiersIsSet(boolean) - Method in class alluxio.thrift.BlockMasterWorkerService.blockHeartbeat_args
 
setUsedBytesOnTiersIsSet(boolean) - Method in class alluxio.thrift.BlockMasterWorkerService.registerWorker_args
 
setUsedBytesOnTiersIsSet(boolean) - Method in class alluxio.thrift.WorkerInfo
 
setUser(String) - Method in class alluxio.proto.dataserver.Protocol.OpenUfsBlockOptions.Builder
optional string user = 7;
setUserBytes(ByteString) - Method in class alluxio.proto.dataserver.Protocol.OpenUfsBlockOptions.Builder
optional string user = 7;
setUserSpecifiedConf(Map<String, String>) - Method in class alluxio.underfs.UnderFileSystemConfiguration
 
setValue(String) - Method in class alluxio.master.meta.checkconf.ConfigRecord
 
setValue(double) - Method in class alluxio.metrics.Metric
Set the metric value.
setValue(String) - Method in class alluxio.proto.journal.File.StringPairEntry.Builder
optional string value = 2;
setValue(String) - Method in class alluxio.thrift.ConfigProperty
 
setValue(String) - Method in class alluxio.thrift.LocalityTier
 
setValue(double) - Method in class alluxio.thrift.Metric
 
setValue(String) - Method in class alluxio.thrift.OptionalString
 
setValue(String) - Method in class alluxio.wire.ConfigProperty
 
setValueBytes(ByteString) - Method in class alluxio.proto.journal.File.StringPairEntry.Builder
optional string value = 2;
setValueIsSet(boolean) - Method in class alluxio.thrift.ConfigProperty
 
setValueIsSet(boolean) - Method in class alluxio.thrift.LocalityTier
 
setValueIsSet(boolean) - Method in class alluxio.thrift.Metric
 
setValueIsSet(boolean) - Method in class alluxio.thrift.OptionalString
 
setValues(Map<OptionalString, List<String>>) - Method in class alluxio.thrift.InconsistentProperty
 
setValues(Map<Optional<String>, List<String>>) - Method in class alluxio.wire.InconsistentProperty
 
setValuesIsSet(boolean) - Method in class alluxio.thrift.InconsistentProperty
 
setVersion(long) - Method in class alluxio.thrift.GetServiceVersionTResponse
 
setVersion(String) - Method in class alluxio.thrift.MasterInfo
 
setVersion(String) - Method in class alluxio.wire.AlluxioMasterInfo
 
setVersion(String) - Method in class alluxio.wire.AlluxioProxyInfo
 
setVersion(String) - Method in class alluxio.wire.AlluxioWorkerInfo
 
setVersion(String) - Method in class alluxio.wire.MasterInfo
 
setVersionIsSet(boolean) - Method in class alluxio.thrift.GetServiceVersionTResponse
 
setVersionIsSet(boolean) - Method in class alluxio.thrift.MasterInfo
 
setWarns(Map<Scope, List<InconsistentProperty>>) - Method in class alluxio.thrift.ConfigCheckReport
 
setWarnsIsSet(boolean) - Method in class alluxio.thrift.ConfigCheckReport
 
setWebPort(int) - Method in class alluxio.thrift.MasterInfo
 
setWebPort(int) - Method in class alluxio.thrift.WorkerNetAddress
 
setWebPort(int) - Method in class alluxio.wire.MasterInfo
 
setWebPort(int) - Method in class alluxio.wire.WorkerNetAddress
 
setWebPortIsSet(boolean) - Method in class alluxio.thrift.MasterInfo
 
setWebPortIsSet(boolean) - Method in class alluxio.thrift.WorkerNetAddress
 
setWorkerAddress(WorkerNetAddress) - Method in class alluxio.thrift.BlockLocation
 
setWorkerAddress(WorkerNetAddress) - Method in class alluxio.wire.BlockLocation
 
setWorkerAddresses(List<MasterNetAddress>) - Method in class alluxio.thrift.MasterInfo
 
setWorkerAddresses(List<Address>) - Method in class alluxio.wire.MasterInfo
 
setWorkerAddressesIsSet(boolean) - Method in class alluxio.thrift.MasterInfo
 
setWorkerAddressIsSet(boolean) - Method in class alluxio.thrift.BlockLocation
 
setWorkerId(long) - Method in class alluxio.thrift.BlockLocation
 
setWorkerId(long) - Method in class alluxio.thrift.BlockMasterWorkerService.blockHeartbeat_args
the id of the worker
setWorkerId(long) - Method in class alluxio.thrift.BlockMasterWorkerService.commitBlock_args
the id of the worker
setWorkerId(long) - Method in class alluxio.thrift.BlockMasterWorkerService.registerWorker_args
the id of the worker
setWorkerId(long) - Method in class alluxio.thrift.FileSystemMasterWorkerService.fileSystemHeartbeat_args
the id of the worker
setWorkerId(long) - Method in class alluxio.thrift.GetWorkerIdTResponse
 
setWorkerId(long) - Method in class alluxio.wire.BlockLocation
 
setWorkerIdIsSet(boolean) - Method in class alluxio.thrift.BlockLocation
 
setWorkerIdIsSet(boolean) - Method in class alluxio.thrift.BlockMasterWorkerService.blockHeartbeat_args
 
setWorkerIdIsSet(boolean) - Method in class alluxio.thrift.BlockMasterWorkerService.commitBlock_args
 
setWorkerIdIsSet(boolean) - Method in class alluxio.thrift.BlockMasterWorkerService.registerWorker_args
 
setWorkerIdIsSet(boolean) - Method in class alluxio.thrift.FileSystemMasterWorkerService.fileSystemHeartbeat_args
 
setWorkerIdIsSet(boolean) - Method in class alluxio.thrift.GetWorkerIdTResponse
 
setWorkerInfoList(List<WorkerInfo>) - Method in class alluxio.thrift.GetWorkerInfoListTResponse
 
setWorkerInfoListIsSet(boolean) - Method in class alluxio.thrift.GetWorkerInfoListTResponse
 
setWorkerNetAddress(WorkerNetAddress) - Method in class alluxio.thrift.BlockMasterWorkerService.getWorkerId_args
the worker network address
setWorkerNetAddressIsSet(boolean) - Method in class alluxio.thrift.BlockMasterWorkerService.getWorkerId_args
 
setWorkerProperties(Map<Integer, Map<PropertyKey, String>>) - Method in class alluxio.multi.process.MultiProcessCluster.Builder
Sets worker specific properties.
setWorkerRange(GetWorkerReportOptions.WorkerRange) - Method in class alluxio.client.block.options.GetWorkerReportOptions
 
setWorkerRange(WorkerRange) - Method in class alluxio.thrift.GetWorkerReportTOptions
 
setWorkerRangeIsSet(boolean) - Method in class alluxio.thrift.GetWorkerReportTOptions
 
setWorkers(List<WorkerInfo>) - Method in class alluxio.wire.AlluxioMasterInfo
 
setWriteTier(int) - Method in class alluxio.client.file.options.CreateFileOptions
 
setWriteTier(int) - Method in class alluxio.client.file.options.OutStreamOptions
Sets the write tier.
setWriteTier(int) - Method in class alluxio.thrift.BlockWorkerClientService.requestBlockLocation_args
the target tier to write to
setWriteTierIsSet(boolean) - Method in class alluxio.thrift.BlockWorkerClientService.requestBlockLocation_args
 
setWriteType(WriteType) - Method in class alluxio.client.file.options.CreateDirectoryOptions
 
setWriteType(WriteType) - Method in class alluxio.client.file.options.CreateFileOptions
 
setWriteType(WriteType) - Method in class alluxio.client.file.options.OutStreamOptions
Sets the WriteType.
setZookeeperAddresses(List<String>) - Method in class alluxio.thrift.MasterInfo
 
setZookeeperAddresses(List<String>) - Method in class alluxio.wire.MasterInfo
 
setZookeeperAddressesIsSet(boolean) - Method in class alluxio.thrift.MasterInfo
 
SHARED_FIELD_NUMBER - Static variable in class alluxio.proto.journal.File.AddMountPointEntry
 
ShellBasedUnixGroupsMapping - Class in alluxio.security.group.provider
A simple shell-based implementation of GroupMappingService that exec's the groups shell command to fetch the group memberships of a given user.
ShellBasedUnixGroupsMapping() - Constructor for class alluxio.security.group.provider.ShellBasedUnixGroupsMapping
Constructs a new ShellBasedUnixGroupsMapping.
ShellUtils - Class in alluxio.util
A utility class for running Unix commands.
ShellUtils.ExitCodeException - Exception in alluxio.util
This is an IOException with exit code added.
shouldGc(DynamicResourcePool<BlockMasterClient>.ResourceInternal<BlockMasterClient>) - Method in class alluxio.client.block.BlockMasterClientPool
 
shouldGc(DynamicResourcePool<FileSystemMasterClient>.ResourceInternal<FileSystemMasterClient>) - Method in class alluxio.client.file.FileSystemMasterClientPool
 
shouldGc(DynamicResourcePool<Channel>.ResourceInternal<Channel>) - Method in class alluxio.network.netty.NettyChannelPool
 
shouldGc(DynamicResourcePool<T>.ResourceInternal<T>) - Method in class alluxio.resource.DynamicResourcePool
 
shouldSkip() - Method in class alluxio.cli.validation.HdfsValidationTask
 
shouldSkip() - Method in class alluxio.cli.validation.SecureHdfsValidationTask
 
shouldSync() - Method in class alluxio.master.file.meta.LockingScheme
 
shouldSyncPath(String, long) - Method in class alluxio.master.file.meta.UfsSyncPathCache
 
shouldUseDisplayValue() - Method in class alluxio.ConfigurationValueOptions
 
shouldUseRawValue() - Method in class alluxio.ConfigurationValueOptions
 
ShowKeyValueStore - Class in alluxio.examples.keyvalue
Prints out (key, value) pairs, or only keys, or only values in a key-value store.
shutdown() - Method in class alluxio.util.executor.ControllableScheduler
 
shutdownAndAwaitTermination(ExecutorService) - Static method in class alluxio.util.ThreadUtils
From https://docs.oracle.com/javase/7/docs/api/java/util/concurrent/ExecutorService.html The following method shuts down an ExecutorService in two phases, first by calling shutdown to reject incoming tasks, and then calling shutdownNow, if necessary, to cancel any lingering tasks.
shutdownNow() - Method in class alluxio.util.executor.ControllableScheduler
 
signalLosePrimacy() - Method in class alluxio.master.journal.ufs.UfsJournal
Notifies this journal that it is no longer primary.
SimpleAuthenticationProvider - Class in alluxio.security.authentication
An authentication provider implementation that allows arbitrary combination of username and password including empty strings.
SimpleAuthenticationProvider() - Constructor for class alluxio.security.authentication.SimpleAuthenticationProvider
singleElementIterator(T) - Static method in class alluxio.util.CommonUtils
Returns an iterator that iterates on a single element.
SingleMasterConnectDetails(InetSocketAddress) - Constructor for class alluxio.master.SingleMasterInquireClient.SingleMasterConnectDetails
 
SingleMasterInquireClient - Class in alluxio.master
A MasterInquireClient which always returns a fixed master address.
SingleMasterInquireClient(InetSocketAddress) - Constructor for class alluxio.master.SingleMasterInquireClient
 
SingleMasterInquireClient.SingleMasterConnectDetails - Class in alluxio.master
Connect details for a single master inquire client.
SingleTagValueAggregator - Class in alluxio.metrics.aggregator
An aggregator that aggregates the metrics into multiple values based on a single tag of the metric.
SingleTagValueAggregator(String, MetricsSystem.InstanceType, String, String) - Constructor for class alluxio.metrics.aggregator.SingleTagValueAggregator
Constructs a new instance of SingleTagValueAggregator.
SingleValueAggregator - Interface in alluxio.metrics
Interface for the aggregator that aggregates into a single value from the metrics of different hosts.
Sink - Interface in alluxio.metrics.sink
Sink consumes the records generated by the metrics source.
SINK_REGEX - Static variable in class alluxio.metrics.MetricsSystem
 
SITE_CONF_DIR - Static variable in class alluxio.PropertyKey.Name
 
SITE_CONF_DIR - Static variable in class alluxio.PropertyKey
 
SITE_PROPERTIES - Static variable in class alluxio.Constants
 
siteProperty(String) - Static method in class alluxio.conf.Source
Creates a site property source with the specified filename.
size() - Method in class alluxio.client.keyvalue.ByteBufferKeyValuePartitionReader
 
size() - Method in interface alluxio.client.keyvalue.KeyValuePartitionReader
 
size() - Method in interface alluxio.client.keyvalue.KeyValueStoreReader
 
size() - Method in class alluxio.collections.ConcurrentHashSet
 
size() - Method in interface alluxio.collections.FieldIndex
 
size() - Method in class alluxio.collections.IndexedSet
 
size() - Method in class alluxio.collections.NonUniqueFieldIndex
 
size() - Method in class alluxio.collections.UniqueFieldIndex
 
size() - Method in class alluxio.resource.DynamicResourcePool
 
size() - Method in interface alluxio.resource.Pool
 
size() - Method in class alluxio.resource.ResourcePool
 
size() - Method in class alluxio.StorageTierAssoc
 
size() - Method in class alluxio.StreamCache
 
skip(long) - Method in class alluxio.client.block.stream.BlockInStream
 
skip(long) - Method in class alluxio.client.file.FileInStream
 
skip(long) - Method in class alluxio.hadoop.HdfsFileInputStream
 
skip(long) - Method in class alluxio.underfs.gcs.GCSInputStream
This method leverages the ability to open a stream from GCS from a given offset.
skip(long) - Method in class alluxio.underfs.MultiRangeObjectInputStream
 
skip(long) - Method in class alluxio.underfs.s3a.S3AInputStream
 
sleep(Duration) - Method in interface alluxio.time.Sleeper
Sleeps for the given duration.
sleep(Duration) - Method in class alluxio.time.ThreadSleeper
 
Sleeper - Interface in alluxio.time
An interface for a utility which provides a sleep method.
SLEEPING_TIMER_CLASS - Static variable in class alluxio.heartbeat.HeartbeatContext
 
SleepingRetry - Class in alluxio.retry
A retry policy that uses thread sleeping for the delay.
SleepingRetry(int) - Constructor for class alluxio.retry.SleepingRetry
 
SleepingTimer - Class in alluxio.heartbeat
This class can be used for executing heartbeats periodically.
SleepingTimer(String, long) - Constructor for class alluxio.heartbeat.SleepingTimer
Creates a new instance of SleepingTimer.
SleepingTimer(String, long, Logger, Clock, Sleeper) - Constructor for class alluxio.heartbeat.SleepingTimer
Creates a new instance of SleepingTimer.
sleepMs(long) - Static method in class alluxio.util.CommonUtils
Sleeps for the given number of milliseconds.
sleepMs(Logger, long) - Static method in class alluxio.util.CommonUtils
Sleeps for the given number of milliseconds, reporting interruptions using the given logger.
sliceByteBuffer(ByteBuffer, int, int) - Static method in class alluxio.util.io.BufferUtils
Creates a new ByteBuffer sliced from a given ByteBuffer.
sliceByteBuffer(ByteBuffer, int) - Static method in class alluxio.util.io.BufferUtils
Convenience method for BufferUtils.sliceByteBuffer(ByteBuffer, int, int) where the last parameter is the number of remaining bytes in the new buffer.
SocketTrackingTServerSocket - Class in alluxio.network.thrift
Extension of TServerSocket which tracks all accepted sockets and closes them when the server socket is closed.
SocketTrackingTServerSocket(TServerSocket.ServerSocketTransportArgs) - Constructor for class alluxio.network.thrift.SocketTrackingTServerSocket
 
sortLineageTopologically(Set<Lineage>) - Method in class alluxio.master.lineage.meta.LineageStore
Sorts a given set of lineages topologically.
sortTopologically(Set<T>) - Method in class alluxio.collections.DirectedAcyclicGraph
Sorts a given set of payloads topologically based on the DAG.
Source - Class in alluxio.conf
The source of a configuration property.
Source - Interface in alluxio.metrics.source
Source is where the metrics generated.
Source.Type - Enum in alluxio.conf
Source type.
SOURCE_HOST_FIELD_NUMBER - Static variable in class alluxio.proto.dataserver.Protocol.AsyncCacheRequest
 
SOURCE_PORT_FIELD_NUMBER - Static variable in class alluxio.proto.dataserver.Protocol.AsyncCacheRequest
 
SPACE_TO_RESERVE_FIELD_NUMBER - Static variable in class alluxio.proto.dataserver.Protocol.LocalBlockCreateRequest
 
SpaceReserver - Class in alluxio.worker.block
The SpaceReserver periodically checks the available space on each storage tier.
SpaceReserver(BlockWorker) - Constructor for class alluxio.worker.block.SpaceReserver
Creates a new instance of SpaceReserver.
SparkIntegrationChecker - Class in alluxio.checker
The Spark integration checker includes a Spark job to test the integration of Spark with Alluxio.
SparkIntegrationChecker() - Constructor for class alluxio.checker.SparkIntegrationChecker
 
SpecificHostPolicy - Class in alluxio.client.file.policy
Always returns a worker with the specified hostname.
SpecificHostPolicy(String) - Constructor for class alluxio.client.file.policy.SpecificHostPolicy
Constructs the policy with the hostname.
SPECIFIED_OPTION_NAME - Static variable in class alluxio.cli.fsadmin.command.ReportCommand
 
SshValidationTask - Class in alluxio.cli.validation
Task for validating SSH reachability.
SshValidationTask(String) - Constructor for class alluxio.cli.validation.SshValidationTask
Creates a new instance of SshValidationTask.
standardSchemeReadValue(TProtocol, TField) - Method in class alluxio.thrift.FileSystemCommandOptions
 
standardSchemeWriteValue(TProtocol) - Method in class alluxio.thrift.FileSystemCommandOptions
 
StandardURI - Class in alluxio
A wrapper class around URI.
StandardURI(String, String, String, String) - Constructor for class alluxio.StandardURI
 
start() - Method in class alluxio.logserver.AlluxioLogServerProcess
Starts the Alluxio process.
start() - Method in class alluxio.master.AbstractLocalAlluxioCluster
Starts both master and a worker using the configurations in test conf respectively.
start(Boolean) - Method in class alluxio.master.AbstractMaster
 
start() - Method in class alluxio.master.AlluxioMasterProcess
 
start() - Method in class alluxio.master.AlluxioSecondaryMaster
 
start() - Method in class alluxio.master.audit.AsyncUserAccessAuditLogWriter
start(Boolean) - Method in class alluxio.master.block.DefaultBlockMaster
 
start(Boolean) - Method in class alluxio.master.file.DefaultFileSystemMaster
 
start() - Method in class alluxio.master.journal.AbstractJournalSystem
 
start() - Method in interface alluxio.master.journal.JournalSystem
Starts the journal system.
start() - Method in class alluxio.master.journal.noop.NoopJournalSystem
 
start() - Method in class alluxio.master.journal.ufs.UfsJournal
Starts the journal in secondary mode.
start(Boolean) - Method in class alluxio.master.keyvalue.DefaultKeyValueMaster
 
start(Boolean) - Method in class alluxio.master.lineage.DefaultLineageMaster
 
start() - Method in class alluxio.master.LocalAlluxioMaster
Starts the master.
start() - Method in class alluxio.master.meta.DailyMetadataBackup
start(Boolean) - Method in class alluxio.master.meta.DefaultMetaMaster
 
start(Boolean) - Method in class alluxio.master.metrics.DefaultMetricsMaster
 
start(Boolean) - Method in class alluxio.master.NoopMaster
 
start(InetSocketAddress) - Method in interface alluxio.master.PrimarySelector
Starts the primary selector.
start(InetSocketAddress) - Method in class alluxio.master.PrimarySelectorClient
Starts the leader selection.
start() - Method in class alluxio.metrics.sink.ConsoleSink
 
start() - Method in class alluxio.metrics.sink.CsvSink
 
start() - Method in class alluxio.metrics.sink.GraphiteSink
 
start() - Method in class alluxio.metrics.sink.JmxSink
 
start() - Method in class alluxio.metrics.sink.MetricsServlet
 
start() - Method in class alluxio.metrics.sink.PrometheusMetricsServlet
 
start() - Method in interface alluxio.metrics.sink.Sink
Starts the reporter polling.
start() - Method in class alluxio.multi.process.ExternalProcess
Starts the process.
start() - Method in class alluxio.multi.process.Master
Launches the master process.
start() - Method in class alluxio.multi.process.MultiProcessCluster
Starts the cluster, launching all server processes.
start() - Method in class alluxio.multi.process.Worker
Launches the worker process.
start() - Method in interface alluxio.Process
Starts the Alluxio process.
start() - Method in class alluxio.proxy.AlluxioProxyProcess
 
start(U) - Method in class alluxio.Registry
Starts all Servers in dependency order.
start(T) - Method in interface alluxio.Server
Starts the Alluxio server.
start(I, AlluxioService.getServiceVersion_args, AsyncMethodCallback<GetServiceVersionTResponse>) - Method in class alluxio.thrift.AlluxioService.AsyncProcessor.getServiceVersion
 
start(I, BlockMasterClientService.getBlockInfo_args, AsyncMethodCallback<GetBlockInfoTResponse>) - Method in class alluxio.thrift.BlockMasterClientService.AsyncProcessor.getBlockInfo
 
start(I, BlockMasterClientService.getBlockMasterInfo_args, AsyncMethodCallback<GetBlockMasterInfoTResponse>) - Method in class alluxio.thrift.BlockMasterClientService.AsyncProcessor.getBlockMasterInfo
 
start(I, BlockMasterClientService.getCapacityBytes_args, AsyncMethodCallback<GetCapacityBytesTResponse>) - Method in class alluxio.thrift.BlockMasterClientService.AsyncProcessor.getCapacityBytes
 
start(I, BlockMasterClientService.getUsedBytes_args, AsyncMethodCallback<GetUsedBytesTResponse>) - Method in class alluxio.thrift.BlockMasterClientService.AsyncProcessor.getUsedBytes
 
start(I, BlockMasterClientService.getWorkerInfoList_args, AsyncMethodCallback<GetWorkerInfoListTResponse>) - Method in class alluxio.thrift.BlockMasterClientService.AsyncProcessor.getWorkerInfoList
 
start(I, BlockMasterClientService.getWorkerReport_args, AsyncMethodCallback<GetWorkerInfoListTResponse>) - Method in class alluxio.thrift.BlockMasterClientService.AsyncProcessor.getWorkerReport
 
start(I, BlockMasterWorkerService.blockHeartbeat_args, AsyncMethodCallback<BlockHeartbeatTResponse>) - Method in class alluxio.thrift.BlockMasterWorkerService.AsyncProcessor.blockHeartbeat
 
start(I, BlockMasterWorkerService.commitBlock_args, AsyncMethodCallback<CommitBlockTResponse>) - Method in class alluxio.thrift.BlockMasterWorkerService.AsyncProcessor.commitBlock
 
start(I, BlockMasterWorkerService.getWorkerId_args, AsyncMethodCallback<GetWorkerIdTResponse>) - Method in class alluxio.thrift.BlockMasterWorkerService.AsyncProcessor.getWorkerId
 
start(I, BlockMasterWorkerService.registerWorker_args, AsyncMethodCallback<RegisterWorkerTResponse>) - Method in class alluxio.thrift.BlockMasterWorkerService.AsyncProcessor.registerWorker
 
start(I, BlockWorkerClientService.accessBlock_args, AsyncMethodCallback<AccessBlockTResponse>) - Method in class alluxio.thrift.BlockWorkerClientService.AsyncProcessor.accessBlock
 
start(I, BlockWorkerClientService.cacheBlock_args, AsyncMethodCallback<CacheBlockTResponse>) - Method in class alluxio.thrift.BlockWorkerClientService.AsyncProcessor.cacheBlock
 
start(I, BlockWorkerClientService.cancelBlock_args, AsyncMethodCallback<CancelBlockTResponse>) - Method in class alluxio.thrift.BlockWorkerClientService.AsyncProcessor.cancelBlock
 
start(I, BlockWorkerClientService.lockBlock_args, AsyncMethodCallback<LockBlockTResponse>) - Method in class alluxio.thrift.BlockWorkerClientService.AsyncProcessor.lockBlock
 
start(I, BlockWorkerClientService.promoteBlock_args, AsyncMethodCallback<PromoteBlockTResponse>) - Method in class alluxio.thrift.BlockWorkerClientService.AsyncProcessor.promoteBlock
 
start(I, BlockWorkerClientService.removeBlock_args, AsyncMethodCallback<RemoveBlockTResponse>) - Method in class alluxio.thrift.BlockWorkerClientService.AsyncProcessor.removeBlock
 
start(I, BlockWorkerClientService.requestBlockLocation_args, AsyncMethodCallback<RequestBlockLocationTResponse>) - Method in class alluxio.thrift.BlockWorkerClientService.AsyncProcessor.requestBlockLocation
 
start(I, BlockWorkerClientService.requestSpace_args, AsyncMethodCallback<RequestSpaceTResponse>) - Method in class alluxio.thrift.BlockWorkerClientService.AsyncProcessor.requestSpace
 
start(I, BlockWorkerClientService.sessionBlockHeartbeat_args, AsyncMethodCallback<SessionBlockHeartbeatTResponse>) - Method in class alluxio.thrift.BlockWorkerClientService.AsyncProcessor.sessionBlockHeartbeat
 
start(I, BlockWorkerClientService.unlockBlock_args, AsyncMethodCallback<UnlockBlockTResponse>) - Method in class alluxio.thrift.BlockWorkerClientService.AsyncProcessor.unlockBlock
 
start(I, FileSystemMasterClientService.checkConsistency_args, AsyncMethodCallback<CheckConsistencyTResponse>) - Method in class alluxio.thrift.FileSystemMasterClientService.AsyncProcessor.checkConsistency
 
start(I, FileSystemMasterClientService.completeFile_args, AsyncMethodCallback<CompleteFileTResponse>) - Method in class alluxio.thrift.FileSystemMasterClientService.AsyncProcessor.completeFile
 
start(I, FileSystemMasterClientService.createDirectory_args, AsyncMethodCallback<CreateDirectoryTResponse>) - Method in class alluxio.thrift.FileSystemMasterClientService.AsyncProcessor.createDirectory
 
start(I, FileSystemMasterClientService.createFile_args, AsyncMethodCallback<CreateFileTResponse>) - Method in class alluxio.thrift.FileSystemMasterClientService.AsyncProcessor.createFile
 
start(I, FileSystemMasterClientService.free_args, AsyncMethodCallback<FreeTResponse>) - Method in class alluxio.thrift.FileSystemMasterClientService.AsyncProcessor.free
 
start(I, FileSystemMasterClientService.getFilePath_args, AsyncMethodCallback<GetFilePathTResponse>) - Method in class alluxio.thrift.FileSystemMasterClientService.AsyncProcessor.getFilePath
 
start(I, FileSystemMasterClientService.getMountTable_args, AsyncMethodCallback<GetMountTableTResponse>) - Method in class alluxio.thrift.FileSystemMasterClientService.AsyncProcessor.getMountTable
 
start(I, FileSystemMasterClientService.getNewBlockIdForFile_args, AsyncMethodCallback<GetNewBlockIdForFileTResponse>) - Method in class alluxio.thrift.FileSystemMasterClientService.AsyncProcessor.getNewBlockIdForFile
 
start(I, FileSystemMasterClientService.getStatus_args, AsyncMethodCallback<GetStatusTResponse>) - Method in class alluxio.thrift.FileSystemMasterClientService.AsyncProcessor.getStatus
 
start(I, FileSystemMasterClientService.listStatus_args, AsyncMethodCallback<ListStatusTResponse>) - Method in class alluxio.thrift.FileSystemMasterClientService.AsyncProcessor.listStatus
 
start(I, FileSystemMasterClientService.loadMetadata_args, AsyncMethodCallback<LoadMetadataTResponse>) - Method in class alluxio.thrift.FileSystemMasterClientService.AsyncProcessor.loadMetadata
 
start(I, FileSystemMasterClientService.mount_args, AsyncMethodCallback<MountTResponse>) - Method in class alluxio.thrift.FileSystemMasterClientService.AsyncProcessor.mount
 
start(I, FileSystemMasterClientService.remove_args, AsyncMethodCallback<DeleteTResponse>) - Method in class alluxio.thrift.FileSystemMasterClientService.AsyncProcessor.remove
 
start(I, FileSystemMasterClientService.rename_args, AsyncMethodCallback<RenameTResponse>) - Method in class alluxio.thrift.FileSystemMasterClientService.AsyncProcessor.rename
 
start(I, FileSystemMasterClientService.scheduleAsyncPersistence_args, AsyncMethodCallback<ScheduleAsyncPersistenceTResponse>) - Method in class alluxio.thrift.FileSystemMasterClientService.AsyncProcessor.scheduleAsyncPersistence
 
start(I, FileSystemMasterClientService.setAttribute_args, AsyncMethodCallback<SetAttributeTResponse>) - Method in class alluxio.thrift.FileSystemMasterClientService.AsyncProcessor.setAttribute
 
start(I, FileSystemMasterClientService.unmount_args, AsyncMethodCallback<UnmountTResponse>) - Method in class alluxio.thrift.FileSystemMasterClientService.AsyncProcessor.unmount
 
start(I, FileSystemMasterClientService.updateUfsMode_args, AsyncMethodCallback<UpdateUfsModeTResponse>) - Method in class alluxio.thrift.FileSystemMasterClientService.AsyncProcessor.updateUfsMode
 
start(I, FileSystemMasterWorkerService.fileSystemHeartbeat_args, AsyncMethodCallback<FileSystemHeartbeatTResponse>) - Method in class alluxio.thrift.FileSystemMasterWorkerService.AsyncProcessor.fileSystemHeartbeat
 
start(I, FileSystemMasterWorkerService.getFileInfo_args, AsyncMethodCallback<GetFileInfoTResponse>) - Method in class alluxio.thrift.FileSystemMasterWorkerService.AsyncProcessor.getFileInfo
 
start(I, FileSystemMasterWorkerService.getPinnedFileIds_args, AsyncMethodCallback<GetPinnedFileIdsTResponse>) - Method in class alluxio.thrift.FileSystemMasterWorkerService.AsyncProcessor.getPinnedFileIds
 
start(I, FileSystemMasterWorkerService.getUfsInfo_args, AsyncMethodCallback<GetUfsInfoTResponse>) - Method in class alluxio.thrift.FileSystemMasterWorkerService.AsyncProcessor.getUfsInfo
 
start(I, FileSystemWorkerClientService.cancelUfsFile_args, AsyncMethodCallback<CancelUfsFileTResponse>) - Method in class alluxio.thrift.FileSystemWorkerClientService.AsyncProcessor.cancelUfsFile
 
start(I, FileSystemWorkerClientService.closeUfsFile_args, AsyncMethodCallback<CloseUfsFileTResponse>) - Method in class alluxio.thrift.FileSystemWorkerClientService.AsyncProcessor.closeUfsFile
 
start(I, FileSystemWorkerClientService.completeUfsFile_args, AsyncMethodCallback<CompleteUfsFileTReponse>) - Method in class alluxio.thrift.FileSystemWorkerClientService.AsyncProcessor.completeUfsFile
 
start(I, FileSystemWorkerClientService.createUfsFile_args, AsyncMethodCallback<CreateUfsFileTResponse>) - Method in class alluxio.thrift.FileSystemWorkerClientService.AsyncProcessor.createUfsFile
 
start(I, FileSystemWorkerClientService.openUfsFile_args, AsyncMethodCallback<OpenUfsFileTResponse>) - Method in class alluxio.thrift.FileSystemWorkerClientService.AsyncProcessor.openUfsFile
 
start(I, FileSystemWorkerClientService.sessionFileSystemHeartbeat_args, AsyncMethodCallback<SessionFileSystemHeartbeatTResponse>) - Method in class alluxio.thrift.FileSystemWorkerClientService.AsyncProcessor.sessionFileSystemHeartbeat
 
start(I, KeyValueMasterClientService.completePartition_args, AsyncMethodCallback<CompletePartitionTResponse>) - Method in class alluxio.thrift.KeyValueMasterClientService.AsyncProcessor.completePartition
 
start(I, KeyValueMasterClientService.completeStore_args, AsyncMethodCallback<CompleteStoreTResponse>) - Method in class alluxio.thrift.KeyValueMasterClientService.AsyncProcessor.completeStore
 
start(I, KeyValueMasterClientService.createStore_args, AsyncMethodCallback<CreateStoreTResponse>) - Method in class alluxio.thrift.KeyValueMasterClientService.AsyncProcessor.createStore
 
start(I, KeyValueMasterClientService.deleteStore_args, AsyncMethodCallback<DeleteStoreTResponse>) - Method in class alluxio.thrift.KeyValueMasterClientService.AsyncProcessor.deleteStore
 
start(I, KeyValueMasterClientService.getPartitionInfo_args, AsyncMethodCallback<GetPartitionInfoTResponse>) - Method in class alluxio.thrift.KeyValueMasterClientService.AsyncProcessor.getPartitionInfo
 
start(I, KeyValueMasterClientService.mergeStore_args, AsyncMethodCallback<MergeStoreTResponse>) - Method in class alluxio.thrift.KeyValueMasterClientService.AsyncProcessor.mergeStore
 
start(I, KeyValueMasterClientService.renameStore_args, AsyncMethodCallback<RenameStoreTResponse>) - Method in class alluxio.thrift.KeyValueMasterClientService.AsyncProcessor.renameStore
 
start(I, KeyValueWorkerClientService.get_args, AsyncMethodCallback<GetTResponse>) - Method in class alluxio.thrift.KeyValueWorkerClientService.AsyncProcessor.get
 
start(I, KeyValueWorkerClientService.getNextKeys_args, AsyncMethodCallback<GetNextKeysTResponse>) - Method in class alluxio.thrift.KeyValueWorkerClientService.AsyncProcessor.getNextKeys
 
start(I, KeyValueWorkerClientService.getSize_args, AsyncMethodCallback<GetSizeTResponse>) - Method in class alluxio.thrift.KeyValueWorkerClientService.AsyncProcessor.getSize
 
start(I, LineageMasterClientService.createLineage_args, AsyncMethodCallback<CreateLineageTResponse>) - Method in class alluxio.thrift.LineageMasterClientService.AsyncProcessor.createLineage
 
start(I, LineageMasterClientService.deleteLineage_args, AsyncMethodCallback<DeleteLineageTResponse>) - Method in class alluxio.thrift.LineageMasterClientService.AsyncProcessor.deleteLineage
 
start(I, LineageMasterClientService.getLineageInfoList_args, AsyncMethodCallback<GetLineageInfoListTResponse>) - Method in class alluxio.thrift.LineageMasterClientService.AsyncProcessor.getLineageInfoList
 
start(I, LineageMasterClientService.reinitializeFile_args, AsyncMethodCallback<ReinitializeFileTResponse>) - Method in class alluxio.thrift.LineageMasterClientService.AsyncProcessor.reinitializeFile
 
start(I, LineageMasterClientService.reportLostFile_args, AsyncMethodCallback<ReportLostFileTResponse>) - Method in class alluxio.thrift.LineageMasterClientService.AsyncProcessor.reportLostFile
 
start(I, MetaMasterClientService.backup_args, AsyncMethodCallback<BackupTResponse>) - Method in class alluxio.thrift.MetaMasterClientService.AsyncProcessor.backup
 
start(I, MetaMasterClientService.getConfigReport_args, AsyncMethodCallback<GetConfigReportTResponse>) - Method in class alluxio.thrift.MetaMasterClientService.AsyncProcessor.getConfigReport
 
start(I, MetaMasterClientService.getConfiguration_args, AsyncMethodCallback<GetConfigurationTResponse>) - Method in class alluxio.thrift.MetaMasterClientService.AsyncProcessor.getConfiguration
 
start(I, MetaMasterClientService.getMasterInfo_args, AsyncMethodCallback<GetMasterInfoTResponse>) - Method in class alluxio.thrift.MetaMasterClientService.AsyncProcessor.getMasterInfo
 
start(I, MetaMasterClientService.getMetrics_args, AsyncMethodCallback<GetMetricsTResponse>) - Method in class alluxio.thrift.MetaMasterClientService.AsyncProcessor.getMetrics
 
start(I, MetaMasterMasterService.getMasterId_args, AsyncMethodCallback<GetMasterIdTResponse>) - Method in class alluxio.thrift.MetaMasterMasterService.AsyncProcessor.getMasterId
 
start(I, MetaMasterMasterService.masterHeartbeat_args, AsyncMethodCallback<MasterHeartbeatTResponse>) - Method in class alluxio.thrift.MetaMasterMasterService.AsyncProcessor.masterHeartbeat
 
start(I, MetaMasterMasterService.registerMaster_args, AsyncMethodCallback<RegisterMasterTResponse>) - Method in class alluxio.thrift.MetaMasterMasterService.AsyncProcessor.registerMaster
 
start(I, MetricsMasterClientService.metricsHeartbeat_args, AsyncMethodCallback<MetricsHeartbeatTResponse>) - Method in class alluxio.thrift.MetricsMasterClientService.AsyncProcessor.metricsHeartbeat
 
start() - Method in class alluxio.util.JvmPauseMonitor
Starts jvm monitor thread.
start() - Method in class alluxio.web.WebServer
Starts the web server.
start() - Method in class alluxio.worker.AlluxioWorkerProcess
 
start(WorkerNetAddress) - Method in class alluxio.worker.block.DefaultBlockWorker
Runs the block worker.
start(WorkerNetAddress) - Method in class alluxio.worker.file.DefaultFileSystemWorker
 
start(WorkerNetAddress) - Method in class alluxio.worker.keyvalue.KeyValueWorker
 
startInternal() - Method in class alluxio.master.journal.AbstractJournalSystem
Starts the journal system.
startInternal() - Method in class alluxio.master.journal.ufs.UfsJournalSystem
 
startJvmMonitorProcess() - Method in class alluxio.master.AlluxioMasterProcess
Starts jvm monitor process, to monitor jvm.
startMaster(int) - Method in class alluxio.multi.process.MultiProcessCluster
Starts the specified master.
startMasters() - Method in class alluxio.master.AbstractLocalAlluxioCluster
Configures and starts the master(s).
startMasters(boolean) - Method in class alluxio.master.AlluxioMasterProcess
Starts all masters, including block master, FileSystem master, lineage master and additional masters.
startMasters() - Method in class alluxio.master.LocalAlluxioCluster
 
startMasters() - Method in class alluxio.master.MultiMasterLocalAlluxioCluster
 
startMasters() - Method in class alluxio.multi.process.MultiProcessCluster
Starts all masters.
startServing(String, String) - Method in class alluxio.master.AlluxioMasterProcess
Starts serving, letting MetricsSystem start sink and starting the web ui server and RPC Server.
startServingRPCServer() - Method in class alluxio.master.AlluxioMasterProcess
Starts the Thrift RPC server.
startServingWebServer() - Method in class alluxio.master.AlluxioMasterProcess
Starts serving web ui server, resetting master web port, adding the metrics servlet to the web server and starting web ui.
startSinks() - Static method in class alluxio.metrics.MetricsSystem
Starts sinks specified in the configuration.
startSinksFromConfig(MetricsConfig) - Static method in class alluxio.metrics.MetricsSystem
Starts sinks from a given metrics configuration.
StartupConsistencyCheck - Class in alluxio.master.file
Class to represent the status and result of the startup consistency check.
StartupConsistencyCheck - Class in alluxio.wire
The startup consistency check information.
StartupConsistencyCheck() - Constructor for class alluxio.wire.StartupConsistencyCheck
Creates a new instance of StartupConsistencyCheck.
StartupConsistencyCheck.Status - Enum in alluxio.master.file
Status of the check.
startWorker(int) - Method in class alluxio.multi.process.MultiProcessCluster
Starts the specified worker.
startWorkers() - Method in class alluxio.master.AbstractLocalAlluxioCluster
Configures and starts the worker(s).
startWorkers() - Method in class alluxio.master.MultiMasterLocalAlluxioCluster
 
StatCommand - Class in alluxio.cli.fs.command
Displays the path's info.
StatCommand(FileSystem) - Constructor for class alluxio.cli.fs.command.StatCommand
 
stateChanged(CuratorFramework, ConnectionState) - Method in class alluxio.master.PrimarySelectorClient
 
StateChangeJournalContext - Class in alluxio.master.journal
Context for correctly managing the state change lock for a wrapped journal context.
StateChangeJournalContext(JournalContext, Lock) - Constructor for class alluxio.master.journal.StateChangeJournalContext
stateChangeLock() - Method in class alluxio.master.MasterContext
 
Status - Enum in alluxio.exception.status
A class representing gRPC status codes.
Status - Class in alluxio.proto.status
 
Status.PStatus - Enum in alluxio.proto.status
Protobuf enum alluxio.proto.status.PStatus
STATUS_FIELD_NUMBER - Static variable in class alluxio.proto.dataserver.Protocol.Response
 
stop() - Method in class alluxio.logserver.AlluxioLogServerProcess
Stops the Alluxio process, blocking until the action is completed.
stop() - Method in class alluxio.master.AbstractLocalAlluxioCluster
Stops both the alluxio and underfs service threads.
stop() - Method in class alluxio.master.AbstractMaster
 
stop() - Method in class alluxio.master.AlluxioMasterProcess
 
stop() - Method in class alluxio.master.AlluxioSecondaryMaster
 
stop() - Method in class alluxio.master.audit.AsyncUserAccessAuditLogWriter
stop() - Method in class alluxio.master.file.DefaultFileSystemMaster
 
stop() - Method in class alluxio.master.journal.AbstractJournalSystem
 
stop() - Method in interface alluxio.master.journal.JournalSystem
Stops the journal system.
stop() - Method in class alluxio.master.journal.noop.NoopJournalSystem
 
stop() - Method in class alluxio.master.LocalAlluxioCluster
 
stop() - Method in class alluxio.master.LocalAlluxioMaster
Stops the master processes and cleans up client connections.
stop() - Method in class alluxio.master.meta.DailyMetadataBackup
stop() - Method in class alluxio.master.meta.DefaultMetaMaster
 
stop() - Method in class alluxio.master.NoopMaster
 
stop() - Method in interface alluxio.master.PrimarySelector
Stops the primary selector.
stop() - Method in class alluxio.master.PrimarySelectorClient
 
stop() - Method in class alluxio.metrics.sink.ConsoleSink
 
stop() - Method in class alluxio.metrics.sink.CsvSink
 
stop() - Method in class alluxio.metrics.sink.GraphiteSink
 
stop() - Method in class alluxio.metrics.sink.JmxSink
 
stop() - Method in class alluxio.metrics.sink.MetricsServlet
 
stop() - Method in class alluxio.metrics.sink.PrometheusMetricsServlet
 
stop() - Method in interface alluxio.metrics.sink.Sink
Stops the reporter.
stop() - Method in class alluxio.multi.process.ExternalProcess
Stops the process.
stop() - Method in interface alluxio.Process
Stops the Alluxio process, blocking until the action is completed.
stop() - Method in class alluxio.proxy.AlluxioProxyProcess
 
stop() - Method in class alluxio.Registry
Stops all Servers in reverse dependency order.
stop() - Method in interface alluxio.Server
Stops the Alluxio server.
stop() - Method in class alluxio.util.JvmPauseMonitor
Stops jvm monitor.
stop() - Method in class alluxio.web.WebServer
Shuts down the web server.
stop() - Method in class alluxio.worker.AlluxioWorkerProcess
 
stop() - Method in class alluxio.worker.block.DefaultBlockWorker
Stops the block worker.
stop() - Method in class alluxio.worker.file.DefaultFileSystemWorker
 
stop() - Method in class alluxio.worker.keyvalue.KeyValueWorker
 
stop() - Method in class alluxio.worker.SessionCleaner
Stops the checking, once this method is called, the object should be discarded.
stopFS() - Method in class alluxio.master.AbstractLocalAlluxioCluster
Stops the alluxio filesystem's service thread only.
stopFS() - Method in class alluxio.master.MultiMasterLocalAlluxioCluster
 
stopInternal() - Method in class alluxio.master.journal.AbstractJournalSystem
Stops the journal system.
stopInternal() - Method in class alluxio.master.journal.ufs.UfsJournalSystem
 
stopLeader() - Method in class alluxio.master.MultiMasterLocalAlluxioCluster
Iterates over the masters in the order of master creation, stops the leader master.
stopMaster(int) - Method in class alluxio.multi.process.MultiProcessCluster
 
stopMasters() - Method in class alluxio.master.AbstractLocalAlluxioCluster
Stops the masters.
stopMasters() - Method in class alluxio.master.AlluxioMasterProcess
Stops all masters, including lineage master, block master and fileSystem master and additional masters.
stopMasters() - Method in class alluxio.master.LocalAlluxioCluster
 
stopMasters() - Method in class alluxio.master.MultiMasterLocalAlluxioCluster
 
stopMasters() - Method in class alluxio.multi.process.MultiProcessCluster
Stops all masters.
stopProcessOnShutdown(Process) - Static method in class alluxio.ProcessUtils
Adds a shutdown hook that will be invoked when a signal is sent to this process.
stopProxy() - Method in class alluxio.master.AbstractLocalAlluxioCluster
Stops the proxy.
stopServing() - Method in class alluxio.master.AlluxioMasterProcess
Stops serving, trying stop RPC server and web ui server and letting MetricsSystem stop all the sinks.
stopSinks() - Static method in class alluxio.metrics.MetricsSystem
Stops all the sinks.
stopStandby() - Method in class alluxio.master.MultiMasterLocalAlluxioCluster
Iterates over the masters in the order of master creation, stops the first standby master.
stopWorker(int) - Method in class alluxio.multi.process.MultiProcessCluster
 
stopWorkers() - Method in class alluxio.master.AbstractLocalAlluxioCluster
Stops the workers.
stopZk() - Method in class alluxio.master.MultiMasterLocalAlluxioCluster
Stops the cluster's Zookeeper service.
stopZk() - Method in class alluxio.multi.process.MultiProcessCluster
Stops the Zookeeper cluster.
StorageDir - Class in alluxio.worker.block.meta
Represents a directory in a storage tier.
StorageDirView - Class in alluxio.worker.block.meta
This class is a wrapper of StorageDir to provide more limited access and a filtered list of blocks.
StorageDirView(StorageDir, StorageTierView, BlockMetadataManagerView) - Constructor for class alluxio.worker.block.meta.StorageDirView
Creates a StorageDirView using the actual StorageDir and the associated BlockMetadataManagerView.
StorageSpaceValidationTask - Class in alluxio.cli.validation
Task for validating whether worker tiered storage has enough space.
StorageSpaceValidationTask() - Constructor for class alluxio.cli.validation.StorageSpaceValidationTask
Creates a new instance of StorageSpaceValidationTask for validating tiered storage space.
StorageTier - Class in alluxio.worker.block.meta
Represents a tier of storage, for example memory or SSD.
StorageTierAssoc - Class in alluxio
Creates a two-way mapping between storage tier aliases and ordinal numbers from the given Configuration.
StorageTierAssoc(PropertyKey, PropertyKey.Template) - Constructor for class alluxio.StorageTierAssoc
Constructs a new instance using the given Configuration object.
StorageTierAssoc(List<String>) - Constructor for class alluxio.StorageTierAssoc
Constructs a new instance using the given list of storage tier aliases in order of their position in the hierarchy.
StorageTierView - Class in alluxio.worker.block.meta
This class is a wrapper of StorageTier to provide more limited access.
StorageTierView(StorageTier, BlockMetadataManagerView) - Constructor for class alluxio.worker.block.meta.StorageTierView
Creates a StorageTierView using the actual StorageTier and the above BlockMetadataManagerView.
STORE_ID_FIELD_NUMBER - Static variable in class alluxio.proto.journal.KeyValue.CompletePartitionEntry
 
STORE_ID_FIELD_NUMBER - Static variable in class alluxio.proto.journal.KeyValue.CompleteStoreEntry
 
STORE_ID_FIELD_NUMBER - Static variable in class alluxio.proto.journal.KeyValue.CreateStoreEntry
 
STORE_ID_FIELD_NUMBER - Static variable in class alluxio.proto.journal.KeyValue.DeleteStoreEntry
 
STREAM_CACHE_SERVLET_RESOURCE_KEY - Static variable in class alluxio.web.ProxyWebServer
 
StreamCache - Class in alluxio
Cache for storing file input and output streams.
StreamCache(long) - Constructor for class alluxio.StreamCache
Creates a new instance of StreamCache.
StreamsRestServiceHandler - Class in alluxio.proxy
This class is a REST handler for stream resources.
StreamsRestServiceHandler(ServletContext) - Constructor for class alluxio.proxy.StreamsRestServiceHandler
Constructs a new StreamsRestServiceHandler.
streamToJournalCheckpoint(JournalOutputStream) - Method in interface alluxio.master.journalv0.JournalCheckpointStreamable
Writes to the journal, in a streaming fashion, via the JournalOutputStream.
StreamUtils - Class in alluxio.util
Convenience methods for working with streams.
stripInstanceAndHost(String) - Static method in class alluxio.metrics.MetricsSystem
Removes the instance and host from the given metric name, returning the result.
stripLeadingAndTrailingQuotes(String) - Static method in class alluxio.util.CommonUtils
Strips the leading and trailing quotes from the given string.
stripPrefixIfPresent(String) - Method in class alluxio.underfs.ObjectUnderFileSystem
Strips the bucket prefix or the preceding path separator from the path if it is present.
stripPrefixIfPresent(String, String) - Static method in class alluxio.util.CommonUtils
Strips the prefix from the key if it is present.
stripSuffixIfPresent(String, String) - Static method in class alluxio.util.CommonUtils
Strips the suffix if it exists.
submit(Callable<T>) - Method in class alluxio.util.executor.ControllableScheduler
 
submit(Runnable) - Method in class alluxio.util.executor.ControllableScheduler
 
submit(Runnable, T) - Method in class alluxio.util.executor.ControllableScheduler
 
submitRequest(Protocol.AsyncCacheRequest) - Method in class alluxio.worker.block.AsyncCacheRequestManager
Handles a request to cache a block asynchronously.
subProperties(Properties, String) - Static method in class alluxio.metrics.MetricsConfig
Uses regex to parse every original property key to a prefix and a suffix.
subtractPaths(String, String) - Static method in class alluxio.util.io.PathUtils
Removes the prefix from the path, yielding a relative path from the second path to the first.
SumInstancesAggregator - Class in alluxio.metrics.aggregator
An aggregator that sums the metric values from all the metrics of a given instance type and metric name.
SumInstancesAggregator(String, MetricsSystem.InstanceType, String) - Constructor for class alluxio.metrics.aggregator.SumInstancesAggregator
Creates an instance of SumInstancesAggregator.
SummaryCommand - Class in alluxio.cli.fsadmin.report
Prints Alluxio cluster summarized information.
SummaryCommand(MetaMasterClient, BlockMasterClient, PrintStream) - Constructor for class alluxio.cli.fsadmin.report.SummaryCommand
Creates a new instance of SummaryCommand.
supportAlluxioHA(PrintWriter) - Static method in class alluxio.checker.CheckerUtils
Checks if the Zookeeper address has been set when running the Alluxio HA mode.
supportsFlush() - Method in class alluxio.underfs.hdfs.HdfsUnderFileSystem
 
supportsFlush() - Method in class alluxio.underfs.local.LocalUnderFileSystem
 
supportsFlush() - Method in class alluxio.underfs.ObjectUnderFileSystem
 
supportsFlush() - Method in interface alluxio.underfs.UnderFileSystem
Whether this type of UFS supports flush.
supportsFlush() - Method in class alluxio.underfs.UnderFileSystemWithLogging
 
supportsPath(String, S) - Method in interface alluxio.extensions.ExtensionFactory
Gets whether this factory supports the given path and thus whether calling the #create(String, S) can succeed for this path.
supportsPath(String) - Method in class alluxio.underfs.cos.COSUnderFileSystemFactory
 
supportsPath(String) - Method in class alluxio.underfs.gcs.GCSUnderFileSystemFactory
 
supportsPath(String) - Method in class alluxio.underfs.hdfs.HdfsUnderFileSystemFactory
 
supportsPath(String) - Method in class alluxio.underfs.local.LocalUnderFileSystemFactory
 
supportsPath(String) - Method in class alluxio.underfs.oss.OSSUnderFileSystemFactory
 
supportsPath(String) - Method in class alluxio.underfs.s3a.S3AUnderFileSystemFactory
 
supportsPath(String) - Method in class alluxio.underfs.swift.SwiftUnderFileSystemFactory
 
supportsPath(String) - Method in interface alluxio.underfs.UnderFileSystemFactory
Gets whether this factory supports the given path and thus whether calling the UnderFileSystemFactory.create(String, UnderFileSystemConfiguration) can succeed for this path.
supportsPath(String, UnderFileSystemConfiguration) - Method in interface alluxio.underfs.UnderFileSystemFactory
Gets whether this factory supports the given path and thus whether calling the UnderFileSystemFactory.create(String, UnderFileSystemConfiguration) can succeed for this path.
supportsPath(String) - Method in class alluxio.underfs.wasb.WasbUnderFileSystemFactory
 
SWIFT_API_KEY - Static variable in class alluxio.PropertyKey.Name
 
SWIFT_API_KEY - Static variable in class alluxio.PropertyKey
 
SWIFT_AUTH_KEYSTONE - Static variable in class alluxio.Constants
 
SWIFT_AUTH_KEYSTONE_V3 - Static variable in class alluxio.Constants
 
SWIFT_AUTH_METHOD_KEY - Static variable in class alluxio.PropertyKey.Name
 
SWIFT_AUTH_METHOD_KEY - Static variable in class alluxio.PropertyKey
 
SWIFT_AUTH_SWIFTAUTH - Static variable in class alluxio.Constants
 
SWIFT_AUTH_URL_KEY - Static variable in class alluxio.PropertyKey.Name
 
SWIFT_AUTH_URL_KEY - Static variable in class alluxio.PropertyKey
 
SWIFT_PASSWORD_KEY - Static variable in class alluxio.PropertyKey.Name
 
SWIFT_PASSWORD_KEY - Static variable in class alluxio.PropertyKey
 
SWIFT_REGION_KEY - Static variable in class alluxio.PropertyKey.Name
 
SWIFT_REGION_KEY - Static variable in class alluxio.PropertyKey
 
SWIFT_SIMULATION - Static variable in class alluxio.PropertyKey.Name
 
SWIFT_SIMULATION - Static variable in class alluxio.PropertyKey
 
SWIFT_TENANT_KEY - Static variable in class alluxio.PropertyKey.Name
 
SWIFT_TENANT_KEY - Static variable in class alluxio.PropertyKey
 
SWIFT_USE_PUBLIC_URI_KEY - Static variable in class alluxio.PropertyKey.Name
 
SWIFT_USE_PUBLIC_URI_KEY - Static variable in class alluxio.PropertyKey
 
SWIFT_USER_KEY - Static variable in class alluxio.PropertyKey.Name
 
SWIFT_USER_KEY - Static variable in class alluxio.PropertyKey
 
SwiftDirectClient - Class in alluxio.underfs.swift.http
Makes direct calls to a Swift API backend.
SwiftDirectClient() - Constructor for class alluxio.underfs.swift.http.SwiftDirectClient
Constructs a new SwiftDirectClient.
SwiftInputStream - Class in alluxio.underfs.swift
A stream for reading data from a Swift API based object store.
SwiftInputStream(Account, String, String) - Constructor for class alluxio.underfs.swift.SwiftInputStream
Constructor for an input stream to an object in a Swift API based store.
SwiftInputStream(Account, String, String, long) - Constructor for class alluxio.underfs.swift.SwiftInputStream
Constructor for an input stream to an object in a Swift API based store.
SwiftMockOutputStream - Class in alluxio.underfs.swift
A stream for writing data to an in-memory simulated Swift client.
SwiftMockOutputStream(Account, String, String) - Constructor for class alluxio.underfs.swift.SwiftMockOutputStream
Creates a new instance of SwiftMockOutputStream.
SwiftOutputStream - Class in alluxio.underfs.swift
A stream for writing data to Swift API based object store.
SwiftOutputStream(HttpURLConnection) - Constructor for class alluxio.underfs.swift.SwiftOutputStream
Creates a new instance of SwiftOutputStream.
SwiftUnderFileSystem - Class in alluxio.underfs.swift
OpenStack Swift UnderFileSystem implementation based on the JOSS library.
SwiftUnderFileSystem(AlluxioURI, UnderFileSystemConfiguration) - Constructor for class alluxio.underfs.swift.SwiftUnderFileSystem
Constructs a new Swift UnderFileSystem.
SwiftUnderFileSystemFactory - Class in alluxio.underfs.swift
Factory for creating SwiftUnderFileSystem.
SwiftUnderFileSystemFactory() - Constructor for class alluxio.underfs.swift.SwiftUnderFileSystemFactory
Constructs a new SwiftUnderFileSystemFactory.
SyncMetadataOptions - Class in alluxio.master.file.options
Method options for syncing the metadata of a path.
SyncMetadataOptions(SyncMetadataTOptions) - Constructor for class alluxio.master.file.options.SyncMetadataOptions
Constructs an instance of SyncMetadataOptions from SyncMetadataTOptions.
SyncMetadataOptions(CommonOptions) - Constructor for class alluxio.master.file.options.SyncMetadataOptions
Constructs an instance from CommonOptions.
SyncMetadataTOptions - Class in alluxio.thrift
 
SyncMetadataTOptions() - Constructor for class alluxio.thrift.SyncMetadataTOptions
 
SyncMetadataTOptions(SyncMetadataTOptions) - Constructor for class alluxio.thrift.SyncMetadataTOptions
Performs a deep copy on other.
SyncMetadataTOptions._Fields - Enum in alluxio.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
SyncMetadataTResponse - Class in alluxio.thrift
 
SyncMetadataTResponse() - Constructor for class alluxio.thrift.SyncMetadataTResponse
 
SyncMetadataTResponse(boolean) - Constructor for class alluxio.thrift.SyncMetadataTResponse
 
SyncMetadataTResponse(SyncMetadataTResponse) - Constructor for class alluxio.thrift.SyncMetadataTResponse
Performs a deep copy on other.
SyncMetadataTResponse._Fields - Enum in alluxio.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
syncPersistDirectory(RpcContext, InodeDirectory) - Method in class alluxio.master.file.meta.InodeTree
Synchronously persists an InodeDirectory to the UFS.
SYSTEM - Static variable in class alluxio.time.TimeContext
 
SYSTEM_PROPERTY - Static variable in class alluxio.conf.Source
 
SystemClock - Class in alluxio.clock
A clock representing the current time as reported by the operating system.
SystemClock() - Constructor for class alluxio.clock.SystemClock
Constructs a new Clock which reports the actual time.

T

TAG_SEPARATOR - Static variable in class alluxio.metrics.Metric
 
TAG_UFS - Static variable in class alluxio.metrics.WorkerMetrics
 
TAG_UFS_TYPE - Static variable in class alluxio.metrics.WorkerMetrics
 
TAG_USER - Static variable in class alluxio.metrics.CommonMetrics
 
TailCommand - Class in alluxio.cli.fs.command
Prints the file's last n bytes (by default, 1KB) to the console.
TailCommand(FileSystem) - Constructor for class alluxio.cli.fs.command.TailCommand
 
takeLeadership(CuratorFramework) - Method in class alluxio.master.PrimarySelectorClient
 
TB - Static variable in class alluxio.Constants
 
TempBlockMeta - Class in alluxio.worker.block.meta
Represents the metadata of an uncommitted block in Alluxio managed storage.
TempBlockMeta(long, long, long, StorageDir) - Constructor for class alluxio.worker.block.meta.TempBlockMeta
Creates a new instance of TempBlockMeta.
temporaryFileName(long, String) - Static method in class alluxio.util.io.PathUtils
Generates a deterministic temporary file name for the a path and a file id and a nonce.
tempPath(StorageDir, long, long) - Static method in class alluxio.worker.block.meta.AbstractBlockMeta
All blocks are created as temp blocks before committed.
TEST_ARTIFACTS_DIR - Static variable in class alluxio.Constants
 
TEST_DIRECTORY_NAME - Static variable in class alluxio.cli.TestRunner
Directory for the test generated files.
TEST_LOG_DIR - Static variable in class alluxio.Constants
 
TEST_MODE - Static variable in class alluxio.PropertyKey.Name
 
TEST_MODE - Static variable in class alluxio.PropertyKey
 
TestCommand - Class in alluxio.cli.fs.command
Tests properties of the path specified in args.
TestCommand(FileSystem) - Constructor for class alluxio.cli.fs.command.TestCommand
 
TestRunner - Class in alluxio.cli
Driver to run Alluxio tests.
TESTS_LOG - Static variable in class alluxio.Constants
 
TestUtils - Class in alluxio.master
Test utilities.
TestUtils() - Constructor for class alluxio.master.TestUtils
 
THREAD_OPTION - Static variable in class alluxio.cli.fs.command.CpCommand
 
ThreadFactoryUtils - Class in alluxio.util
Utility methods for the ThreadFactory class.
ThreadSleeper - Class in alluxio.time
A sleeping utility which delegates to Thread.sleep().
ThreadUtils - Class in alluxio.util
Utility method for working with threads.
THRIFT_STOP_TIMEOUT_SECONDS - Static variable in class alluxio.Constants
Maximum number of seconds to wait for thrift servers to stop on shutdown.
ThriftUtils - Class in alluxio.network.thrift
Util class for methods to create Thrift communication with Alluxio services.
tick() - Method in interface alluxio.heartbeat.HeartbeatTimer
Waits until next heartbeat should be executed.
tick() - Method in class alluxio.heartbeat.ScheduledTimer
Waits until the heartbeat is scheduled for execution.
tick() - Method in class alluxio.heartbeat.SleepingTimer
Enforces the thread waits for the given interval between consecutive ticks.
tick(long) - Method in class alluxio.util.executor.ControllableQueue
Jumps to a future time period.
TIER - Static variable in class alluxio.master.block.DefaultBlockMaster.Metrics
 
TIER - Static variable in class alluxio.worker.block.DefaultBlockWorker.Metrics
 
TIER_FIELD_NUMBER - Static variable in class alluxio.proto.dataserver.Protocol.LocalBlockCreateRequest
 
TIER_FIELD_NUMBER - Static variable in class alluxio.proto.dataserver.Protocol.WriteRequest
 
tierAlias() - Method in class alluxio.worker.block.BlockStoreLocation
Gets the storage tier alias of the location.
TieredBlockStore - Class in alluxio.worker.block
This class represents an object store that manages all the blocks in the local tiered storage.
TieredBlockStore() - Constructor for class alluxio.worker.block.TieredBlockStore
Creates a new instance of TieredBlockStore.
TieredIdentity - Class in alluxio.thrift
 
TieredIdentity() - Constructor for class alluxio.thrift.TieredIdentity
 
TieredIdentity(List<LocalityTier>) - Constructor for class alluxio.thrift.TieredIdentity
 
TieredIdentity(TieredIdentity) - Constructor for class alluxio.thrift.TieredIdentity
Performs a deep copy on other.
TieredIdentity - Class in alluxio.wire
Class representing a node's tier identity.
TieredIdentity(List<TieredIdentity.LocalityTier>) - Constructor for class alluxio.wire.TieredIdentity
 
TieredIdentity._Fields - Enum in alluxio.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
TieredIdentity.LocalityTier - Class in alluxio.wire
Class representing a locality tier, e.g.
TieredIdentityFactory - Class in alluxio.network
Class for getting tiered identity.
TieredIdentityFactory() - Constructor for class alluxio.network.TieredIdentityFactory
 
TimeBoundedRetry - Class in alluxio.retry
Retry mechanism which performs retries until a certain period of time has elapsed.
TimeBoundedRetry(TimeContext, Duration) - Constructor for class alluxio.retry.TimeBoundedRetry
 
TimeContext - Class in alluxio.time
Context for managing time.
TimeContext(Clock, Sleeper) - Constructor for class alluxio.time.TimeContext
 
timeout() - Method in class alluxio.SessionInfo
Checks whether the session has timed out.
TimeoutRetry - Class in alluxio.retry
A retry policy which allows retrying until a specified timeout is reached.
TimeoutRetry(long, int) - Constructor for class alluxio.retry.TimeoutRetry
Constructs a retry facility which allows retrying until a specified timeout is reached.
timer(String) - Static method in class alluxio.metrics.MetricsSystem
 
TMP_DIRS - Static variable in class alluxio.PropertyKey.Name
 
TMP_DIRS - Static variable in class alluxio.PropertyKey
 
TO_STORE_ID_FIELD_NUMBER - Static variable in class alluxio.proto.journal.KeyValue.MergeStoreEntry
 
toAlluxioException() - Method in exception alluxio.exception.status.AlluxioStatusException
 
toArray() - Method in class alluxio.collections.ConcurrentHashSet
 
toArray(E[]) - Method in class alluxio.collections.ConcurrentHashSet
 
toBlockStoreLocation() - Method in class alluxio.worker.block.meta.StorageDir
 
toBlockStoreLocation() - Method in class alluxio.worker.block.meta.StorageDirView
Creates a BlockStoreLocation for this directory view.
toBuilder() - Method in class alluxio.proto.dataserver.Protocol.AsyncCacheRequest
 
toBuilder() - Method in class alluxio.proto.dataserver.Protocol.CreateUfsFileOptions
 
toBuilder() - Method in class alluxio.proto.dataserver.Protocol.Heartbeat
 
toBuilder() - Method in class alluxio.proto.dataserver.Protocol.LocalBlockCloseRequest
 
toBuilder() - Method in class alluxio.proto.dataserver.Protocol.LocalBlockCompleteRequest
 
toBuilder() - Method in class alluxio.proto.dataserver.Protocol.LocalBlockCreateRequest
 
toBuilder() - Method in class alluxio.proto.dataserver.Protocol.LocalBlockCreateResponse
 
toBuilder() - Method in class alluxio.proto.dataserver.Protocol.LocalBlockOpenRequest
 
toBuilder() - Method in class alluxio.proto.dataserver.Protocol.LocalBlockOpenResponse
 
toBuilder() - Method in class alluxio.proto.dataserver.Protocol.OpenUfsBlockOptions
 
toBuilder() - Method in class alluxio.proto.dataserver.Protocol.ReadRequest
 
toBuilder() - Method in class alluxio.proto.dataserver.Protocol.ReadResponse
 
toBuilder() - Method in class alluxio.proto.dataserver.Protocol.Response
 
toBuilder() - Method in class alluxio.proto.dataserver.Protocol.WriteRequest
 
toBuilder() - Method in class alluxio.proto.journal.Block.BlockContainerIdGeneratorEntry
 
toBuilder() - Method in class alluxio.proto.journal.Block.BlockInfoEntry
 
toBuilder() - Method in class alluxio.proto.journal.Block.DeleteBlockEntry
 
toBuilder() - Method in class alluxio.proto.journal.File.AddMountPointEntry
 
toBuilder() - Method in class alluxio.proto.journal.File.AsyncPersistRequestEntry
 
toBuilder() - Method in class alluxio.proto.journal.File.CompleteFileEntry
 
toBuilder() - Method in class alluxio.proto.journal.File.DeleteFileEntry
 
toBuilder() - Method in class alluxio.proto.journal.File.DeleteMountPointEntry
 
toBuilder() - Method in class alluxio.proto.journal.File.InodeDirectoryEntry
 
toBuilder() - Method in class alluxio.proto.journal.File.InodeDirectoryIdGeneratorEntry
 
toBuilder() - Method in class alluxio.proto.journal.File.InodeFileEntry
 
toBuilder() - Method in class alluxio.proto.journal.File.InodeLastModificationTimeEntry
 
toBuilder() - Method in class alluxio.proto.journal.File.PersistDirectoryEntry
 
toBuilder() - Method in class alluxio.proto.journal.File.PersistFileEntry
 
toBuilder() - Method in class alluxio.proto.journal.File.ReinitializeFileEntry
 
toBuilder() - Method in class alluxio.proto.journal.File.RenameEntry
 
toBuilder() - Method in class alluxio.proto.journal.File.SetAttributeEntry
 
toBuilder() - Method in class alluxio.proto.journal.File.StringPairEntry
 
toBuilder() - Method in class alluxio.proto.journal.File.UpdateUfsModeEntry
 
toBuilder() - Method in class alluxio.proto.journal.Journal.JournalEntry
 
toBuilder() - Method in class alluxio.proto.journal.KeyValue.CompletePartitionEntry
 
toBuilder() - Method in class alluxio.proto.journal.KeyValue.CompleteStoreEntry
 
toBuilder() - Method in class alluxio.proto.journal.KeyValue.CreateStoreEntry
 
toBuilder() - Method in class alluxio.proto.journal.KeyValue.DeleteStoreEntry
 
toBuilder() - Method in class alluxio.proto.journal.KeyValue.MergeStoreEntry
 
toBuilder() - Method in class alluxio.proto.journal.KeyValue.RenameStoreEntry
 
toBuilder() - Method in class alluxio.proto.journal.Lineage.DeleteLineageEntry
 
toBuilder() - Method in class alluxio.proto.journal.Lineage.LineageEntry
 
toBuilder() - Method in class alluxio.proto.journal.Lineage.LineageIdGeneratorEntry
 
toByteArray() - Method in class alluxio.util.proto.ProtoMessage
 
toDelete() - Method in class alluxio.master.file.meta.UfsSyncUtils.SyncPlan
 
toDisplayMountPointInfo() - Method in class alluxio.master.file.meta.options.MountInfo
 
toEvict() - Method in class alluxio.worker.block.evictor.EvictionPlan
 
toGetStatusOptions() - Method in class alluxio.client.file.options.ExistsOptions
 
toInStreamOptions(URIStatus) - Method in class alluxio.client.file.options.OpenFileOptions
 
toIOException() - Method in exception alluxio.exception.JournalClosedException
 
toJournalClosedException() - Method in exception alluxio.exception.JournalClosedException.IOJournalClosedException
 
toJournalEntry() - Method in class alluxio.master.file.meta.InodeDirectory
 
toJournalEntry() - Method in class alluxio.master.file.meta.InodeDirectoryIdGenerator
 
toJournalEntry() - Method in class alluxio.master.file.meta.InodeFile
 
toJournalEntry() - Method in interface alluxio.master.journal.JournalEntryRepresentable
 
toJournalEntry() - Method in interface alluxio.master.journalv0.JournalEntryRepresentable
 
toJournalEntry() - Method in class alluxio.master.lineage.meta.Lineage
 
toJournalEntry() - Method in class alluxio.master.lineage.meta.LineageIdGenerator
 
TOKEN_SEPARATOR_REGEX - Static variable in class alluxio.util.ShellUtils
Token separator regex used to parse Shell tool outputs.
toLoadMetadata() - Method in class alluxio.master.file.meta.UfsSyncUtils.SyncPlan
 
toMap() - Method in interface alluxio.AlluxioConfiguration
 
toMap(ConfigurationValueOptions) - Method in interface alluxio.AlluxioConfiguration
 
toMap(ConfigurationValueOptions) - Method in class alluxio.conf.InstancedConfiguration
 
toMap() - Static method in class alluxio.Configuration
 
toMap(ConfigurationValueOptions) - Static method in class alluxio.Configuration
 
toMap() - Method in class alluxio.underfs.UnderFileSystemConfiguration
 
toMountPointInfo() - Method in class alluxio.master.file.meta.options.MountInfo
 
toMove() - Method in class alluxio.worker.block.evictor.EvictionPlan
 
toOutStreamOptions() - Method in class alluxio.client.file.options.CreateFileOptions
 
toProto(Status) - Static method in enum alluxio.exception.status.Status
Converts an internal exception status to a protocol buffer type status.
toProtobuf(TtlAction) - Static method in class alluxio.master.ProtobufUtils
Converts Wire type to Protobuf type.
topTiersMatch(TieredIdentity) - Method in class alluxio.wire.TieredIdentity
 
toS3Date(long) - Static method in class alluxio.proxy.s3.S3RestUtils
 
toShort() - Method in class alluxio.security.authorization.Mode
Encodes the object as a short.
toString() - Method in class alluxio.AlluxioURI
Illegal characters unescaped in the string, for glob processing, etc.
toString() - Method in class alluxio.client.block.BlockWorkerInfo
 
toString() - Method in class alluxio.client.block.options.GetWorkerReportOptions
 
toString() - Method in class alluxio.client.block.options.LockBlockOptions
 
toString() - Method in class alluxio.client.block.policy.DeterministicHashPolicy
 
toString() - Method in class alluxio.client.block.policy.options.CreateOptions
 
toString() - Method in class alluxio.client.block.policy.options.GetWorkerOptions
 
toString() - Method in class alluxio.client.file.options.CancelUfsFileOptions
 
toString() - Method in class alluxio.client.file.options.CheckConsistencyOptions
 
toString() - Method in class alluxio.client.file.options.CloseUfsFileOptions
 
toString() - Method in class alluxio.client.file.options.CompleteFileOptions
 
toString() - Method in class alluxio.client.file.options.CompleteUfsFileOptions
 
toString() - Method in class alluxio.client.file.options.CreateDirectoryOptions
 
toString() - Method in class alluxio.client.file.options.CreateFileOptions
 
toString() - Method in class alluxio.client.file.options.CreateUfsFileOptions
 
toString() - Method in class alluxio.client.file.options.DeleteOptions
 
toString() - Method in class alluxio.client.file.options.ExistsOptions
 
toString() - Method in class alluxio.client.file.options.FreeOptions
 
toString() - Method in class alluxio.client.file.options.GetStatusOptions
 
toString() - Method in class alluxio.client.file.options.InStreamOptions
 
toString() - Method in class alluxio.client.file.options.ListStatusOptions
 
toString() - Method in class alluxio.client.file.options.LoadMetadataOptions
Deprecated.
 
toString() - Method in class alluxio.client.file.options.MountOptions
 
toString() - Method in class alluxio.client.file.options.OpenFileOptions
 
toString() - Method in class alluxio.client.file.options.OpenUfsFileOptions
 
toString() - Method in class alluxio.client.file.options.OutStreamOptions
 
toString() - Method in class alluxio.client.file.options.RenameOptions
 
toString() - Method in class alluxio.client.file.options.SetAttributeOptions
 
toString() - Method in class alluxio.client.file.options.UnmountOptions
 
toString() - Method in class alluxio.client.file.options.UpdateUfsModeOptions
 
toString() - Method in class alluxio.client.file.policy.LocalFirstAvoidEvictionPolicy
 
toString() - Method in class alluxio.client.file.policy.LocalFirstPolicy
 
toString() - Method in class alluxio.client.file.policy.MostAvailableFirstPolicy
 
toString() - Method in class alluxio.client.file.policy.RoundRobinPolicy
 
toString() - Method in class alluxio.client.file.policy.SpecificHostPolicy
 
toString() - Method in class alluxio.client.file.URIStatus
 
toString() - Method in class alluxio.client.lineage.options.CreateLineageOptions
 
toString() - Method in class alluxio.client.lineage.options.DeleteLineageOptions
 
toString() - Method in class alluxio.client.lineage.options.GetLineageInfoListOptions
 
toString() - Method in class alluxio.collections.ConcurrentHashSet
 
toString() - Method in class alluxio.collections.Pair
 
toString() - Method in class alluxio.collections.PrefixList
Print out all prefixes separated by ";".
toString() - Method in class alluxio.conf.Source
 
toString() - Method in exception alluxio.exception.AggregateException
 
toString() - Method in enum alluxio.exception.PreconditionMessage
 
toString() - Method in class alluxio.job.CommandLineJob
 
toString() - Method in class alluxio.master.AlluxioMasterProcess
 
toString() - Method in class alluxio.master.AlluxioSecondaryMaster
 
toString() - Method in class alluxio.master.block.meta.MasterBlockInfo
 
toString() - Method in class alluxio.master.block.meta.MasterBlockLocation
 
toString() - Method in class alluxio.master.block.meta.MasterWorkerInfo
 
toString() - Method in class alluxio.master.file.FileSystemMasterAuditContext
 
toString() - Method in class alluxio.master.file.meta.InodeDirectory
 
toString() - Method in class alluxio.master.file.meta.InodeFile
 
toString() - Method in class alluxio.master.file.options.CheckConsistencyOptions
 
toString() - Method in class alluxio.master.file.options.CompleteFileOptions
 
toString() - Method in class alluxio.master.file.options.CreateDirectoryOptions
 
toString() - Method in class alluxio.master.file.options.CreateFileOptions
 
toString() - Method in class alluxio.master.file.options.DeleteOptions
 
toString() - Method in class alluxio.master.file.options.FreeOptions
 
toString() - Method in class alluxio.master.file.options.GetStatusOptions
 
toString() - Method in class alluxio.master.file.options.ListStatusOptions
 
toString() - Method in class alluxio.master.file.options.LoadMetadataOptions
 
toString() - Method in class alluxio.master.file.options.MountOptions
 
toString() - Method in class alluxio.master.file.options.RenameOptions
 
toString() - Method in class alluxio.master.file.options.SetAttributeOptions
 
toString() - Method in class alluxio.master.file.options.SyncMetadataOptions
 
toString() - Method in class alluxio.master.file.options.WorkerHeartbeatOptions
 
toString() - Method in class alluxio.master.journal.options.JournalReaderOptions
 
toString() - Method in class alluxio.master.journal.options.JournalWriterOptions
 
toString() - Method in class alluxio.master.journal.ufs.UfsJournal
 
toString() - Method in class alluxio.master.journal.ufs.UfsJournalFile
 
toString() - Method in class alluxio.master.lineage.checkpoint.CheckpointPlan
 
toString() - Method in class alluxio.master.lineage.meta.Lineage
 
toString() - Method in class alluxio.master.lineage.recompute.RecomputePlan
 
toString() - Method in class alluxio.master.meta.MasterInfo
 
toString() - Method in class alluxio.master.PollingMasterInquireClient.MultiMasterConnectDetails
 
toString() - Method in class alluxio.master.SingleMasterInquireClient.SingleMasterConnectDetails
 
toString() - Method in class alluxio.master.ZkMasterInquireClient.ZkMasterConnectDetails
 
toString() - Method in class alluxio.metrics.Metric
 
toString() - Method in class alluxio.metrics.MetricsConfig
 
toString() - Method in class alluxio.metrics.MetricsFilter
 
toString() - Method in enum alluxio.metrics.MetricsSystem.InstanceType
 
toString() - Method in enum alluxio.metrics.WorkerMetrics.UfsOps
 
toString() - Method in class alluxio.multi.process.MasterNetAddress
 
toString() - Method in class alluxio.network.protocol.RPCProtoMessage
 
toString() - Method in class alluxio.PropertyKey.Builder
 
toString() - Method in enum alluxio.PropertyKey.Template
 
toString() - Method in class alluxio.PropertyKey
 
toString() - Method in class alluxio.proxy.AlluxioProxyProcess
 
toString() - Method in class alluxio.proxy.s3.ListBucketOptions
 
toString() - Method in enum alluxio.security.authorization.Mode.Bits
 
toString() - Method in class alluxio.security.authorization.Mode
 
toString() - Method in class alluxio.security.User
 
toString() - Method in class alluxio.SessionInfo
 
toString() - Method in class alluxio.thrift.AccessBlockTOptions
 
toString() - Method in class alluxio.thrift.AccessBlockTResponse
 
toString() - Method in class alluxio.thrift.AlluxioService.getServiceVersion_args
 
toString() - Method in class alluxio.thrift.AlluxioService.getServiceVersion_result
 
toString() - Method in exception alluxio.thrift.AlluxioTException
 
toString() - Method in class alluxio.thrift.BackupTOptions
 
toString() - Method in class alluxio.thrift.BackupTResponse
 
toString() - Method in class alluxio.thrift.BlockHeartbeatTOptions
 
toString() - Method in class alluxio.thrift.BlockHeartbeatTResponse
 
toString() - Method in class alluxio.thrift.BlockInfo
 
toString() - Method in class alluxio.thrift.BlockLocation
 
toString() - Method in class alluxio.thrift.BlockMasterClientService.getBlockInfo_args
 
toString() - Method in class alluxio.thrift.BlockMasterClientService.getBlockInfo_result
 
toString() - Method in class alluxio.thrift.BlockMasterClientService.getBlockMasterInfo_args
 
toString() - Method in class alluxio.thrift.BlockMasterClientService.getBlockMasterInfo_result
 
toString() - Method in class alluxio.thrift.BlockMasterClientService.getCapacityBytes_args
 
toString() - Method in class alluxio.thrift.BlockMasterClientService.getCapacityBytes_result
 
toString() - Method in class alluxio.thrift.BlockMasterClientService.getUsedBytes_args
 
toString() - Method in class alluxio.thrift.BlockMasterClientService.getUsedBytes_result
 
toString() - Method in class alluxio.thrift.BlockMasterClientService.getWorkerInfoList_args
 
toString() - Method in class alluxio.thrift.BlockMasterClientService.getWorkerInfoList_result
 
toString() - Method in class alluxio.thrift.BlockMasterClientService.getWorkerReport_args
 
toString() - Method in class alluxio.thrift.BlockMasterClientService.getWorkerReport_result
 
toString() - Method in class alluxio.thrift.BlockMasterInfo
 
toString() - Method in class alluxio.thrift.BlockMasterWorkerService.blockHeartbeat_args
 
toString() - Method in class alluxio.thrift.BlockMasterWorkerService.blockHeartbeat_result
 
toString() - Method in class alluxio.thrift.BlockMasterWorkerService.commitBlock_args
 
toString() - Method in class alluxio.thrift.BlockMasterWorkerService.commitBlock_result
 
toString() - Method in class alluxio.thrift.BlockMasterWorkerService.getWorkerId_args
 
toString() - Method in class alluxio.thrift.BlockMasterWorkerService.getWorkerId_result
 
toString() - Method in class alluxio.thrift.BlockMasterWorkerService.registerWorker_args
 
toString() - Method in class alluxio.thrift.BlockMasterWorkerService.registerWorker_result
 
toString() - Method in class alluxio.thrift.BlockWorkerClientService.accessBlock_args
 
toString() - Method in class alluxio.thrift.BlockWorkerClientService.accessBlock_result
 
toString() - Method in class alluxio.thrift.BlockWorkerClientService.cacheBlock_args
 
toString() - Method in class alluxio.thrift.BlockWorkerClientService.cacheBlock_result
 
toString() - Method in class alluxio.thrift.BlockWorkerClientService.cancelBlock_args
 
toString() - Method in class alluxio.thrift.BlockWorkerClientService.cancelBlock_result
 
toString() - Method in class alluxio.thrift.BlockWorkerClientService.lockBlock_args
 
toString() - Method in class alluxio.thrift.BlockWorkerClientService.lockBlock_result
 
toString() - Method in class alluxio.thrift.BlockWorkerClientService.promoteBlock_args
 
toString() - Method in class alluxio.thrift.BlockWorkerClientService.promoteBlock_result
 
toString() - Method in class alluxio.thrift.BlockWorkerClientService.removeBlock_args
 
toString() - Method in class alluxio.thrift.BlockWorkerClientService.removeBlock_result
 
toString() - Method in class alluxio.thrift.BlockWorkerClientService.requestBlockLocation_args
 
toString() - Method in class alluxio.thrift.BlockWorkerClientService.requestBlockLocation_result
 
toString() - Method in class alluxio.thrift.BlockWorkerClientService.requestSpace_args
 
toString() - Method in class alluxio.thrift.BlockWorkerClientService.requestSpace_result
 
toString() - Method in class alluxio.thrift.BlockWorkerClientService.sessionBlockHeartbeat_args
 
toString() - Method in class alluxio.thrift.BlockWorkerClientService.sessionBlockHeartbeat_result
 
toString() - Method in class alluxio.thrift.BlockWorkerClientService.unlockBlock_args
 
toString() - Method in class alluxio.thrift.BlockWorkerClientService.unlockBlock_result
 
toString() - Method in class alluxio.thrift.CacheBlockTOptions
 
toString() - Method in class alluxio.thrift.CacheBlockTResponse
 
toString() - Method in class alluxio.thrift.CancelBlockTOptions
 
toString() - Method in class alluxio.thrift.CancelBlockTResponse
 
toString() - Method in class alluxio.thrift.CancelUfsFileTOptions
 
toString() - Method in class alluxio.thrift.CancelUfsFileTResponse
 
toString() - Method in class alluxio.thrift.CheckConsistencyTOptions
 
toString() - Method in class alluxio.thrift.CheckConsistencyTResponse
 
toString() - Method in class alluxio.thrift.CloseUfsFileTOptions
 
toString() - Method in class alluxio.thrift.CloseUfsFileTResponse
 
toString() - Method in class alluxio.thrift.Command
 
toString() - Method in class alluxio.thrift.CommandLineJobInfo
 
toString() - Method in class alluxio.thrift.CommitBlockTOptions
 
toString() - Method in class alluxio.thrift.CommitBlockTResponse
 
toString() - Method in class alluxio.thrift.CompleteFileTOptions
 
toString() - Method in class alluxio.thrift.CompleteFileTResponse
 
toString() - Method in class alluxio.thrift.CompletePartitionTOptions
 
toString() - Method in class alluxio.thrift.CompletePartitionTResponse
 
toString() - Method in class alluxio.thrift.CompleteStoreTOptions
 
toString() - Method in class alluxio.thrift.CompleteStoreTResponse
 
toString() - Method in class alluxio.thrift.CompleteUfsFileTOptions
 
toString() - Method in class alluxio.thrift.CompleteUfsFileTReponse
 
toString() - Method in class alluxio.thrift.ConfigCheckReport
 
toString() - Method in class alluxio.thrift.ConfigProperty
 
toString() - Method in class alluxio.thrift.CreateDirectoryTOptions
 
toString() - Method in class alluxio.thrift.CreateDirectoryTResponse
 
toString() - Method in class alluxio.thrift.CreateFileTOptions
 
toString() - Method in class alluxio.thrift.CreateFileTResponse
 
toString() - Method in class alluxio.thrift.CreateLineageTOptions
 
toString() - Method in class alluxio.thrift.CreateLineageTResponse
 
toString() - Method in class alluxio.thrift.CreateStoreTOptions
 
toString() - Method in class alluxio.thrift.CreateStoreTResponse
 
toString() - Method in class alluxio.thrift.CreateUfsFileTOptions
 
toString() - Method in class alluxio.thrift.CreateUfsFileTResponse
 
toString() - Method in class alluxio.thrift.DeleteLineageTOptions
 
toString() - Method in class alluxio.thrift.DeleteLineageTResponse
 
toString() - Method in class alluxio.thrift.DeleteStoreTOptions
 
toString() - Method in class alluxio.thrift.DeleteStoreTResponse
 
toString() - Method in class alluxio.thrift.DeleteTOptions
 
toString() - Method in class alluxio.thrift.DeleteTResponse
 
toString() - Method in class alluxio.thrift.DependencyInfo
 
toString() - Method in class alluxio.thrift.FileBlockInfo
 
toString() - Method in class alluxio.thrift.FileInfo
 
toString() - Method in class alluxio.thrift.FileSystemCommand
 
toString() - Method in class alluxio.thrift.FileSystemHeartbeatTOptions
 
toString() - Method in class alluxio.thrift.FileSystemHeartbeatTResponse
 
toString() - Method in class alluxio.thrift.FileSystemMasterClientService.checkConsistency_args
 
toString() - Method in class alluxio.thrift.FileSystemMasterClientService.checkConsistency_result
 
toString() - Method in class alluxio.thrift.FileSystemMasterClientService.completeFile_args
 
toString() - Method in class alluxio.thrift.FileSystemMasterClientService.completeFile_result
 
toString() - Method in class alluxio.thrift.FileSystemMasterClientService.createDirectory_args
 
toString() - Method in class alluxio.thrift.FileSystemMasterClientService.createDirectory_result
 
toString() - Method in class alluxio.thrift.FileSystemMasterClientService.createFile_args
 
toString() - Method in class alluxio.thrift.FileSystemMasterClientService.createFile_result
 
toString() - Method in class alluxio.thrift.FileSystemMasterClientService.free_args
 
toString() - Method in class alluxio.thrift.FileSystemMasterClientService.free_result
 
toString() - Method in class alluxio.thrift.FileSystemMasterClientService.getFilePath_args
 
toString() - Method in class alluxio.thrift.FileSystemMasterClientService.getFilePath_result
 
toString() - Method in class alluxio.thrift.FileSystemMasterClientService.getMountTable_args
 
toString() - Method in class alluxio.thrift.FileSystemMasterClientService.getMountTable_result
 
toString() - Method in class alluxio.thrift.FileSystemMasterClientService.getNewBlockIdForFile_args
 
toString() - Method in class alluxio.thrift.FileSystemMasterClientService.getNewBlockIdForFile_result
 
toString() - Method in class alluxio.thrift.FileSystemMasterClientService.getStatus_args
 
toString() - Method in class alluxio.thrift.FileSystemMasterClientService.getStatus_result
 
toString() - Method in class alluxio.thrift.FileSystemMasterClientService.listStatus_args
 
toString() - Method in class alluxio.thrift.FileSystemMasterClientService.listStatus_result
 
toString() - Method in class alluxio.thrift.FileSystemMasterClientService.loadMetadata_args
 
toString() - Method in class alluxio.thrift.FileSystemMasterClientService.loadMetadata_result
 
toString() - Method in class alluxio.thrift.FileSystemMasterClientService.mount_args
 
toString() - Method in class alluxio.thrift.FileSystemMasterClientService.mount_result
 
toString() - Method in class alluxio.thrift.FileSystemMasterClientService.remove_args
 
toString() - Method in class alluxio.thrift.FileSystemMasterClientService.remove_result
 
toString() - Method in class alluxio.thrift.FileSystemMasterClientService.rename_args
 
toString() - Method in class alluxio.thrift.FileSystemMasterClientService.rename_result
 
toString() - Method in class alluxio.thrift.FileSystemMasterClientService.scheduleAsyncPersistence_args
 
toString() - Method in class alluxio.thrift.FileSystemMasterClientService.scheduleAsyncPersistence_result
 
toString() - Method in class alluxio.thrift.FileSystemMasterClientService.setAttribute_args
 
toString() - Method in class alluxio.thrift.FileSystemMasterClientService.setAttribute_result
 
toString() - Method in class alluxio.thrift.FileSystemMasterClientService.unmount_args
 
toString() - Method in class alluxio.thrift.FileSystemMasterClientService.unmount_result
 
toString() - Method in class alluxio.thrift.FileSystemMasterClientService.updateUfsMode_args
 
toString() - Method in class alluxio.thrift.FileSystemMasterClientService.updateUfsMode_result
 
toString() - Method in class alluxio.thrift.FileSystemMasterCommonTOptions
 
toString() - Method in class alluxio.thrift.FileSystemMasterWorkerService.fileSystemHeartbeat_args
 
toString() - Method in class alluxio.thrift.FileSystemMasterWorkerService.fileSystemHeartbeat_result
 
toString() - Method in class alluxio.thrift.FileSystemMasterWorkerService.getFileInfo_args
 
toString() - Method in class alluxio.thrift.FileSystemMasterWorkerService.getFileInfo_result
 
toString() - Method in class alluxio.thrift.FileSystemMasterWorkerService.getPinnedFileIds_args
 
toString() - Method in class alluxio.thrift.FileSystemMasterWorkerService.getPinnedFileIds_result
 
toString() - Method in class alluxio.thrift.FileSystemMasterWorkerService.getUfsInfo_args
 
toString() - Method in class alluxio.thrift.FileSystemMasterWorkerService.getUfsInfo_result
 
toString() - Method in class alluxio.thrift.FileSystemWorkerClientService.cancelUfsFile_args
 
toString() - Method in class alluxio.thrift.FileSystemWorkerClientService.cancelUfsFile_result
 
toString() - Method in class alluxio.thrift.FileSystemWorkerClientService.closeUfsFile_args
 
toString() - Method in class alluxio.thrift.FileSystemWorkerClientService.closeUfsFile_result
 
toString() - Method in class alluxio.thrift.FileSystemWorkerClientService.completeUfsFile_args
 
toString() - Method in class alluxio.thrift.FileSystemWorkerClientService.completeUfsFile_result
 
toString() - Method in class alluxio.thrift.FileSystemWorkerClientService.createUfsFile_args
 
toString() - Method in class alluxio.thrift.FileSystemWorkerClientService.createUfsFile_result
 
toString() - Method in class alluxio.thrift.FileSystemWorkerClientService.openUfsFile_args
 
toString() - Method in class alluxio.thrift.FileSystemWorkerClientService.openUfsFile_result
 
toString() - Method in class alluxio.thrift.FileSystemWorkerClientService.sessionFileSystemHeartbeat_args
 
toString() - Method in class alluxio.thrift.FileSystemWorkerClientService.sessionFileSystemHeartbeat_result
 
toString() - Method in class alluxio.thrift.FreeTOptions
 
toString() - Method in class alluxio.thrift.FreeTResponse
 
toString() - Method in class alluxio.thrift.GetBlockInfoTOptions
 
toString() - Method in class alluxio.thrift.GetBlockInfoTResponse
 
toString() - Method in class alluxio.thrift.GetBlockMasterInfoTOptions
 
toString() - Method in class alluxio.thrift.GetBlockMasterInfoTResponse
 
toString() - Method in class alluxio.thrift.GetCapacityBytesTOptions
 
toString() - Method in class alluxio.thrift.GetCapacityBytesTResponse
 
toString() - Method in class alluxio.thrift.GetConfigReportTOptions
 
toString() - Method in class alluxio.thrift.GetConfigReportTResponse
 
toString() - Method in class alluxio.thrift.GetConfigurationTOptions
 
toString() - Method in class alluxio.thrift.GetConfigurationTResponse
 
toString() - Method in class alluxio.thrift.GetFileInfoTOptions
 
toString() - Method in class alluxio.thrift.GetFileInfoTResponse
 
toString() - Method in class alluxio.thrift.GetFilePathTOptions
 
toString() - Method in class alluxio.thrift.GetFilePathTResponse
 
toString() - Method in class alluxio.thrift.GetLineageInfoListTOptions
 
toString() - Method in class alluxio.thrift.GetLineageInfoListTResponse
 
toString() - Method in class alluxio.thrift.GetMasterIdTOptions
 
toString() - Method in class alluxio.thrift.GetMasterIdTResponse
 
toString() - Method in class alluxio.thrift.GetMasterInfoTOptions
 
toString() - Method in class alluxio.thrift.GetMasterInfoTResponse
 
toString() - Method in class alluxio.thrift.GetMetricsTOptions
 
toString() - Method in class alluxio.thrift.GetMetricsTResponse
 
toString() - Method in class alluxio.thrift.GetMountTableTResponse
 
toString() - Method in class alluxio.thrift.GetNewBlockIdForFileTOptions
 
toString() - Method in class alluxio.thrift.GetNewBlockIdForFileTResponse
 
toString() - Method in class alluxio.thrift.GetNextKeysTOptions
 
toString() - Method in class alluxio.thrift.GetNextKeysTResponse
 
toString() - Method in class alluxio.thrift.GetPartitionInfoTOptions
 
toString() - Method in class alluxio.thrift.GetPartitionInfoTResponse
 
toString() - Method in class alluxio.thrift.GetPinnedFileIdsTOptions
 
toString() - Method in class alluxio.thrift.GetPinnedFileIdsTResponse
 
toString() - Method in class alluxio.thrift.GetServiceVersionTOptions
 
toString() - Method in class alluxio.thrift.GetServiceVersionTResponse
 
toString() - Method in class alluxio.thrift.GetSizeTOptions
 
toString() - Method in class alluxio.thrift.GetSizeTResponse
 
toString() - Method in class alluxio.thrift.GetStatusTOptions
 
toString() - Method in class alluxio.thrift.GetStatusTResponse
 
toString() - Method in class alluxio.thrift.GetTOptions
 
toString() - Method in class alluxio.thrift.GetTResponse
 
toString() - Method in class alluxio.thrift.GetUfsInfoTOptions
 
toString() - Method in class alluxio.thrift.GetUfsInfoTResponse
 
toString() - Method in class alluxio.thrift.GetUsedBytesTOptions
 
toString() - Method in class alluxio.thrift.GetUsedBytesTResponse
 
toString() - Method in class alluxio.thrift.GetWorkerIdTOptions
 
toString() - Method in class alluxio.thrift.GetWorkerIdTResponse
 
toString() - Method in class alluxio.thrift.GetWorkerInfoListTOptions
 
toString() - Method in class alluxio.thrift.GetWorkerInfoListTResponse
 
toString() - Method in class alluxio.thrift.GetWorkerReportTOptions
 
toString() - Method in class alluxio.thrift.InconsistentProperty
 
toString() - Method in class alluxio.thrift.JobConfInfo
 
toString() - Method in class alluxio.thrift.KeyValueMasterClientService.completePartition_args
 
toString() - Method in class alluxio.thrift.KeyValueMasterClientService.completePartition_result
 
toString() - Method in class alluxio.thrift.KeyValueMasterClientService.completeStore_args
 
toString() - Method in class alluxio.thrift.KeyValueMasterClientService.completeStore_result
 
toString() - Method in class alluxio.thrift.KeyValueMasterClientService.createStore_args
 
toString() - Method in class alluxio.thrift.KeyValueMasterClientService.createStore_result
 
toString() - Method in class alluxio.thrift.KeyValueMasterClientService.deleteStore_args
 
toString() - Method in class alluxio.thrift.KeyValueMasterClientService.deleteStore_result
 
toString() - Method in class alluxio.thrift.KeyValueMasterClientService.getPartitionInfo_args
 
toString() - Method in class alluxio.thrift.KeyValueMasterClientService.getPartitionInfo_result
 
toString() - Method in class alluxio.thrift.KeyValueMasterClientService.mergeStore_args
 
toString() - Method in class alluxio.thrift.KeyValueMasterClientService.mergeStore_result
 
toString() - Method in class alluxio.thrift.KeyValueMasterClientService.renameStore_args
 
toString() - Method in class alluxio.thrift.KeyValueMasterClientService.renameStore_result
 
toString() - Method in class alluxio.thrift.KeyValueWorkerClientService.get_args
 
toString() - Method in class alluxio.thrift.KeyValueWorkerClientService.get_result
 
toString() - Method in class alluxio.thrift.KeyValueWorkerClientService.getNextKeys_args
 
toString() - Method in class alluxio.thrift.KeyValueWorkerClientService.getNextKeys_result
 
toString() - Method in class alluxio.thrift.KeyValueWorkerClientService.getSize_args
 
toString() - Method in class alluxio.thrift.KeyValueWorkerClientService.getSize_result
 
toString() - Method in class alluxio.thrift.LineageInfo
 
toString() - Method in class alluxio.thrift.LineageMasterClientService.createLineage_args
 
toString() - Method in class alluxio.thrift.LineageMasterClientService.createLineage_result
 
toString() - Method in class alluxio.thrift.LineageMasterClientService.deleteLineage_args
 
toString() - Method in class alluxio.thrift.LineageMasterClientService.deleteLineage_result
 
toString() - Method in class alluxio.thrift.LineageMasterClientService.getLineageInfoList_args
 
toString() - Method in class alluxio.thrift.LineageMasterClientService.getLineageInfoList_result
 
toString() - Method in class alluxio.thrift.LineageMasterClientService.reinitializeFile_args
 
toString() - Method in class alluxio.thrift.LineageMasterClientService.reinitializeFile_result
 
toString() - Method in class alluxio.thrift.LineageMasterClientService.reportLostFile_args
 
toString() - Method in class alluxio.thrift.LineageMasterClientService.reportLostFile_result
 
toString() - Method in class alluxio.thrift.ListStatusTOptions
 
toString() - Method in class alluxio.thrift.ListStatusTResponse
 
toString() - Method in class alluxio.thrift.LoadMetadataTOptions
 
toString() - Method in class alluxio.thrift.LoadMetadataTResponse
 
toString() - Method in class alluxio.thrift.LocalityTier
 
toString() - Method in class alluxio.thrift.LockBlockTOptions
 
toString() - Method in class alluxio.thrift.LockBlockTResponse
 
toString() - Method in class alluxio.thrift.MasterHeartbeatTOptions
 
toString() - Method in class alluxio.thrift.MasterHeartbeatTResponse
 
toString() - Method in class alluxio.thrift.MasterInfo
 
toString() - Method in class alluxio.thrift.MasterNetAddress
 
toString() - Method in class alluxio.thrift.MergeStoreTOptions
 
toString() - Method in class alluxio.thrift.MergeStoreTResponse
 
toString() - Method in class alluxio.thrift.MetaMasterClientService.backup_args
 
toString() - Method in class alluxio.thrift.MetaMasterClientService.backup_result
 
toString() - Method in class alluxio.thrift.MetaMasterClientService.getConfigReport_args
 
toString() - Method in class alluxio.thrift.MetaMasterClientService.getConfigReport_result
 
toString() - Method in class alluxio.thrift.MetaMasterClientService.getConfiguration_args
 
toString() - Method in class alluxio.thrift.MetaMasterClientService.getConfiguration_result
 
toString() - Method in class alluxio.thrift.MetaMasterClientService.getMasterInfo_args
 
toString() - Method in class alluxio.thrift.MetaMasterClientService.getMasterInfo_result
 
toString() - Method in class alluxio.thrift.MetaMasterClientService.getMetrics_args
 
toString() - Method in class alluxio.thrift.MetaMasterClientService.getMetrics_result
 
toString() - Method in class alluxio.thrift.MetaMasterMasterService.getMasterId_args
 
toString() - Method in class alluxio.thrift.MetaMasterMasterService.getMasterId_result
 
toString() - Method in class alluxio.thrift.MetaMasterMasterService.masterHeartbeat_args
 
toString() - Method in class alluxio.thrift.MetaMasterMasterService.masterHeartbeat_result
 
toString() - Method in class alluxio.thrift.MetaMasterMasterService.registerMaster_args
 
toString() - Method in class alluxio.thrift.MetaMasterMasterService.registerMaster_result
 
toString() - Method in class alluxio.thrift.Metric
 
toString() - Method in class alluxio.thrift.MetricsHeartbeatTOptions
 
toString() - Method in class alluxio.thrift.MetricsHeartbeatTResponse
 
toString() - Method in class alluxio.thrift.MetricsMasterClientService.metricsHeartbeat_args
 
toString() - Method in class alluxio.thrift.MetricsMasterClientService.metricsHeartbeat_result
 
toString() - Method in class alluxio.thrift.MetricValue
 
toString() - Method in class alluxio.thrift.MountPointInfo
 
toString() - Method in class alluxio.thrift.MountTOptions
 
toString() - Method in class alluxio.thrift.MountTResponse
 
toString() - Method in class alluxio.thrift.OpenUfsFileTOptions
 
toString() - Method in class alluxio.thrift.OpenUfsFileTResponse
 
toString() - Method in class alluxio.thrift.OptionalString
 
toString() - Method in class alluxio.thrift.PartitionInfo
 
toString() - Method in class alluxio.thrift.PersistCommandOptions
 
toString() - Method in class alluxio.thrift.PersistFile
 
toString() - Method in class alluxio.thrift.PromoteBlockTOptions
 
toString() - Method in class alluxio.thrift.PromoteBlockTResponse
 
toString() - Method in class alluxio.thrift.RegisterMasterTOptions
 
toString() - Method in class alluxio.thrift.RegisterMasterTResponse
 
toString() - Method in class alluxio.thrift.RegisterWorkerTOptions
 
toString() - Method in class alluxio.thrift.RegisterWorkerTResponse
 
toString() - Method in class alluxio.thrift.ReinitializeFileTOptions
 
toString() - Method in class alluxio.thrift.ReinitializeFileTResponse
 
toString() - Method in class alluxio.thrift.RemoveBlockTOptions
 
toString() - Method in class alluxio.thrift.RemoveBlockTResponse
 
toString() - Method in class alluxio.thrift.RenameStoreTOptions
 
toString() - Method in class alluxio.thrift.RenameStoreTResponse
 
toString() - Method in class alluxio.thrift.RenameTOptions
 
toString() - Method in class alluxio.thrift.RenameTResponse
 
toString() - Method in class alluxio.thrift.ReportLostFileTOptions
 
toString() - Method in class alluxio.thrift.ReportLostFileTResponse
 
toString() - Method in class alluxio.thrift.RequestBlockLocationTOptions
 
toString() - Method in class alluxio.thrift.RequestBlockLocationTResponse
 
toString() - Method in class alluxio.thrift.RequestSpaceTOptions
 
toString() - Method in class alluxio.thrift.RequestSpaceTResponse
 
toString() - Method in class alluxio.thrift.ScheduleAsyncPersistenceTOptions
 
toString() - Method in class alluxio.thrift.ScheduleAsyncPersistenceTResponse
 
toString() - Method in class alluxio.thrift.SessionBlockHeartbeatTOptions
 
toString() - Method in class alluxio.thrift.SessionBlockHeartbeatTResponse
 
toString() - Method in class alluxio.thrift.SessionFileSystemHeartbeatTOptions
 
toString() - Method in class alluxio.thrift.SessionFileSystemHeartbeatTResponse
 
toString() - Method in class alluxio.thrift.SetAttributeTOptions
 
toString() - Method in class alluxio.thrift.SetAttributeTResponse
 
toString() - Method in class alluxio.thrift.SyncMetadataTOptions
 
toString() - Method in class alluxio.thrift.SyncMetadataTResponse
 
toString() - Method in class alluxio.thrift.TieredIdentity
 
toString() - Method in class alluxio.thrift.UfsInfo
 
toString() - Method in class alluxio.thrift.UnlockBlockTOptions
 
toString() - Method in class alluxio.thrift.UnlockBlockTResponse
 
toString() - Method in class alluxio.thrift.UnmountTOptions
 
toString() - Method in class alluxio.thrift.UnmountTResponse
 
toString() - Method in class alluxio.thrift.UpdateUfsModeTOptions
 
toString() - Method in class alluxio.thrift.UpdateUfsModeTResponse
 
toString() - Method in class alluxio.thrift.WorkerInfo
 
toString() - Method in class alluxio.thrift.WorkerNetAddress
 
toString() - Method in class alluxio.underfs.AbstractUfsManager.Key
 
toString() - Method in class alluxio.underfs.options.CreateOptions
 
toString() - Method in class alluxio.underfs.options.DeleteOptions
 
toString() - Method in class alluxio.underfs.options.FileLocationOptions
 
toString() - Method in class alluxio.underfs.options.ListOptions
 
toString() - Method in class alluxio.underfs.options.MkdirsOptions
 
toString() - Method in class alluxio.underfs.options.OpenOptions
 
toString() - Method in class alluxio.underfs.UfsDirectoryStatus
 
toString() - Method in class alluxio.underfs.UfsFileStatus
 
toString() - Method in class alluxio.util.executor.ControllableQueue
 
toString() - Method in class alluxio.util.proto.ProtoMessage
 
toString() - Method in exception alluxio.util.ShellUtils.ExitCodeException
 
toString() - Method in class alluxio.util.UnixMountInfo.Options
 
toString() - Method in class alluxio.util.UnixMountInfo
 
toString() - Method in class alluxio.util.WaitForOptions
 
toString() - Method in class alluxio.wire.Address
 
toString() - Method in class alluxio.wire.AlluxioMasterInfo
 
toString() - Method in class alluxio.wire.AlluxioProxyInfo
 
toString() - Method in class alluxio.wire.AlluxioWorkerInfo
 
toString() - Method in class alluxio.wire.BlockInfo
 
toString() - Method in class alluxio.wire.BlockLocation
 
toString() - Method in class alluxio.wire.BlockMasterInfo
 
toString() - Method in class alluxio.wire.Capacity
 
toString() - Method in class alluxio.wire.CommandLineJobInfo
 
toString() - Method in class alluxio.wire.CommonOptions
 
toString() - Method in class alluxio.wire.ConfigProperty
 
toString() - Method in class alluxio.wire.FileBlockInfo
 
toString() - Method in class alluxio.wire.FileInfo
 
toString() - Method in class alluxio.wire.GetConfigurationOptions
 
toString() - Method in class alluxio.wire.InconsistentProperty
 
toString() - Method in class alluxio.wire.JobConfInfo
 
toString() - Method in class alluxio.wire.LineageInfo
 
toString() - Method in class alluxio.wire.LogInfo
 
toString() - Method in class alluxio.wire.MasterInfo
 
toString() - Method in class alluxio.wire.MetricValue
 
toString() - Method in class alluxio.wire.MountPointInfo
 
toString() - Method in class alluxio.wire.StartupConsistencyCheck
 
toString() - Method in class alluxio.wire.TieredIdentity.LocalityTier
 
toString() - Method in class alluxio.wire.TieredIdentity
 
toString() - Method in class alluxio.wire.WorkerInfo
 
toString() - Method in class alluxio.wire.WorkerNetAddress
 
toString() - Method in class alluxio.worker.AlluxioWorkerProcess
 
toString() - Method in class alluxio.worker.block.BlockStoreLocation
Converts the location to a human readable form.
toString() - Method in class alluxio.worker.block.evictor.BlockTransferInfo
 
toString() - Method in class alluxio.worker.block.evictor.EvictionPlan
 
toStringArray(ArrayList<String>) - Static method in class alluxio.util.CommonUtils
Parses ArrayList<String> into String[].
toStringHadoopFileSplit(FileSplit) - Static method in class alluxio.hadoop.HadoopUtils
Returns a string representation of a Hadoop FileSplit.
toStringHadoopFileStatus(FileStatus) - Static method in class alluxio.hadoop.HadoopUtils
Returns a string representation of a Hadoop FileStatus.
toStringHadoopInputSplit(InputSplit) - Static method in class alluxio.hadoop.HadoopUtils
Returns a string representation of a InputSplit.
toStringHelper() - Method in class alluxio.master.file.meta.Inode
 
toStringHelper() - Method in class alluxio.master.file.options.CreatePathOptions
 
toStringHelper() - Method in class alluxio.underfs.UfsStatus
 
toSyncChildren() - Method in class alluxio.master.file.meta.UfsSyncUtils.SyncPlan
 
toThrift() - Method in class alluxio.client.block.options.GetWorkerReportOptions
 
toThrift() - Method in enum alluxio.client.block.options.GetWorkerReportOptions.WorkerInfoField
 
toThrift() - Method in enum alluxio.client.block.options.GetWorkerReportOptions.WorkerRange
 
toThrift() - Method in class alluxio.client.block.options.LockBlockOptions
Converts the object to a LockBlockTOptions object.
toThrift() - Method in class alluxio.client.file.options.CancelUfsFileOptions
 
toThrift() - Method in class alluxio.client.file.options.CheckConsistencyOptions
 
toThrift() - Method in class alluxio.client.file.options.CloseUfsFileOptions
 
toThrift() - Method in class alluxio.client.file.options.CompleteFileOptions
 
toThrift() - Method in class alluxio.client.file.options.CompleteUfsFileOptions
 
toThrift() - Method in class alluxio.client.file.options.CreateDirectoryOptions
 
toThrift() - Method in class alluxio.client.file.options.CreateFileOptions
 
toThrift() - Method in class alluxio.client.file.options.CreateUfsFileOptions
 
toThrift() - Method in class alluxio.client.file.options.DeleteOptions
 
toThrift() - Method in class alluxio.client.file.options.FreeOptions
 
toThrift() - Method in class alluxio.client.file.options.GetStatusOptions
 
toThrift() - Method in class alluxio.client.file.options.ListStatusOptions
 
toThrift() - Method in class alluxio.client.file.options.MountOptions
 
toThrift() - Method in class alluxio.client.file.options.OpenUfsFileOptions
 
toThrift() - Method in class alluxio.client.file.options.RenameOptions
 
toThrift() - Method in class alluxio.client.file.options.SetAttributeOptions
 
toThrift() - Method in class alluxio.client.file.options.UnmountOptions
 
toThrift() - Method in class alluxio.client.file.options.UpdateUfsModeOptions
 
toThrift() - Method in exception alluxio.exception.status.AlluxioStatusException
 
toThrift(Status) - Static method in enum alluxio.exception.status.Status
Converts an internal exception status to a Thrift type status.
toThrift() - Method in class alluxio.metrics.Metric
 
toThrift() - Method in class alluxio.wire.Address
 
toThrift() - Method in class alluxio.wire.BackupOptions
 
toThrift() - Method in class alluxio.wire.BackupResponse
 
toThrift() - Method in class alluxio.wire.BlockInfo
 
toThrift() - Method in class alluxio.wire.BlockLocation
 
toThrift() - Method in enum alluxio.wire.BlockMasterInfo.BlockMasterInfoField
 
toThrift() - Method in class alluxio.wire.BlockMasterInfo
 
toThrift() - Method in class alluxio.wire.CommandLineJobInfo
 
toThrift() - Method in class alluxio.wire.CommonOptions
 
toThrift() - Method in enum alluxio.wire.ConfigCheckReport.ConfigStatus
 
toThrift() - Method in class alluxio.wire.ConfigCheckReport
 
toThrift() - Method in class alluxio.wire.ConfigProperty
 
toThrift() - Method in class alluxio.wire.FileBlockInfo
 
toThrift() - Method in class alluxio.wire.FileInfo
 
toThrift() - Method in class alluxio.wire.GetConfigurationOptions
 
toThrift() - Method in class alluxio.wire.InconsistentProperty
 
toThrift() - Method in class alluxio.wire.JobConfInfo
 
toThrift() - Method in class alluxio.wire.LineageInfo
 
toThrift(LoadMetadataType) - Static method in enum alluxio.wire.LoadMetadataType
 
toThrift() - Method in enum alluxio.wire.MasterInfo.MasterInfoField
 
toThrift() - Method in class alluxio.wire.MasterInfo
 
toThrift() - Method in class alluxio.wire.MetricValue
 
toThrift() - Method in class alluxio.wire.MountPointInfo
 
toThrift() - Method in class alluxio.wire.OptionalString
 
toThrift() - Method in enum alluxio.wire.Scope
 
toThrift() - Method in class alluxio.wire.TieredIdentity.LocalityTier
 
toThrift() - Method in class alluxio.wire.TieredIdentity
 
toThrift(TtlAction) - Static method in enum alluxio.wire.TtlAction
Converts wire type to thrift type.
toThrift() - Method in class alluxio.wire.WorkerInfo
 
toThrift() - Method in class alluxio.wire.WorkerNetAddress
 
touch(UnderFileSystem, String) - Static method in class alluxio.util.UnderFileSystemUtils
Creates an empty file.
TouchCommand - Class in alluxio.cli.fs.command
Creates a 0 byte file specified by argv.
TouchCommand(FileSystem) - Constructor for class alluxio.cli.fs.command.TouchCommand
 
toUpdateMetaData() - Method in class alluxio.master.file.meta.UfsSyncUtils.SyncPlan
 
toUserPropertyMap(ConfigurationValueOptions) - Method in class alluxio.underfs.UnderFileSystemConfiguration
 
trace(String) - Method in class alluxio.util.logging.SamplingLogger
 
trace(String, Object) - Method in class alluxio.util.logging.SamplingLogger
 
trace(String, Object, Object) - Method in class alluxio.util.logging.SamplingLogger
 
trace(String, Object...) - Method in class alluxio.util.logging.SamplingLogger
 
trace(String, Throwable) - Method in class alluxio.util.logging.SamplingLogger
 
trace(Marker, String) - Method in class alluxio.util.logging.SamplingLogger
 
trace(Marker, String, Object) - Method in class alluxio.util.logging.SamplingLogger
 
trace(Marker, String, Object, Object) - Method in class alluxio.util.logging.SamplingLogger
 
trace(Marker, String, Object...) - Method in class alluxio.util.logging.SamplingLogger
 
trace(Marker, String, Throwable) - Method in class alluxio.util.logging.SamplingLogger
 
transferTo(ByteBuf) - Method in interface alluxio.worker.block.io.BlockReader
Transfers data (up to buf.writableBytes()) from this reader to the buffer.
transferTo(ByteBuf) - Method in class alluxio.worker.block.io.LocalFileBlockReader
 
transferTo(ByteBuf) - Method in class alluxio.worker.block.RemoteBlockReader
 
transferTo(ByteBuf) - Method in class alluxio.worker.block.UnderFileSystemBlockReader
This interface is supposed to be used for sequence block reads.
translateBucketAcl(GSAccessControlList, String) - Static method in class alluxio.underfs.gcs.GCSUtils
Translates GCS bucket owner ACL to Alluxio owner mode.
translateBucketAcl(AccessControlList, String) - Static method in class alluxio.underfs.s3a.S3AUtils
Translates S3 bucket ACL to Alluxio owner mode.
translatePosixPermissionToMode(Set<PosixFilePermission>) - Static method in class alluxio.util.io.FileUtils
Translate posix file permissions to short mode.
TransportProvider - Interface in alluxio.security.authentication
Interface to provide thrift transport service for thrift client and server, based on the type of authentication.
TransportProvider.Factory - Class in alluxio.security.authentication
Factory for TransportProvider.
TransportProviderUtils - Class in alluxio.security.authentication
This class provides util methods for TransportProviders.
TStatus - Enum in alluxio.thrift
 
TTL_FIELD_NUMBER - Static variable in class alluxio.proto.journal.File.InodeDirectoryEntry
 
TTL_FIELD_NUMBER - Static variable in class alluxio.proto.journal.File.InodeFileEntry
 
TTL_FIELD_NUMBER - Static variable in class alluxio.proto.journal.File.ReinitializeFileEntry
 
TTL_FIELD_NUMBER - Static variable in class alluxio.proto.journal.File.SetAttributeEntry
 
TtlAction - Enum in alluxio.wire
Represents the file action to take when its TTL expires.
TTLACTION_FIELD_NUMBER - Static variable in class alluxio.proto.journal.File.InodeDirectoryEntry
 
TTLACTION_FIELD_NUMBER - Static variable in class alluxio.proto.journal.File.InodeFileEntry
 
TTLACTION_FIELD_NUMBER - Static variable in class alluxio.proto.journal.File.ReinitializeFileEntry
 
TTLACTION_FIELD_NUMBER - Static variable in class alluxio.proto.journal.File.SetAttributeEntry
 
TtlBucket - Class in alluxio.master.file.meta
A bucket with all inodes whose ttl value lies in the bucket's time interval.
TtlBucket(long) - Constructor for class alluxio.master.file.meta.TtlBucket
Creates a new instance of TtlBucket.
TtlBucketList - Class in alluxio.master.file.meta
A list of non-empty TtlBuckets sorted by ttl interval start time of each bucket.
TtlBucketList() - Constructor for class alluxio.master.file.meta.TtlBucketList
Creates a new list of TtlBuckets.
TTtlAction - Enum in alluxio.thrift
 
tupleSchemeReadValue(TProtocol, short) - Method in class alluxio.thrift.FileSystemCommandOptions
 
tupleSchemeWriteValue(TProtocol) - Method in class alluxio.thrift.FileSystemCommandOptions
 
TYPE_FIELD_NUMBER - Static variable in class alluxio.proto.dataserver.Protocol.ReadResponse
 
TYPE_FIELD_NUMBER - Static variable in class alluxio.proto.dataserver.Protocol.WriteRequest
 

U

UFS_CAPACITY_FREE - Static variable in class alluxio.metrics.MasterMetrics
 
UFS_CAPACITY_TOTAL - Static variable in class alluxio.metrics.MasterMetrics
 
UFS_CAPACITY_USED - Static variable in class alluxio.metrics.MasterMetrics
 
UFS_FILE_VALUE - Static variable in enum alluxio.proto.dataserver.Protocol.RequestType
UFS_FILE = 1;
UFS_FINGERPRINT_FIELD_NUMBER - Static variable in class alluxio.proto.journal.File.CompleteFileEntry
 
UFS_FINGERPRINT_FIELD_NUMBER - Static variable in class alluxio.proto.journal.File.InodeFileEntry
 
UFS_FINGERPRINT_FIELD_NUMBER - Static variable in class alluxio.proto.journal.File.SetAttributeEntry
 
UFS_INPUT_STREAM_CACHE_EXPIRATION - Static variable in class alluxio.Constants
 
UFS_OP_PREFIX - Static variable in class alluxio.metrics.WorkerMetrics
 
UFS_PATH_FIELD_NUMBER - Static variable in class alluxio.proto.dataserver.Protocol.CreateUfsFileOptions
 
UFS_PATH_FIELD_NUMBER - Static variable in class alluxio.proto.dataserver.Protocol.OpenUfsBlockOptions
 
UFS_PATH_FIELD_NUMBER - Static variable in class alluxio.proto.journal.File.AddMountPointEntry
 
UFS_READ_HEARTBEAT_VALUE - Static variable in enum alluxio.proto.dataserver.Protocol.ReadResponse.Type
UFS_READ_HEARTBEAT = 1;
UfsAbsentPathCache - Interface in alluxio.master.file.meta
Cache for recording information about paths that are not present in UFS.
UfsAbsentPathCache.Factory - Class in alluxio.master.file.meta
Factory class for UfsAbsentPathCache.
UfsBlockAccessTokenUnavailableException - Exception in alluxio.exception
The exception thrown when it fails to grab a UFS access token for a UFS block.
UfsBlockAccessTokenUnavailableException(String) - Constructor for exception alluxio.exception.UfsBlockAccessTokenUnavailableException
Constructs a new exception with the specified detail message.
UfsBlockAccessTokenUnavailableException(String, Throwable) - Constructor for exception alluxio.exception.UfsBlockAccessTokenUnavailableException
Constructs a new exception with the specified detail message and cause.
UfsBlockAccessTokenUnavailableException(ExceptionMessage, Object...) - Constructor for exception alluxio.exception.UfsBlockAccessTokenUnavailableException
Constructs a new exception with the specified exception message and multiple parameters.
UfsBlockAccessTokenUnavailableException(ExceptionMessage, Throwable, Object...) - Constructor for exception alluxio.exception.UfsBlockAccessTokenUnavailableException
Constructs a new exception with the specified exception message, the cause and multiple parameters.
UfsBlockLocationCache - Interface in alluxio.master.file.meta
Cache for block locations in the UFS.
UfsBlockLocationCache.Factory - Class in alluxio.master.file.meta
Factory class for UfsBlockLocationCache.
UfsCheckpointManager - Class in alluxio.master.journalv0.ufs
Manages the checkpoint for a journal.
UfsCheckpointManager(UnderFileSystem, URI, UfsJournalWriter) - Constructor for class alluxio.master.journalv0.ufs.UfsCheckpointManager
Creates a new instance of UfsCheckpointManager.
UfsClient(Supplier<UnderFileSystem>, AlluxioURI) - Constructor for class alluxio.underfs.UfsManager.UfsClient
 
UfsCommand - Class in alluxio.cli.fsadmin.command
Update attributes for an existing mount point.
UfsCommand(Context) - Constructor for class alluxio.cli.fsadmin.command.UfsCommand
 
UfsCommand - Class in alluxio.cli.fsadmin.report
Prints under filesystem information.
UfsCommand(FileSystemMasterClient) - Constructor for class alluxio.cli.fsadmin.report.UfsCommand
Creates a new instance of UfsCommand.
UfsDeleter - Interface in alluxio.master.file
Interface for deleting persisted entries from the UFS.
UfsDirectoryStatus - Class in alluxio.underfs
Information about a directory in the under file system.
UfsDirectoryStatus(String, String, String, short) - Constructor for class alluxio.underfs.UfsDirectoryStatus
Creates new instance of UfsDirectoryStatus without providing last modified time.
UfsDirectoryStatus(String, String, String, short, long) - Constructor for class alluxio.underfs.UfsDirectoryStatus
Creates new instance of UfsDirectoryStatus.
UfsDirectoryStatus(UfsDirectoryStatus) - Constructor for class alluxio.underfs.UfsDirectoryStatus
Creates a new instance of under directory information as a copy.
UfsDirectoryValidationTask - Class in alluxio.cli.validation
Task for validating whether UFS directory is accessible.
UfsDirectoryValidationTask() - Constructor for class alluxio.cli.validation.UfsDirectoryValidationTask
Creates a new instance of UfsDirectoryValidationTask for validating root under file system.
UfsFilePacketWriter(UfsFileWriteRequestContext, Channel, UfsManager) - Constructor for class alluxio.worker.netty.UfsFileWriteHandler.UfsFilePacketWriter
 
UfsFileStatus - Class in alluxio.underfs
Information about a file in UnderFileSystem.
UfsFileStatus(String, String, long, long, String, String, short) - Constructor for class alluxio.underfs.UfsFileStatus
Creates new instance of UfsFileStatus.
UfsFileStatus(UfsFileStatus) - Constructor for class alluxio.underfs.UfsFileStatus
Creates a new instance of UfsFileStatus as a copy.
UfsFileWriteHandler - Class in alluxio.worker.netty
This handler handles writes to a file in the under file system.
UfsFileWriteHandler.UfsFilePacketWriter - Class in alluxio.worker.netty
The packet writer that writes to UFS.
UfsFileWriteRequest - Class in alluxio.worker.netty
The UFS File write request internal representation.
UfsFileWriteRequestContext - Class in alluxio.worker.netty
The UFS File write request internal representation.
ufsFingerprintList() - Method in class alluxio.worker.file.FileDataManager.PersistedFilesInfo
 
UfsInfo - Class in alluxio.thrift
 
UfsInfo() - Constructor for class alluxio.thrift.UfsInfo
 
UfsInfo(UfsInfo) - Constructor for class alluxio.thrift.UfsInfo
Performs a deep copy on other.
UfsInfo._Fields - Enum in alluxio.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
UfsInputStreamManager - Class in alluxio.worker.block
An under filesystem input stream manager that can cache seekable input streams for future reuse.
UfsInputStreamManager() - Constructor for class alluxio.worker.block.UfsInputStreamManager
Creates a new UfsInputStreamManager.
UfsJournal - Class in alluxio.master.journal.ufs
Implementation of UFS-based journal.
UfsJournal(URI, JournalEntryStateMachine, long) - Constructor for class alluxio.master.journal.ufs.UfsJournal
Creates a new instance of UfsJournal.
UfsJournal - Class in alluxio.master.journalv0.ufs
Implementation of UFS-based journal.
UfsJournal(URI) - Constructor for class alluxio.master.journalv0.ufs.UfsJournal
Creates a new instance of UfsJournal.
UfsJournalCheckpointThread - Class in alluxio.master.journal.ufs
This thread continually replays the journal and applies it to the master, until the master initiates the shutdown of the thread.
UfsJournalCheckpointThread(JournalEntryStateMachine, UfsJournal) - Constructor for class alluxio.master.journal.ufs.UfsJournalCheckpointThread
Creates a new instance of UfsJournalCheckpointThread.
UfsJournalFile - Class in alluxio.master.journal.ufs
A simple data structure that represents a journal file.
UfsJournalFileParser - Class in alluxio.master.journal.ufs
Implementation of JournalFileParser that parses a journal file.
UfsJournalFileParser(URI) - Constructor for class alluxio.master.journal.ufs.UfsJournalFileParser
Creates a new instance of UfsJournalFileParser.
UfsJournalReader - Class in alluxio.master.journal.ufs
Implementation of JournalReader that reads journal entries from a UFS.
UfsJournalReader(UfsJournal, long, boolean) - Constructor for class alluxio.master.journal.ufs.UfsJournalReader
Creates a new instance of UfsJournalReader.
UfsJournalReader - Class in alluxio.master.journalv0.ufs
Implementation of JournalReader based on UFS.
UfsJournalSnapshot - Class in alluxio.master.journal.ufs
This class provides a snapshot of everything in the journal and some utility methods.
UfsJournalSystem - Class in alluxio.master.journal.ufs
Factory for under file storage journals.
UfsJournalSystem(URI, long) - Constructor for class alluxio.master.journal.ufs.UfsJournalSystem
Creates a UFS journal system with the specified base location.
UfsJournalWriter - Class in alluxio.master.journalv0.ufs
Implementation of JournalWriter based on UFS.
UfsJournalWriter.EntryOutputStream - Class in alluxio.master.journalv0.ufs
This is the output stream for the journal entries after the checkpoint.
UfsManager - Interface in alluxio.underfs
A class that manages the UFS used by different services.
UfsManager.UfsClient - Class in alluxio.underfs
Container for a UFS and the URI for that UFS.
UfsMode - Enum in alluxio.thrift
 
UFSMODE_FIELD_NUMBER - Static variable in class alluxio.proto.journal.File.UpdateUfsModeEntry
 
UfsMutableJournal - Class in alluxio.master.journalv0.ufs
Implementation of MutableJournal based on UFS.
UfsMutableJournal(URI) - Constructor for class alluxio.master.journalv0.ufs.UfsMutableJournal
 
UFSPATH_FIELD_NUMBER - Static variable in class alluxio.proto.journal.File.UpdateUfsModeEntry
 
UfsStatus - Class in alluxio.underfs
Information about a file or a directory in the under file system.
UfsStatus(String, boolean, String, String, short, Long) - Constructor for class alluxio.underfs.UfsStatus
Creates new instance of UfsStatus.
UfsStatus(UfsStatus) - Constructor for class alluxio.underfs.UfsStatus
Creates a new instance of UfsStatus as a copy.
UfsSuperUserValidationTask - Class in alluxio.cli.validation
Task for validating whether Alluxio can access UFS as super user.
UfsSuperUserValidationTask() - Constructor for class alluxio.cli.validation.UfsSuperUserValidationTask
Creates a new instance of UfsSuperUserValidationTask for validating root under file system.
UfsSyncChecker - Class in alluxio.master.file
Class to check if the contents of the under storage is in-sync with the master.
UfsSyncChecker(MountTable) - Constructor for class alluxio.master.file.UfsSyncChecker
Create a new instance of UfsSyncChecker.
UfsSyncPathCache - Class in alluxio.master.file.meta
This cache maintains the Alluxio paths which have been synced with UFS.
UfsSyncPathCache() - Constructor for class alluxio.master.file.meta.UfsSyncPathCache
Creates a new instance of UfsSyncPathCache.
UfsSyncUtils - Class in alluxio.master.file.meta
Util methods for UFS sync.
UfsSyncUtils.SyncPlan - Class in alluxio.master.file.meta
A class describing how to sync an inode with the ufs.
UIFileBlockInfo - Class in alluxio.web
Contains information for displaying a file block in the UI.
UIFileBlockInfo(FileBlockInfo) - Constructor for class alluxio.web.UIFileBlockInfo
Creates a new instance of UIFileBlockInfo.
UIFileBlockInfo(long, long, long, String) - Constructor for class alluxio.web.UIFileBlockInfo
Creates a new instance of UIFileBlockInfo.
UIFileInfo - Class in alluxio.web
Contains information about a file to be displayed in the UI.
UIFileInfo(URIStatus) - Constructor for class alluxio.web.UIFileInfo
Creates a new instance of UIFileInfo.
UIFileInfo(FileInfo) - Constructor for class alluxio.web.UIFileInfo
Creates a new instance of UIFileInfo.
UIFileInfo(UIFileInfo.LocalFileInfo) - Constructor for class alluxio.web.UIFileInfo
Creates a new instance of UIFileInfo.
UIStorageDir(String, String, long, long) - Constructor for class alluxio.web.WebInterfaceWorkerGeneralServlet.UIStorageDir
UIUsageOnTier(String, long, long) - Constructor for class alluxio.web.WebInterfaceWorkerGeneralServlet.UIUsageOnTier
UIWorkerInfo(String, long) - Constructor for class alluxio.web.WebInterfaceWorkerGeneralServlet.UIWorkerInfo
UNAUTHENTICATED_VALUE - Static variable in enum alluxio.proto.status.Status.PStatus
UNAUTHENTICATED = 16;
UnauthenticatedException - Exception in alluxio.exception.status
Exception indicating that the request does not have valid authentication credentials for the operation.
UnauthenticatedException(String) - Constructor for exception alluxio.exception.status.UnauthenticatedException
 
UnauthenticatedException(Throwable) - Constructor for exception alluxio.exception.status.UnauthenticatedException
 
UnauthenticatedException(String, Throwable) - Constructor for exception alluxio.exception.status.UnauthenticatedException
 
UNAVAILABLE_VALUE - Static variable in enum alluxio.proto.status.Status.PStatus
UNAVAILABLE = 14;
UnavailableException - Exception in alluxio.exception.status
Exception indicating that the service is currently unavailable.
UnavailableException(String) - Constructor for exception alluxio.exception.status.UnavailableException
 
UnavailableException(Throwable) - Constructor for exception alluxio.exception.status.UnavailableException
 
UnavailableException(String, Throwable) - Constructor for exception alluxio.exception.status.UnavailableException
 
UnderFileSystem - Interface in alluxio.underfs
Alluxio stores data into an under layer file system.
UnderFileSystem.Factory - Class in alluxio.underfs
The factory for the UnderFileSystem.
UnderFileSystem.SpaceType - Enum in alluxio.underfs
The different types of space indicate the total space, the free space and the space used in the under file system.
UnderFileSystem.UfsMode - Enum in alluxio.underfs
Operation mode for under storage.
UnderFileSystemBlockMeta - Class in alluxio.worker.block.meta
This class represents the metadata of a block that is in UFS.
UnderFileSystemBlockMeta(long, long, Protocol.OpenUfsBlockOptions) - Constructor for class alluxio.worker.block.meta.UnderFileSystemBlockMeta
Creates an instance of UnderFileSystemBlockMeta.
UnderFileSystemBlockReader - Class in alluxio.worker.block
This class implements a BlockReader to read a block directly from UFS, and optionally cache the block to the Alluxio worker if the whole block it is read.
UnderFileSystemBlockStore - Class in alluxio.worker.block
This class manages the virtual blocks in the UFS for delegated UFS reads/writes.
UnderFileSystemBlockStore(BlockStore, UfsManager) - Constructor for class alluxio.worker.block.UnderFileSystemBlockStore
Creates an instance of UnderFileSystemBlockStore.
UnderFileSystemConfiguration - Class in alluxio.underfs
A class that gets the value of the given key in the given UFS configuration or the global configuration (in case the key is not found in the UFS configuration), throw RuntimeException if the key is not found in both configurations..
UnderFileSystemFactory - Interface in alluxio.underfs
Interface for under file system factories.
UnderFileSystemFactoryRegistry - Class in alluxio.underfs
Central registry of available UnderFileSystemFactory instances that uses the ServiceLoader mechanism to automatically discover available factories and provides a central place for obtaining actual UnderFileSystem instances.
UnderFileSystemFileOutStream - Class in alluxio.client.block.stream
Provides a streaming API to write to a file in the under file system through an Alluxio worker's data server.
UnderFileSystemFileOutStream(PacketWriter, WorkerNetAddress) - Constructor for class alluxio.client.block.stream.UnderFileSystemFileOutStream
Constructs a new UnderFileSystemFileOutStream with only one PacketWriter.
UnderFileSystemUtils - Class in alluxio.util
Utility functions for working with UnderFileSystem.
UnderFileSystemUtils - Class in alluxio.worker.file
Utility functions for working with UnderFileSystem.
UnderFileSystemWithLogging - Class in alluxio.underfs
This class forwards all calls to the UnderFileSystem interface to an internal implementation.
UnderFileSystemWithLogging.UfsCallable<T> - Interface in alluxio.underfs
Interface representing a callable to the under storage system which throws an IOException if an error occurs during the external communication.
UNDERFS_ADDRESS - Static variable in class alluxio.PropertyKey.Name
 
UNDERFS_ADDRESS - Static variable in class alluxio.PropertyKey
Deprecated.
since 1.5.0 and will be removed in 2.0. Use MASTER_MOUNT_TABLE_ROOT_UFS instead.
UNDERFS_ALLOW_SET_OWNER_FAILURE - Static variable in class alluxio.PropertyKey.Name
 
UNDERFS_ALLOW_SET_OWNER_FAILURE - Static variable in class alluxio.PropertyKey
 
UNDERFS_GCS_DIRECTORY_SUFFIX - Static variable in class alluxio.PropertyKey.Name
 
UNDERFS_GCS_DIRECTORY_SUFFIX - Static variable in class alluxio.PropertyKey
 
UNDERFS_GCS_OWNER_ID_TO_USERNAME_MAPPING - Static variable in class alluxio.PropertyKey.Name
 
UNDERFS_GCS_OWNER_ID_TO_USERNAME_MAPPING - Static variable in class alluxio.PropertyKey
 
UNDERFS_HDFS_CONFIGURATION - Static variable in class alluxio.PropertyKey.Name
 
UNDERFS_HDFS_CONFIGURATION - Static variable in class alluxio.PropertyKey
 
UNDERFS_HDFS_IMPL - Static variable in class alluxio.PropertyKey.Name
 
UNDERFS_HDFS_IMPL - Static variable in class alluxio.PropertyKey
 
UNDERFS_HDFS_PREFIXES - Static variable in class alluxio.PropertyKey.Name
 
UNDERFS_HDFS_PREFIXES - Static variable in class alluxio.PropertyKey
 
UNDERFS_HDFS_REMOTE - Static variable in class alluxio.PropertyKey.Name
 
UNDERFS_HDFS_REMOTE - Static variable in class alluxio.PropertyKey
 
UNDERFS_LISTING_LENGTH - Static variable in class alluxio.PropertyKey.Name
 
UNDERFS_LISTING_LENGTH - Static variable in class alluxio.PropertyKey
 
UNDERFS_OBJECT_STORE_MOUNT_SHARED_PUBLICLY - Static variable in class alluxio.PropertyKey.Name
 
UNDERFS_OBJECT_STORE_MOUNT_SHARED_PUBLICLY - Static variable in class alluxio.PropertyKey
 
UNDERFS_OBJECT_STORE_READ_RETRY_BASE_SLEEP_MS - Static variable in class alluxio.PropertyKey.Name
 
UNDERFS_OBJECT_STORE_READ_RETRY_BASE_SLEEP_MS - Static variable in class alluxio.PropertyKey
 
UNDERFS_OBJECT_STORE_READ_RETRY_MAX_NUM - Static variable in class alluxio.PropertyKey.Name
 
UNDERFS_OBJECT_STORE_READ_RETRY_MAX_NUM - Static variable in class alluxio.PropertyKey
 
UNDERFS_OBJECT_STORE_READ_RETRY_MAX_SLEEP_MS - Static variable in class alluxio.PropertyKey.Name
 
UNDERFS_OBJECT_STORE_READ_RETRY_MAX_SLEEP_MS - Static variable in class alluxio.PropertyKey
 
UNDERFS_OBJECT_STORE_SERVICE_THREADS - Static variable in class alluxio.PropertyKey.Name
 
UNDERFS_OBJECT_STORE_SERVICE_THREADS - Static variable in class alluxio.PropertyKey
 
UNDERFS_OSS_CONNECT_MAX - Static variable in class alluxio.PropertyKey.Name
 
UNDERFS_OSS_CONNECT_MAX - Static variable in class alluxio.PropertyKey
 
UNDERFS_OSS_CONNECT_TIMEOUT - Static variable in class alluxio.PropertyKey.Name
 
UNDERFS_OSS_CONNECT_TIMEOUT - Static variable in class alluxio.PropertyKey
 
UNDERFS_OSS_CONNECT_TTL - Static variable in class alluxio.PropertyKey.Name
 
UNDERFS_OSS_CONNECT_TTL - Static variable in class alluxio.PropertyKey
 
UNDERFS_OSS_SOCKET_TIMEOUT - Static variable in class alluxio.PropertyKey.Name
 
UNDERFS_OSS_SOCKET_TIMEOUT - Static variable in class alluxio.PropertyKey
 
UNDERFS_S3_ADMIN_THREADS_MAX - Static variable in class alluxio.PropertyKey.Name
 
UNDERFS_S3_ADMIN_THREADS_MAX - Static variable in class alluxio.PropertyKey
 
UNDERFS_S3_DISABLE_DNS_BUCKETS - Static variable in class alluxio.PropertyKey.Name
 
UNDERFS_S3_DISABLE_DNS_BUCKETS - Static variable in class alluxio.PropertyKey
 
UNDERFS_S3_ENDPOINT - Static variable in class alluxio.PropertyKey.Name
 
UNDERFS_S3_ENDPOINT - Static variable in class alluxio.PropertyKey
 
UNDERFS_S3_OWNER_ID_TO_USERNAME_MAPPING - Static variable in class alluxio.PropertyKey.Name
 
UNDERFS_S3_OWNER_ID_TO_USERNAME_MAPPING - Static variable in class alluxio.PropertyKey
 
UNDERFS_S3_PROXY_HOST - Static variable in class alluxio.PropertyKey.Name
 
UNDERFS_S3_PROXY_HOST - Static variable in class alluxio.PropertyKey
 
UNDERFS_S3_PROXY_PORT - Static variable in class alluxio.PropertyKey.Name
 
UNDERFS_S3_PROXY_PORT - Static variable in class alluxio.PropertyKey
 
UNDERFS_S3_THREADS_MAX - Static variable in class alluxio.PropertyKey.Name
 
UNDERFS_S3_THREADS_MAX - Static variable in class alluxio.PropertyKey
 
UNDERFS_S3_UPLOAD_THREADS_MAX - Static variable in class alluxio.PropertyKey.Name
 
UNDERFS_S3_UPLOAD_THREADS_MAX - Static variable in class alluxio.PropertyKey
 
UNDERFS_S3A_BULK_DELETE_ENABLED - Static variable in class alluxio.PropertyKey.Name
 
UNDERFS_S3A_BULK_DELETE_ENABLED - Static variable in class alluxio.PropertyKey
 
UNDERFS_S3A_CONSISTENCY_TIMEOUT_MS - Static variable in class alluxio.PropertyKey.Name
 
UNDERFS_S3A_CONSISTENCY_TIMEOUT_MS - Static variable in class alluxio.PropertyKey
 
UNDERFS_S3A_DEFAULT_MODE - Static variable in class alluxio.PropertyKey.Name
 
UNDERFS_S3A_DEFAULT_MODE - Static variable in class alluxio.PropertyKey
 
UNDERFS_S3A_DIRECTORY_SUFFIX - Static variable in class alluxio.PropertyKey.Name
 
UNDERFS_S3A_DIRECTORY_SUFFIX - Static variable in class alluxio.PropertyKey
 
UNDERFS_S3A_INHERIT_ACL - Static variable in class alluxio.PropertyKey.Name
 
UNDERFS_S3A_INHERIT_ACL - Static variable in class alluxio.PropertyKey
 
UNDERFS_S3A_LIST_OBJECTS_VERSION_1 - Static variable in class alluxio.PropertyKey.Name
 
UNDERFS_S3A_LIST_OBJECTS_VERSION_1 - Static variable in class alluxio.PropertyKey
 
UNDERFS_S3A_REQUEST_TIMEOUT - Static variable in class alluxio.PropertyKey
 
UNDERFS_S3A_REQUEST_TIMEOUT_MS - Static variable in class alluxio.PropertyKey.Name
 
UNDERFS_S3A_SECURE_HTTP_ENABLED - Static variable in class alluxio.PropertyKey.Name
 
UNDERFS_S3A_SECURE_HTTP_ENABLED - Static variable in class alluxio.PropertyKey
 
UNDERFS_S3A_SERVER_SIDE_ENCRYPTION_ENABLED - Static variable in class alluxio.PropertyKey.Name
 
UNDERFS_S3A_SERVER_SIDE_ENCRYPTION_ENABLED - Static variable in class alluxio.PropertyKey
 
UNDERFS_S3A_SIGNER_ALGORITHM - Static variable in class alluxio.PropertyKey.Name
 
UNDERFS_S3A_SIGNER_ALGORITHM - Static variable in class alluxio.PropertyKey
 
UNDERFS_S3A_SOCKET_TIMEOUT_MS - Static variable in class alluxio.PropertyKey.Name
 
UNDERFS_S3A_SOCKET_TIMEOUT_MS - Static variable in class alluxio.PropertyKey
 
UNDERSCORE - Static variable in class alluxio.underfs.Fingerprint
 
UnderStorageType - Enum in alluxio.client
Specifies the type of data interaction with Alluxio's Under Storage.
UnexpectedAlluxioException - Exception in alluxio.exception
The exception thrown when an unexpected error occurs within the Alluxio system.
UnexpectedAlluxioException(String) - Constructor for exception alluxio.exception.UnexpectedAlluxioException
Constructs a new exception with the specified detail message.
UnexpectedAlluxioException(Exception) - Constructor for exception alluxio.exception.UnexpectedAlluxioException
 
UNIMPLEMENTED_VALUE - Static variable in enum alluxio.proto.status.Status.PStatus
UNIMPLEMENTED = 12;
UnimplementedException - Exception in alluxio.exception.status
Exception indicating that an operation is not implemented or not supported/enabled in this service.
UnimplementedException(String) - Constructor for exception alluxio.exception.status.UnimplementedException
 
UnimplementedException(Throwable) - Constructor for exception alluxio.exception.status.UnimplementedException
 
UnimplementedException(String, Throwable) - Constructor for exception alluxio.exception.status.UnimplementedException
 
UninstallCommand - Class in alluxio.cli.extensions.command
Uninstall an extension.
UninstallCommand() - Constructor for class alluxio.cli.extensions.command.UninstallCommand
Constructs a new instance of UninstallCommand.
uniqPath() - Static method in class alluxio.util.io.PathUtils
Creates a unique path based off the caller.
UniqueFieldIndex<T> - Class in alluxio.collections
A class representing a unique index.
UniqueFieldIndex(IndexDefinition<T>) - Constructor for class alluxio.collections.UniqueFieldIndex
Constructs a new UniqueFieldIndex instance.
UnixMountInfo - Class in alluxio.util
Class representing an entry in a Unix /etc/fstab file.
UnixMountInfo.Builder - Class in alluxio.util
Builder for UnixMountInfo.
UnixMountInfo.Options - Class in alluxio.util
Unix mount info options.
UnixMountInfo.Options.Builder - Class in alluxio.util
Builder for Unix mount info options.
UNKNOWN - Static variable in class alluxio.conf.Source
 
UNKNOWN_SEQUENCE_NUMBER - Static variable in class alluxio.master.journal.ufs.UfsJournal
This is set to Long.MAX_VALUE such that the current log can be sorted after any other completed logs.
UNKNOWN_SERVICE_VERSION - Static variable in class alluxio.Constants
 
UNKNOWN_SIZE - Static variable in class alluxio.Constants
 
UNKNOWN_VALUE - Static variable in enum alluxio.proto.status.Status.PStatus
UNKNOWN = 2;
UnknownException - Exception in alluxio.exception.status
Exception representing an unknown error.
UnknownException(String) - Constructor for exception alluxio.exception.status.UnknownException
 
UnknownException(Throwable) - Constructor for exception alluxio.exception.status.UnknownException
 
UnknownException(String, Throwable) - Constructor for exception alluxio.exception.status.UnknownException
 
unlockBlock(long, long, UnlockBlockTOptions, AsyncMethodCallback) - Method in class alluxio.thrift.BlockWorkerClientService.AsyncClient
 
unlockBlock(long, long, UnlockBlockTOptions, AsyncMethodCallback) - Method in interface alluxio.thrift.BlockWorkerClientService.AsyncIface
 
unlockBlock() - Constructor for class alluxio.thrift.BlockWorkerClientService.AsyncProcessor.unlockBlock
 
unlockBlock(long, long, UnlockBlockTOptions) - Method in class alluxio.thrift.BlockWorkerClientService.Client
 
unlockBlock(long, long, UnlockBlockTOptions) - Method in interface alluxio.thrift.BlockWorkerClientService.Iface
Used to unlock a block after the block is accessed, if the block is to be removed, delete the block file.
unlockBlock() - Constructor for class alluxio.thrift.BlockWorkerClientService.Processor.unlockBlock
 
unlockBlock(long) - Method in class alluxio.worker.block.BlockLockManager
Releases the lock with the specified lock id.
unlockBlock(long, long) - Method in class alluxio.worker.block.BlockLockManager
Releases the lock with the specified session and block id.
unlockBlock(long) - Method in interface alluxio.worker.block.BlockStore
Releases an acquired block lock based on a lockId (returned by BlockStore.lockBlock(long, long).
unlockBlock(long, long) - Method in interface alluxio.worker.block.BlockStore
Releases an acquired block lock based on a session id and block id.
unlockBlock(long) - Method in interface alluxio.worker.block.BlockWorker
Releases the lock with the specified lock id.
unlockBlock(long, long) - Method in interface alluxio.worker.block.BlockWorker
Releases the lock with the specified session and block id.
unlockBlock(long, long, UnlockBlockTOptions) - Method in class alluxio.worker.block.BlockWorkerClientServiceHandler
 
unlockBlock(long) - Method in class alluxio.worker.block.DefaultBlockWorker
 
unlockBlock(long, long) - Method in class alluxio.worker.block.DefaultBlockWorker
 
unlockBlock(long) - Method in class alluxio.worker.block.TieredBlockStore
 
unlockBlock(long, long) - Method in class alluxio.worker.block.TieredBlockStore
 
unlockBlock_args() - Constructor for class alluxio.thrift.BlockWorkerClientService.unlockBlock_args
 
unlockBlock_args(long, long, UnlockBlockTOptions) - Constructor for class alluxio.thrift.BlockWorkerClientService.unlockBlock_args
 
unlockBlock_args(BlockWorkerClientService.unlockBlock_args) - Constructor for class alluxio.thrift.BlockWorkerClientService.unlockBlock_args
Performs a deep copy on other.
unlockBlock_call(long, long, UnlockBlockTOptions, AsyncMethodCallback, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class alluxio.thrift.BlockWorkerClientService.AsyncClient.unlockBlock_call
 
unlockBlock_result() - Constructor for class alluxio.thrift.BlockWorkerClientService.unlockBlock_result
 
unlockBlock_result(UnlockBlockTResponse, AlluxioTException) - Constructor for class alluxio.thrift.BlockWorkerClientService.unlockBlock_result
 
unlockBlock_result(BlockWorkerClientService.unlockBlock_result) - Constructor for class alluxio.thrift.BlockWorkerClientService.unlockBlock_result
Performs a deep copy on other.
unlockBlockNoException(long) - Method in class alluxio.worker.block.BlockLockManager
Releases the lock with the specified lock id.
UnlockBlockTOptions - Class in alluxio.thrift
 
UnlockBlockTOptions() - Constructor for class alluxio.thrift.UnlockBlockTOptions
 
UnlockBlockTOptions(UnlockBlockTOptions) - Constructor for class alluxio.thrift.UnlockBlockTOptions
Performs a deep copy on other.
UnlockBlockTOptions._Fields - Enum in alluxio.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
UnlockBlockTResponse - Class in alluxio.thrift
 
UnlockBlockTResponse() - Constructor for class alluxio.thrift.UnlockBlockTResponse
 
UnlockBlockTResponse(boolean) - Constructor for class alluxio.thrift.UnlockBlockTResponse
 
UnlockBlockTResponse(UnlockBlockTResponse) - Constructor for class alluxio.thrift.UnlockBlockTResponse
Performs a deep copy on other.
UnlockBlockTResponse._Fields - Enum in alluxio.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
unlockLast() - Method in class alluxio.master.file.meta.InodeLockList
Unlocks the last inode that was locked.
unlockLast() - Method in class alluxio.master.file.meta.LockedInodePath
Unlocks the last inode that was locked.
unlockRead() - Method in class alluxio.master.file.meta.Inode
Releases the read lock for this inode.
unlockWrite() - Method in class alluxio.master.file.meta.Inode
Releases the write lock for this inode.
unmount(AlluxioURI) - Method in class alluxio.client.file.BaseFileSystem
 
unmount(AlluxioURI, UnmountOptions) - Method in class alluxio.client.file.BaseFileSystem
 
unmount(AlluxioURI) - Method in interface alluxio.client.file.FileSystem
Convenience method for FileSystem.unmount(AlluxioURI, UnmountOptions) with default options.
unmount(AlluxioURI, UnmountOptions) - Method in interface alluxio.client.file.FileSystem
Unmounts a UFS subtree identified by the given Alluxio path.
unmount(AlluxioURI) - Method in interface alluxio.client.file.FileSystemMasterClient
Unmounts the given Alluxio path.
unmount(AlluxioURI) - Method in class alluxio.client.file.RetryHandlingFileSystemMasterClient
 
unmount(AlluxioURI) - Method in class alluxio.master.file.DefaultFileSystemMaster
 
unmount(AlluxioURI) - Method in interface alluxio.master.file.FileSystemMaster
Unmounts a UFS path previously mounted onto an Alluxio path.
UNMOUNT - Static variable in class alluxio.master.file.FileSystemMasterClientRestServiceHandler
Deprecated.
 
unmount(String) - Method in class alluxio.master.file.FileSystemMasterClientRestServiceHandler
Deprecated.
 
unmount(String, UnmountTOptions) - Method in class alluxio.master.file.FileSystemMasterClientServiceHandler
 
UNMOUNT - Static variable in class alluxio.proxy.PathsRestServiceHandler
 
unmount(String, UnmountOptions) - Method in class alluxio.proxy.PathsRestServiceHandler
 
unmount(String, UnmountTOptions, AsyncMethodCallback) - Method in class alluxio.thrift.FileSystemMasterClientService.AsyncClient
 
unmount(String, UnmountTOptions, AsyncMethodCallback) - Method in interface alluxio.thrift.FileSystemMasterClientService.AsyncIface
 
unmount() - Constructor for class alluxio.thrift.FileSystemMasterClientService.AsyncProcessor.unmount
 
unmount(String, UnmountTOptions) - Method in class alluxio.thrift.FileSystemMasterClientService.Client
 
unmount(String, UnmountTOptions) - Method in interface alluxio.thrift.FileSystemMasterClientService.Iface
Deletes an existing "mount point", voiding the Alluxio namespace at the given path.
unmount() - Constructor for class alluxio.thrift.FileSystemMasterClientService.Processor.unmount
 
unmount_args() - Constructor for class alluxio.thrift.FileSystemMasterClientService.unmount_args
 
unmount_args(String, UnmountTOptions) - Constructor for class alluxio.thrift.FileSystemMasterClientService.unmount_args
 
unmount_args(FileSystemMasterClientService.unmount_args) - Constructor for class alluxio.thrift.FileSystemMasterClientService.unmount_args
Performs a deep copy on other.
unmount_call(String, UnmountTOptions, AsyncMethodCallback, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class alluxio.thrift.FileSystemMasterClientService.AsyncClient.unmount_call
 
UNMOUNT_OPS - Static variable in class alluxio.metrics.MasterMetrics
 
unmount_result() - Constructor for class alluxio.thrift.FileSystemMasterClientService.unmount_result
 
unmount_result(UnmountTResponse, AlluxioTException) - Constructor for class alluxio.thrift.FileSystemMasterClientService.unmount_result
 
unmount_result(FileSystemMasterClientService.unmount_result) - Constructor for class alluxio.thrift.FileSystemMasterClientService.unmount_result
Performs a deep copy on other.
UnmountCommand - Class in alluxio.cli.fs.command
Unmounts an Alluxio path.
UnmountCommand(FileSystem) - Constructor for class alluxio.cli.fs.command.UnmountCommand
 
UnmountOptions - Class in alluxio.client.file.options
Method options for unmounting a path.
UnmountTOptions - Class in alluxio.thrift
 
UnmountTOptions() - Constructor for class alluxio.thrift.UnmountTOptions
 
UnmountTOptions(UnmountTOptions) - Constructor for class alluxio.thrift.UnmountTOptions
Performs a deep copy on other.
UnmountTOptions._Fields - Enum in alluxio.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
UnmountTResponse - Class in alluxio.thrift
 
UnmountTResponse() - Constructor for class alluxio.thrift.UnmountTResponse
 
UnmountTResponse(UnmountTResponse) - Constructor for class alluxio.thrift.UnmountTResponse
Performs a deep copy on other.
UnmountTResponse._Fields - Enum in alluxio.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
UnpinCommand - Class in alluxio.cli.fs.command
Unpins the given file or folder (recursively unpinning all children if a folder).
UnpinCommand(FileSystem) - Constructor for class alluxio.cli.fs.command.UnpinCommand
 
unregister(T) - Method in class alluxio.extensions.ExtensionFactoryRegistry
Unregisters an existing factory.
unregister(PropertyKey) - Static method in class alluxio.PropertyKey
Unregisters the given key from the global key map.
unregister(UnderFileSystemFactory) - Static method in class alluxio.underfs.UnderFileSystemFactoryRegistry
Unregisters an existing factory.
unset(PropertyKey) - Static method in class alluxio.Configuration
Unsets the value for the appropriate key in the Properties.
unsetAddedBlocksOnTiers() - Method in class alluxio.thrift.BlockMasterWorkerService.blockHeartbeat_args
 
unsetAddress() - Method in class alluxio.thrift.WorkerInfo
 
unsetAddresses() - Method in class alluxio.thrift.GetWorkerReportTOptions
 
unsetAllowExists() - Method in class alluxio.thrift.CreateDirectoryTOptions
 
unsetAlluxioOnly() - Method in class alluxio.thrift.DeleteTOptions
 
unsetAlluxioPath() - Method in class alluxio.thrift.FileSystemMasterClientService.mount_args
 
unsetAlluxioPath() - Method in class alluxio.thrift.FileSystemMasterClientService.unmount_args
 
unsetBackupUri() - Method in class alluxio.thrift.BackupTResponse
 
unsetBlockId() - Method in class alluxio.thrift.BlockInfo
 
unsetBlockId() - Method in class alluxio.thrift.BlockMasterClientService.getBlockInfo_args
 
unsetBlockId() - Method in class alluxio.thrift.BlockMasterWorkerService.commitBlock_args
 
unsetBlockId() - Method in class alluxio.thrift.BlockWorkerClientService.accessBlock_args
 
unsetBlockId() - Method in class alluxio.thrift.BlockWorkerClientService.cacheBlock_args
 
unsetBlockId() - Method in class alluxio.thrift.BlockWorkerClientService.cancelBlock_args
 
unsetBlockId() - Method in class alluxio.thrift.BlockWorkerClientService.lockBlock_args
 
unsetBlockId() - Method in class alluxio.thrift.BlockWorkerClientService.promoteBlock_args
 
unsetBlockId() - Method in class alluxio.thrift.BlockWorkerClientService.removeBlock_args
 
unsetBlockId() - Method in class alluxio.thrift.BlockWorkerClientService.requestBlockLocation_args
 
unsetBlockId() - Method in class alluxio.thrift.BlockWorkerClientService.requestSpace_args
 
unsetBlockId() - Method in class alluxio.thrift.BlockWorkerClientService.unlockBlock_args
 
unsetBlockId() - Method in class alluxio.thrift.KeyValueWorkerClientService.get_args
 
unsetBlockId() - Method in class alluxio.thrift.KeyValueWorkerClientService.getNextKeys_args
 
unsetBlockId() - Method in class alluxio.thrift.KeyValueWorkerClientService.getSize_args
 
unsetBlockId() - Method in class alluxio.thrift.PartitionInfo
 
unsetBlockIds() - Method in class alluxio.thrift.FileInfo
 
unsetBlockIds() - Method in class alluxio.thrift.PersistFile
 
unsetBlockInfo() - Method in class alluxio.thrift.FileBlockInfo
 
unsetBlockInfo() - Method in class alluxio.thrift.GetBlockInfoTResponse
 
unsetBlockMasterInfo() - Method in class alluxio.thrift.GetBlockMasterInfoTResponse
 
unsetBlockPath() - Method in class alluxio.thrift.LockBlockTResponse
 
unsetBlockSize() - Method in class alluxio.thrift.LockBlockTOptions
 
unsetBlockSizeBytes() - Method in class alluxio.thrift.CreateFileTOptions
 
unsetBlockSizeBytes() - Method in class alluxio.thrift.FileInfo
 
unsetBlockSizeBytes() - Method in class alluxio.thrift.LineageMasterClientService.reinitializeFile_args
 
unsetBytes() - Method in class alluxio.thrift.GetCapacityBytesTResponse
 
unsetBytes() - Method in class alluxio.thrift.GetUsedBytesTResponse
 
unsetCacheable() - Method in class alluxio.thrift.FileInfo
 
unsetCapacityBytes() - Method in class alluxio.thrift.BlockMasterInfo
 
unsetCapacityBytes() - Method in class alluxio.thrift.WorkerInfo
 
unsetCapacityBytesOnTiers() - Method in class alluxio.thrift.BlockMasterInfo
 
unsetCapacityBytesOnTiers() - Method in class alluxio.thrift.WorkerInfo
 
unsetCascade() - Method in class alluxio.thrift.LineageMasterClientService.deleteLineage_args
 
unsetChildren() - Method in class alluxio.thrift.LineageInfo
 
unsetClientId() - Method in class alluxio.thrift.MetricsMasterClientService.metricsHeartbeat_args
 
unsetCommand() - Method in class alluxio.thrift.BlockHeartbeatTResponse
 
unsetCommand() - Method in class alluxio.thrift.CommandLineJobInfo
 
unsetCommand() - Method in class alluxio.thrift.FileSystemHeartbeatTResponse
 
unsetCommand() - Method in class alluxio.thrift.MasterHeartbeatTResponse
 
unsetCommandOptions() - Method in class alluxio.thrift.FileSystemCommand
 
unsetCommandType() - Method in class alluxio.thrift.Command
 
unsetCommandType() - Method in class alluxio.thrift.FileSystemCommand
 
unsetCommonOptions() - Method in class alluxio.thrift.CheckConsistencyTOptions
 
unsetCommonOptions() - Method in class alluxio.thrift.CompleteFileTOptions
 
unsetCommonOptions() - Method in class alluxio.thrift.CreateDirectoryTOptions
 
unsetCommonOptions() - Method in class alluxio.thrift.CreateFileTOptions
 
unsetCommonOptions() - Method in class alluxio.thrift.DeleteTOptions
 
unsetCommonOptions() - Method in class alluxio.thrift.FreeTOptions
 
unsetCommonOptions() - Method in class alluxio.thrift.GetNewBlockIdForFileTOptions
 
unsetCommonOptions() - Method in class alluxio.thrift.GetStatusTOptions
 
unsetCommonOptions() - Method in class alluxio.thrift.ListStatusTOptions
 
unsetCommonOptions() - Method in class alluxio.thrift.LoadMetadataTOptions
 
unsetCommonOptions() - Method in class alluxio.thrift.MountTOptions
 
unsetCommonOptions() - Method in class alluxio.thrift.RenameTOptions
 
unsetCommonOptions() - Method in class alluxio.thrift.ScheduleAsyncPersistenceTOptions
 
unsetCommonOptions() - Method in class alluxio.thrift.SetAttributeTOptions
 
unsetCommonOptions() - Method in class alluxio.thrift.SyncMetadataTOptions
 
unsetCommonOptions() - Method in class alluxio.thrift.UnmountTOptions
 
unsetCompleted() - Method in class alluxio.thrift.FileInfo
 
unsetConf() - Method in class alluxio.thrift.CommandLineJobInfo
 
unsetConfigList() - Method in class alluxio.thrift.GetConfigurationTResponse
 
unsetConfigList() - Method in class alluxio.thrift.RegisterMasterTOptions
 
unsetConfigList() - Method in class alluxio.thrift.RegisterWorkerTOptions
 
unsetCreationTimeMs() - Method in class alluxio.thrift.FileInfo
 
unsetCreationTimeMs() - Method in class alluxio.thrift.LineageInfo
 
unsetCurrentBlocksOnTiers() - Method in class alluxio.thrift.BlockMasterWorkerService.registerWorker_args
 
unsetData() - Method in class alluxio.thrift.Command
 
unsetData() - Method in class alluxio.thrift.GetTResponse
 
unsetDataPort() - Method in class alluxio.thrift.WorkerNetAddress
 
unsetDomainSocketPath() - Method in class alluxio.thrift.WorkerNetAddress
 
unsetDoubleValue() - Method in class alluxio.thrift.MetricValue
 
unsetDstPath() - Method in class alluxio.thrift.FileSystemMasterClientService.rename_args
 
unsetE() - Method in class alluxio.thrift.AlluxioService.getServiceVersion_result
 
unsetE() - Method in class alluxio.thrift.BlockMasterClientService.getBlockInfo_result
 
unsetE() - Method in class alluxio.thrift.BlockMasterClientService.getBlockMasterInfo_result
 
unsetE() - Method in class alluxio.thrift.BlockMasterClientService.getCapacityBytes_result
 
unsetE() - Method in class alluxio.thrift.BlockMasterClientService.getUsedBytes_result
 
unsetE() - Method in class alluxio.thrift.BlockMasterClientService.getWorkerInfoList_result
 
unsetE() - Method in class alluxio.thrift.BlockMasterClientService.getWorkerReport_result
 
unsetE() - Method in class alluxio.thrift.BlockMasterWorkerService.blockHeartbeat_result
 
unsetE() - Method in class alluxio.thrift.BlockMasterWorkerService.commitBlock_result
 
unsetE() - Method in class alluxio.thrift.BlockMasterWorkerService.getWorkerId_result
 
unsetE() - Method in class alluxio.thrift.BlockMasterWorkerService.registerWorker_result
 
unsetE() - Method in class alluxio.thrift.BlockWorkerClientService.accessBlock_result
 
unsetE() - Method in class alluxio.thrift.BlockWorkerClientService.cacheBlock_result
 
unsetE() - Method in class alluxio.thrift.BlockWorkerClientService.cancelBlock_result
 
unsetE() - Method in class alluxio.thrift.BlockWorkerClientService.lockBlock_result
 
unsetE() - Method in class alluxio.thrift.BlockWorkerClientService.promoteBlock_result
 
unsetE() - Method in class alluxio.thrift.BlockWorkerClientService.removeBlock_result
 
unsetE() - Method in class alluxio.thrift.BlockWorkerClientService.requestBlockLocation_result
 
unsetE() - Method in class alluxio.thrift.BlockWorkerClientService.requestSpace_result
 
unsetE() - Method in class alluxio.thrift.BlockWorkerClientService.sessionBlockHeartbeat_result
 
unsetE() - Method in class alluxio.thrift.BlockWorkerClientService.unlockBlock_result
 
unsetE() - Method in class alluxio.thrift.FileSystemMasterClientService.checkConsistency_result
 
unsetE() - Method in class alluxio.thrift.FileSystemMasterClientService.completeFile_result
 
unsetE() - Method in class alluxio.thrift.FileSystemMasterClientService.createDirectory_result
 
unsetE() - Method in class alluxio.thrift.FileSystemMasterClientService.createFile_result
 
unsetE() - Method in class alluxio.thrift.FileSystemMasterClientService.free_result
 
unsetE() - Method in class alluxio.thrift.FileSystemMasterClientService.getFilePath_result
 
unsetE() - Method in class alluxio.thrift.FileSystemMasterClientService.getMountTable_result
 
unsetE() - Method in class alluxio.thrift.FileSystemMasterClientService.getNewBlockIdForFile_result
 
unsetE() - Method in class alluxio.thrift.FileSystemMasterClientService.getStatus_result
 
unsetE() - Method in class alluxio.thrift.FileSystemMasterClientService.listStatus_result
 
unsetE() - Method in class alluxio.thrift.FileSystemMasterClientService.loadMetadata_result
 
unsetE() - Method in class alluxio.thrift.FileSystemMasterClientService.mount_result
 
unsetE() - Method in class alluxio.thrift.FileSystemMasterClientService.remove_result
 
unsetE() - Method in class alluxio.thrift.FileSystemMasterClientService.rename_result
 
unsetE() - Method in class alluxio.thrift.FileSystemMasterClientService.scheduleAsyncPersistence_result
 
unsetE() - Method in class alluxio.thrift.FileSystemMasterClientService.setAttribute_result
 
unsetE() - Method in class alluxio.thrift.FileSystemMasterClientService.unmount_result
 
unsetE() - Method in class alluxio.thrift.FileSystemMasterClientService.updateUfsMode_result
 
unsetE() - Method in class alluxio.thrift.FileSystemMasterWorkerService.fileSystemHeartbeat_result
 
unsetE() - Method in class alluxio.thrift.FileSystemMasterWorkerService.getFileInfo_result
 
unsetE() - Method in class alluxio.thrift.FileSystemMasterWorkerService.getPinnedFileIds_result
 
unsetE() - Method in class alluxio.thrift.FileSystemMasterWorkerService.getUfsInfo_result
 
unsetE() - Method in class alluxio.thrift.FileSystemWorkerClientService.cancelUfsFile_result
 
unsetE() - Method in class alluxio.thrift.FileSystemWorkerClientService.closeUfsFile_result
 
unsetE() - Method in class alluxio.thrift.FileSystemWorkerClientService.completeUfsFile_result
 
unsetE() - Method in class alluxio.thrift.FileSystemWorkerClientService.createUfsFile_result
 
unsetE() - Method in class alluxio.thrift.FileSystemWorkerClientService.openUfsFile_result
 
unsetE() - Method in class alluxio.thrift.FileSystemWorkerClientService.sessionFileSystemHeartbeat_result
 
unsetE() - Method in class alluxio.thrift.KeyValueMasterClientService.completePartition_result
 
unsetE() - Method in class alluxio.thrift.KeyValueMasterClientService.completeStore_result
 
unsetE() - Method in class alluxio.thrift.KeyValueMasterClientService.createStore_result
 
unsetE() - Method in class alluxio.thrift.KeyValueMasterClientService.deleteStore_result
 
unsetE() - Method in class alluxio.thrift.KeyValueMasterClientService.getPartitionInfo_result
 
unsetE() - Method in class alluxio.thrift.KeyValueMasterClientService.mergeStore_result
 
unsetE() - Method in class alluxio.thrift.KeyValueMasterClientService.renameStore_result
 
unsetE() - Method in class alluxio.thrift.KeyValueWorkerClientService.get_result
 
unsetE() - Method in class alluxio.thrift.KeyValueWorkerClientService.getNextKeys_result
 
unsetE() - Method in class alluxio.thrift.KeyValueWorkerClientService.getSize_result
 
unsetE() - Method in class alluxio.thrift.LineageMasterClientService.createLineage_result
 
unsetE() - Method in class alluxio.thrift.LineageMasterClientService.deleteLineage_result
 
unsetE() - Method in class alluxio.thrift.LineageMasterClientService.getLineageInfoList_result
 
unsetE() - Method in class alluxio.thrift.LineageMasterClientService.reinitializeFile_result
 
unsetE() - Method in class alluxio.thrift.LineageMasterClientService.reportLostFile_result
 
unsetE() - Method in class alluxio.thrift.MetaMasterClientService.backup_result
 
unsetE() - Method in class alluxio.thrift.MetaMasterClientService.getConfigReport_result
 
unsetE() - Method in class alluxio.thrift.MetaMasterClientService.getConfiguration_result
 
unsetE() - Method in class alluxio.thrift.MetaMasterClientService.getMasterInfo_result
 
unsetE() - Method in class alluxio.thrift.MetaMasterClientService.getMetrics_result
 
unsetE() - Method in class alluxio.thrift.MetaMasterMasterService.getMasterId_result
 
unsetE() - Method in class alluxio.thrift.MetaMasterMasterService.masterHeartbeat_result
 
unsetE() - Method in class alluxio.thrift.MetaMasterMasterService.registerMaster_result
 
unsetE() - Method in class alluxio.thrift.MetricsMasterClientService.metricsHeartbeat_result
 
unsetEntryCount() - Method in class alluxio.thrift.BackupTResponse
 
unsetErrors() - Method in class alluxio.thrift.ConfigCheckReport
 
unsetFieldRange() - Method in class alluxio.thrift.GetWorkerReportTOptions
 
unsetFileBlockInfos() - Method in class alluxio.thrift.FileInfo
 
unsetFileId() - Method in class alluxio.thrift.FileInfo
 
unsetFileId() - Method in class alluxio.thrift.FileSystemMasterWorkerService.getFileInfo_args
 
unsetFileId() - Method in class alluxio.thrift.GetFilePathTOptions
 
unsetFileId() - Method in class alluxio.thrift.PersistFile
 
unsetFileInfo() - Method in class alluxio.thrift.GetFileInfoTResponse
 
unsetFileInfo() - Method in class alluxio.thrift.GetStatusTResponse
 
unsetFileInfoList() - Method in class alluxio.thrift.ListStatusTResponse
 
unsetFilter() - Method in class alluxio.thrift.GetBlockMasterInfoTOptions
 
unsetFilter() - Method in class alluxio.thrift.GetMasterInfoTOptions
 
unsetFolder() - Method in class alluxio.thrift.FileInfo
 
unsetForced() - Method in class alluxio.thrift.FreeTOptions
 
unsetFreeBytes() - Method in class alluxio.thrift.BlockMasterInfo
 
unsetFromPath() - Method in class alluxio.thrift.KeyValueMasterClientService.mergeStore_args
 
unsetGroup() - Method in class alluxio.thrift.CompleteUfsFileTOptions
 
unsetGroup() - Method in class alluxio.thrift.CreateUfsFileTOptions
 
unsetGroup() - Method in class alluxio.thrift.FileInfo
 
unsetGroup() - Method in class alluxio.thrift.SetAttributeTOptions
 
unsetHost() - Method in class alluxio.thrift.MasterNetAddress
 
unsetHost() - Method in class alluxio.thrift.WorkerNetAddress
 
unsetHostname() - Method in class alluxio.thrift.BackupTResponse
 
unsetHostname() - Method in class alluxio.thrift.Metric
 
unsetHostname() - Method in class alluxio.thrift.MetricsMasterClientService.metricsHeartbeat_args
 
unsetId() - Method in class alluxio.thrift.CompleteUfsFileTReponse
 
unsetId() - Method in class alluxio.thrift.CreateLineageTResponse
 
unsetId() - Method in class alluxio.thrift.CreateUfsFileTResponse
 
unsetId() - Method in class alluxio.thrift.GetNewBlockIdForFileTResponse
 
unsetId() - Method in class alluxio.thrift.LineageInfo
 
unsetId() - Method in class alluxio.thrift.LoadMetadataTResponse
 
unsetId() - Method in class alluxio.thrift.OpenUfsFileTResponse
 
unsetId() - Method in class alluxio.thrift.ReinitializeFileTResponse
 
unsetId() - Method in class alluxio.thrift.WorkerInfo
 
unsetInAlluxioPercentage() - Method in class alluxio.thrift.FileInfo
 
unsetInconsistentPaths() - Method in class alluxio.thrift.CheckConsistencyTResponse
 
unsetInfo() - Method in class alluxio.thrift.KeyValueMasterClientService.completePartition_args
 
unsetInitialBytes() - Method in class alluxio.thrift.BlockWorkerClientService.requestBlockLocation_args
 
unsetInMemoryPercentage() - Method in class alluxio.thrift.FileInfo
 
unsetInputFiles() - Method in class alluxio.thrift.LineageInfo
 
unsetInputFiles() - Method in class alluxio.thrift.LineageMasterClientService.createLineage_args
 
unsetInstance() - Method in class alluxio.thrift.Metric
 
unsetInstanceId() - Method in class alluxio.thrift.Metric
 
unsetJob() - Method in class alluxio.thrift.LineageInfo
 
unsetJob() - Method in class alluxio.thrift.LineageMasterClientService.createLineage_args
 
unsetKey() - Method in class alluxio.thrift.KeyValueWorkerClientService.get_args
 
unsetKey() - Method in class alluxio.thrift.KeyValueWorkerClientService.getNextKeys_args
 
unsetKeyCount() - Method in class alluxio.thrift.PartitionInfo
 
unsetKeyLimit() - Method in class alluxio.thrift.PartitionInfo
 
unsetKeys() - Method in class alluxio.thrift.GetNextKeysTResponse
 
unsetKeyStart() - Method in class alluxio.thrift.PartitionInfo
 
unsetLastContactSec() - Method in class alluxio.thrift.WorkerInfo
 
unsetLastModificationTimeMs() - Method in class alluxio.thrift.FileInfo
 
unsetLeaderMasterAddress() - Method in class alluxio.thrift.MasterInfo
 
unsetLength() - Method in class alluxio.thrift.BlockInfo
 
unsetLength() - Method in class alluxio.thrift.BlockMasterWorkerService.commitBlock_args
 
unsetLength() - Method in class alluxio.thrift.FileInfo
 
unsetLineageId() - Method in class alluxio.thrift.LineageMasterClientService.deleteLineage_args
 
unsetLineageInfoList() - Method in class alluxio.thrift.GetLineageInfoListTResponse
 
unsetLiveWorkerNum() - Method in class alluxio.thrift.BlockMasterInfo
 
unsetLoadDirectChildren() - Method in class alluxio.thrift.ListStatusTOptions
 
unsetLoadMetadataType() - Method in class alluxio.thrift.GetStatusTOptions
 
unsetLoadMetadataType() - Method in class alluxio.thrift.ListStatusTOptions
 
unsetLocalFileSystem() - Method in class alluxio.thrift.BackupTOptions
 
unsetLocation() - Method in class alluxio.thrift.RequestBlockLocationTResponse
 
unsetLocations() - Method in class alluxio.thrift.BlockInfo
 
unsetLockBlockStatus() - Method in class alluxio.thrift.LockBlockTResponse
 
unsetLockId() - Method in class alluxio.thrift.LockBlockTResponse
 
unsetLongValue() - Method in class alluxio.thrift.MetricValue
 
unsetLostWorkerNum() - Method in class alluxio.thrift.BlockMasterInfo
 
unsetMasterAddress() - Method in class alluxio.thrift.MetaMasterMasterService.getMasterId_args
 
unsetMasterAddresses() - Method in class alluxio.thrift.MasterInfo
 
unsetMasterId() - Method in class alluxio.thrift.GetMasterIdTResponse
 
unsetMasterId() - Method in class alluxio.thrift.MetaMasterMasterService.masterHeartbeat_args
 
unsetMasterId() - Method in class alluxio.thrift.MetaMasterMasterService.registerMaster_args
 
unsetMasterInfo() - Method in class alluxio.thrift.GetMasterInfoTResponse
 
unsetMaxUfsReadConcurrency() - Method in class alluxio.thrift.LockBlockTOptions
 
unsetMessage() - Method in exception alluxio.thrift.AlluxioTException
 
unsetMetrics() - Method in class alluxio.thrift.BlockHeartbeatTOptions
 
unsetMetrics() - Method in class alluxio.thrift.BlockWorkerClientService.sessionBlockHeartbeat_args
 
unsetMetrics() - Method in class alluxio.thrift.FileSystemWorkerClientService.sessionFileSystemHeartbeat_args
 
unsetMetrics() - Method in class alluxio.thrift.MetricsHeartbeatTOptions
 
unsetMetricsMap() - Method in class alluxio.thrift.GetMetricsTResponse
 
unsetMode() - Method in class alluxio.thrift.CompleteUfsFileTOptions
 
unsetMode() - Method in class alluxio.thrift.CreateDirectoryTOptions
 
unsetMode() - Method in class alluxio.thrift.CreateFileTOptions
 
unsetMode() - Method in class alluxio.thrift.CreateUfsFileTOptions
 
unsetMode() - Method in class alluxio.thrift.FileInfo
 
unsetMode() - Method in class alluxio.thrift.SetAttributeTOptions
 
unsetMountId() - Method in class alluxio.thrift.FileInfo
 
unsetMountId() - Method in class alluxio.thrift.FileSystemMasterWorkerService.getUfsInfo_args
 
unsetMountId() - Method in class alluxio.thrift.LockBlockTOptions
 
unsetMountPoint() - Method in class alluxio.thrift.FileInfo
 
unsetMountTable() - Method in class alluxio.thrift.GetMountTableTResponse
 
unsetName() - Method in class alluxio.thrift.ConfigProperty
 
unsetName() - Method in class alluxio.thrift.FileInfo
 
unsetName() - Method in class alluxio.thrift.InconsistentProperty
 
unsetName() - Method in class alluxio.thrift.Metric
 
unsetNewPath() - Method in class alluxio.thrift.KeyValueMasterClientService.renameStore_args
 
unsetNumKeys() - Method in class alluxio.thrift.KeyValueWorkerClientService.getNextKeys_args
 
unsetOffset() - Method in class alluxio.thrift.FileBlockInfo
 
unsetOffset() - Method in class alluxio.thrift.LockBlockTOptions
 
unsetOldPath() - Method in class alluxio.thrift.KeyValueMasterClientService.renameStore_args
 
unsetOptions() - Method in class alluxio.thrift.AlluxioService.getServiceVersion_args
 
unsetOptions() - Method in class alluxio.thrift.BlockMasterClientService.getBlockInfo_args
 
unsetOptions() - Method in class alluxio.thrift.BlockMasterClientService.getBlockMasterInfo_args
 
unsetOptions() - Method in class alluxio.thrift.BlockMasterClientService.getCapacityBytes_args
 
unsetOptions() - Method in class alluxio.thrift.BlockMasterClientService.getUsedBytes_args
 
unsetOptions() - Method in class alluxio.thrift.BlockMasterClientService.getWorkerInfoList_args
 
unsetOptions() - Method in class alluxio.thrift.BlockMasterClientService.getWorkerReport_args
 
unsetOptions() - Method in class alluxio.thrift.BlockMasterWorkerService.blockHeartbeat_args
 
unsetOptions() - Method in class alluxio.thrift.BlockMasterWorkerService.commitBlock_args
 
unsetOptions() - Method in class alluxio.thrift.BlockMasterWorkerService.getWorkerId_args
 
unsetOptions() - Method in class alluxio.thrift.BlockMasterWorkerService.registerWorker_args
 
unsetOptions() - Method in class alluxio.thrift.BlockWorkerClientService.accessBlock_args
 
unsetOptions() - Method in class alluxio.thrift.BlockWorkerClientService.cacheBlock_args
 
unsetOptions() - Method in class alluxio.thrift.BlockWorkerClientService.cancelBlock_args
 
unsetOptions() - Method in class alluxio.thrift.BlockWorkerClientService.lockBlock_args
 
unsetOptions() - Method in class alluxio.thrift.BlockWorkerClientService.promoteBlock_args
 
unsetOptions() - Method in class alluxio.thrift.BlockWorkerClientService.removeBlock_args
 
unsetOptions() - Method in class alluxio.thrift.BlockWorkerClientService.requestBlockLocation_args
 
unsetOptions() - Method in class alluxio.thrift.BlockWorkerClientService.requestSpace_args
 
unsetOptions() - Method in class alluxio.thrift.BlockWorkerClientService.sessionBlockHeartbeat_args
 
unsetOptions() - Method in class alluxio.thrift.BlockWorkerClientService.unlockBlock_args
 
unsetOptions() - Method in class alluxio.thrift.FileSystemMasterClientService.checkConsistency_args
 
unsetOptions() - Method in class alluxio.thrift.FileSystemMasterClientService.completeFile_args
 
unsetOptions() - Method in class alluxio.thrift.FileSystemMasterClientService.createDirectory_args
 
unsetOptions() - Method in class alluxio.thrift.FileSystemMasterClientService.createFile_args
 
unsetOptions() - Method in class alluxio.thrift.FileSystemMasterClientService.free_args
 
unsetOptions() - Method in class alluxio.thrift.FileSystemMasterClientService.getFilePath_args
 
unsetOptions() - Method in class alluxio.thrift.FileSystemMasterClientService.getNewBlockIdForFile_args
 
unsetOptions() - Method in class alluxio.thrift.FileSystemMasterClientService.getStatus_args
 
unsetOptions() - Method in class alluxio.thrift.FileSystemMasterClientService.listStatus_args
 
unsetOptions() - Method in class alluxio.thrift.FileSystemMasterClientService.loadMetadata_args
 
unsetOptions() - Method in class alluxio.thrift.FileSystemMasterClientService.mount_args
 
unsetOptions() - Method in class alluxio.thrift.FileSystemMasterClientService.remove_args
 
unsetOptions() - Method in class alluxio.thrift.FileSystemMasterClientService.rename_args
 
unsetOptions() - Method in class alluxio.thrift.FileSystemMasterClientService.scheduleAsyncPersistence_args
 
unsetOptions() - Method in class alluxio.thrift.FileSystemMasterClientService.setAttribute_args
 
unsetOptions() - Method in class alluxio.thrift.FileSystemMasterClientService.unmount_args
 
unsetOptions() - Method in class alluxio.thrift.FileSystemMasterClientService.updateUfsMode_args
 
unsetOptions() - Method in class alluxio.thrift.FileSystemMasterWorkerService.fileSystemHeartbeat_args
 
unsetOptions() - Method in class alluxio.thrift.FileSystemMasterWorkerService.getFileInfo_args
 
unsetOptions() - Method in class alluxio.thrift.FileSystemMasterWorkerService.getPinnedFileIds_args
 
unsetOptions() - Method in class alluxio.thrift.FileSystemMasterWorkerService.getUfsInfo_args
 
unsetOptions() - Method in class alluxio.thrift.FileSystemWorkerClientService.cancelUfsFile_args
 
unsetOptions() - Method in class alluxio.thrift.FileSystemWorkerClientService.closeUfsFile_args
 
unsetOptions() - Method in class alluxio.thrift.FileSystemWorkerClientService.completeUfsFile_args
 
unsetOptions() - Method in class alluxio.thrift.FileSystemWorkerClientService.createUfsFile_args
 
unsetOptions() - Method in class alluxio.thrift.FileSystemWorkerClientService.openUfsFile_args
 
unsetOptions() - Method in class alluxio.thrift.FileSystemWorkerClientService.sessionFileSystemHeartbeat_args
 
unsetOptions() - Method in class alluxio.thrift.KeyValueMasterClientService.completePartition_args
 
unsetOptions() - Method in class alluxio.thrift.KeyValueMasterClientService.completeStore_args
 
unsetOptions() - Method in class alluxio.thrift.KeyValueMasterClientService.createStore_args
 
unsetOptions() - Method in class alluxio.thrift.KeyValueMasterClientService.deleteStore_args
 
unsetOptions() - Method in class alluxio.thrift.KeyValueMasterClientService.getPartitionInfo_args
 
unsetOptions() - Method in class alluxio.thrift.KeyValueMasterClientService.mergeStore_args
 
unsetOptions() - Method in class alluxio.thrift.KeyValueMasterClientService.renameStore_args
 
unsetOptions() - Method in class alluxio.thrift.KeyValueWorkerClientService.get_args
 
unsetOptions() - Method in class alluxio.thrift.KeyValueWorkerClientService.getNextKeys_args
 
unsetOptions() - Method in class alluxio.thrift.KeyValueWorkerClientService.getSize_args
 
unsetOptions() - Method in class alluxio.thrift.LineageMasterClientService.createLineage_args
 
unsetOptions() - Method in class alluxio.thrift.LineageMasterClientService.deleteLineage_args
 
unsetOptions() - Method in class alluxio.thrift.LineageMasterClientService.getLineageInfoList_args
 
unsetOptions() - Method in class alluxio.thrift.LineageMasterClientService.reinitializeFile_args
 
unsetOptions() - Method in class alluxio.thrift.LineageMasterClientService.reportLostFile_args
 
unsetOptions() - Method in class alluxio.thrift.MetaMasterClientService.backup_args
 
unsetOptions() - Method in class alluxio.thrift.MetaMasterClientService.getConfigReport_args
 
unsetOptions() - Method in class alluxio.thrift.MetaMasterClientService.getConfiguration_args
 
unsetOptions() - Method in class alluxio.thrift.MetaMasterClientService.getMasterInfo_args
 
unsetOptions() - Method in class alluxio.thrift.MetaMasterClientService.getMetrics_args
 
unsetOptions() - Method in class alluxio.thrift.MetaMasterMasterService.getMasterId_args
 
unsetOptions() - Method in class alluxio.thrift.MetaMasterMasterService.masterHeartbeat_args
 
unsetOptions() - Method in class alluxio.thrift.MetaMasterMasterService.registerMaster_args
 
unsetOptions() - Method in class alluxio.thrift.MetricsMasterClientService.metricsHeartbeat_args
 
unsetOutputFile() - Method in class alluxio.thrift.JobConfInfo
 
unsetOutputFiles() - Method in class alluxio.thrift.LineageInfo
 
unsetOutputFiles() - Method in class alluxio.thrift.LineageMasterClientService.createLineage_args
 
unsetOwner() - Method in class alluxio.thrift.CompleteUfsFileTOptions
 
unsetOwner() - Method in class alluxio.thrift.CreateUfsFileTOptions
 
unsetOwner() - Method in class alluxio.thrift.FileInfo
 
unsetOwner() - Method in class alluxio.thrift.SetAttributeTOptions
 
unsetParents() - Method in class alluxio.thrift.LineageInfo
 
unsetPartitionInfo() - Method in class alluxio.thrift.GetPartitionInfoTResponse
 
unsetPath() - Method in class alluxio.thrift.FileInfo
 
unsetPath() - Method in class alluxio.thrift.FileSystemMasterClientService.checkConsistency_args
 
unsetPath() - Method in class alluxio.thrift.FileSystemMasterClientService.completeFile_args
 
unsetPath() - Method in class alluxio.thrift.FileSystemMasterClientService.createDirectory_args
 
unsetPath() - Method in class alluxio.thrift.FileSystemMasterClientService.createFile_args
 
unsetPath() - Method in class alluxio.thrift.FileSystemMasterClientService.free_args
 
unsetPath() - Method in class alluxio.thrift.FileSystemMasterClientService.getNewBlockIdForFile_args
 
unsetPath() - Method in class alluxio.thrift.FileSystemMasterClientService.getStatus_args
 
unsetPath() - Method in class alluxio.thrift.FileSystemMasterClientService.listStatus_args
 
unsetPath() - Method in class alluxio.thrift.FileSystemMasterClientService.remove_args
 
unsetPath() - Method in class alluxio.thrift.FileSystemMasterClientService.rename_args
 
unsetPath() - Method in class alluxio.thrift.FileSystemMasterClientService.scheduleAsyncPersistence_args
 
unsetPath() - Method in class alluxio.thrift.FileSystemMasterClientService.setAttribute_args
 
unsetPath() - Method in class alluxio.thrift.GetFilePathTResponse
 
unsetPath() - Method in class alluxio.thrift.KeyValueMasterClientService.completePartition_args
 
unsetPath() - Method in class alluxio.thrift.KeyValueMasterClientService.completeStore_args
 
unsetPath() - Method in class alluxio.thrift.KeyValueMasterClientService.createStore_args
 
unsetPath() - Method in class alluxio.thrift.KeyValueMasterClientService.deleteStore_args
 
unsetPath() - Method in class alluxio.thrift.KeyValueMasterClientService.getPartitionInfo_args
 
unsetPath() - Method in class alluxio.thrift.LineageMasterClientService.reinitializeFile_args
 
unsetPath() - Method in class alluxio.thrift.LineageMasterClientService.reportLostFile_args
 
unsetPersisted() - Method in class alluxio.thrift.CreateDirectoryTOptions
 
unsetPersisted() - Method in class alluxio.thrift.CreateFileTOptions
 
unsetPersisted() - Method in class alluxio.thrift.FileInfo
 
unsetPersisted() - Method in class alluxio.thrift.SetAttributeTOptions
 
unsetPersistedFileFingerprints() - Method in class alluxio.thrift.FileSystemHeartbeatTOptions
 
unsetPersistedFiles() - Method in class alluxio.thrift.FileSystemMasterWorkerService.fileSystemHeartbeat_args
 
unsetPersistenceState() - Method in class alluxio.thrift.FileInfo
 
unsetPersistFiles() - Method in class alluxio.thrift.PersistCommandOptions
 
unsetPinned() - Method in class alluxio.thrift.FileInfo
 
unsetPinned() - Method in class alluxio.thrift.SetAttributeTOptions
 
unsetPinnedFileIds() - Method in class alluxio.thrift.GetPinnedFileIdsTResponse
 
unsetPromoted() - Method in class alluxio.thrift.PromoteBlockTResponse
 
unsetProperties() - Method in class alluxio.thrift.MountPointInfo
 
unsetProperties() - Method in class alluxio.thrift.MountTOptions
 
unsetProperties() - Method in class alluxio.thrift.UfsInfo
 
unsetRawValue() - Method in class alluxio.thrift.GetConfigurationTOptions
 
unsetReadOnly() - Method in class alluxio.thrift.MountPointInfo
 
unsetReadOnly() - Method in class alluxio.thrift.MountTOptions
 
unsetRecursive() - Method in class alluxio.thrift.CreateDirectoryTOptions
 
unsetRecursive() - Method in class alluxio.thrift.CreateFileTOptions
 
unsetRecursive() - Method in class alluxio.thrift.DeleteTOptions
 
unsetRecursive() - Method in class alluxio.thrift.FileSystemMasterClientService.free_args
 
unsetRecursive() - Method in class alluxio.thrift.FileSystemMasterClientService.loadMetadata_args
 
unsetRecursive() - Method in class alluxio.thrift.FileSystemMasterClientService.remove_args
 
unsetRecursive() - Method in class alluxio.thrift.FreeTOptions
 
unsetRecursive() - Method in class alluxio.thrift.ListStatusTOptions
 
unsetRecursive() - Method in class alluxio.thrift.SetAttributeTOptions
 
unsetRemovedBlockIds() - Method in class alluxio.thrift.BlockMasterWorkerService.blockHeartbeat_args
 
unsetReport() - Method in class alluxio.thrift.GetConfigReportTResponse
 
unsetRequestBytes() - Method in class alluxio.thrift.BlockWorkerClientService.requestSpace_args
 
unsetRpcPort() - Method in class alluxio.thrift.MasterInfo
 
unsetRpcPort() - Method in class alluxio.thrift.MasterNetAddress
 
unsetRpcPort() - Method in class alluxio.thrift.WorkerNetAddress
 
unsetSafeMode() - Method in class alluxio.thrift.MasterInfo
 
unsetSessionId() - Method in class alluxio.thrift.BlockWorkerClientService.cacheBlock_args
 
unsetSessionId() - Method in class alluxio.thrift.BlockWorkerClientService.cancelBlock_args
 
unsetSessionId() - Method in class alluxio.thrift.BlockWorkerClientService.lockBlock_args
 
unsetSessionId() - Method in class alluxio.thrift.BlockWorkerClientService.requestBlockLocation_args
 
unsetSessionId() - Method in class alluxio.thrift.BlockWorkerClientService.requestSpace_args
 
unsetSessionId() - Method in class alluxio.thrift.BlockWorkerClientService.sessionBlockHeartbeat_args
 
unsetSessionId() - Method in class alluxio.thrift.BlockWorkerClientService.unlockBlock_args
 
unsetSessionId() - Method in class alluxio.thrift.FileSystemWorkerClientService.cancelUfsFile_args
 
unsetSessionId() - Method in class alluxio.thrift.FileSystemWorkerClientService.closeUfsFile_args
 
unsetSessionId() - Method in class alluxio.thrift.FileSystemWorkerClientService.completeUfsFile_args
 
unsetSessionId() - Method in class alluxio.thrift.FileSystemWorkerClientService.createUfsFile_args
 
unsetSessionId() - Method in class alluxio.thrift.FileSystemWorkerClientService.openUfsFile_args
 
unsetSessionId() - Method in class alluxio.thrift.FileSystemWorkerClientService.sessionFileSystemHeartbeat_args
 
unsetShared() - Method in class alluxio.thrift.MountPointInfo
 
unsetShared() - Method in class alluxio.thrift.MountTOptions
 
unsetSize() - Method in class alluxio.thrift.GetSizeTResponse
 
unsetSource() - Method in class alluxio.thrift.ConfigProperty
 
unsetStartTimeMs() - Method in class alluxio.thrift.MasterInfo
 
unsetStartTimeMs() - Method in class alluxio.thrift.WorkerInfo
 
unsetState() - Method in class alluxio.thrift.WorkerInfo
 
unsetStatus() - Method in exception alluxio.thrift.AlluxioTException
 
unsetStatus() - Method in class alluxio.thrift.ConfigCheckReport
 
unsetStorageTiers() - Method in class alluxio.thrift.BlockMasterWorkerService.registerWorker_args
 
unsetSuccess() - Method in class alluxio.thrift.AlluxioService.getServiceVersion_result
 
unsetSuccess() - Method in class alluxio.thrift.BlockMasterClientService.getBlockInfo_result
 
unsetSuccess() - Method in class alluxio.thrift.BlockMasterClientService.getBlockMasterInfo_result
 
unsetSuccess() - Method in class alluxio.thrift.BlockMasterClientService.getCapacityBytes_result
 
unsetSuccess() - Method in class alluxio.thrift.BlockMasterClientService.getUsedBytes_result
 
unsetSuccess() - Method in class alluxio.thrift.BlockMasterClientService.getWorkerInfoList_result
 
unsetSuccess() - Method in class alluxio.thrift.BlockMasterClientService.getWorkerReport_result
 
unsetSuccess() - Method in class alluxio.thrift.BlockMasterWorkerService.blockHeartbeat_result
 
unsetSuccess() - Method in class alluxio.thrift.BlockMasterWorkerService.commitBlock_result
 
unsetSuccess() - Method in class alluxio.thrift.BlockMasterWorkerService.getWorkerId_result
 
unsetSuccess() - Method in class alluxio.thrift.BlockMasterWorkerService.registerWorker_result
 
unsetSuccess() - Method in class alluxio.thrift.BlockWorkerClientService.accessBlock_result
 
unsetSuccess() - Method in class alluxio.thrift.BlockWorkerClientService.cacheBlock_result
 
unsetSuccess() - Method in class alluxio.thrift.BlockWorkerClientService.cancelBlock_result
 
unsetSuccess() - Method in class alluxio.thrift.BlockWorkerClientService.lockBlock_result
 
unsetSuccess() - Method in class alluxio.thrift.BlockWorkerClientService.promoteBlock_result
 
unsetSuccess() - Method in class alluxio.thrift.BlockWorkerClientService.removeBlock_result
 
unsetSuccess() - Method in class alluxio.thrift.BlockWorkerClientService.requestBlockLocation_result
 
unsetSuccess() - Method in class alluxio.thrift.BlockWorkerClientService.requestSpace_result
 
unsetSuccess() - Method in class alluxio.thrift.BlockWorkerClientService.sessionBlockHeartbeat_result
 
unsetSuccess() - Method in class alluxio.thrift.BlockWorkerClientService.unlockBlock_result
 
unsetSuccess() - Method in class alluxio.thrift.DeleteLineageTResponse
 
unsetSuccess() - Method in class alluxio.thrift.FileSystemMasterClientService.checkConsistency_result
 
unsetSuccess() - Method in class alluxio.thrift.FileSystemMasterClientService.completeFile_result
 
unsetSuccess() - Method in class alluxio.thrift.FileSystemMasterClientService.createDirectory_result
 
unsetSuccess() - Method in class alluxio.thrift.FileSystemMasterClientService.createFile_result
 
unsetSuccess() - Method in class alluxio.thrift.FileSystemMasterClientService.free_result
 
unsetSuccess() - Method in class alluxio.thrift.FileSystemMasterClientService.getFilePath_result
 
unsetSuccess() - Method in class alluxio.thrift.FileSystemMasterClientService.getMountTable_result
 
unsetSuccess() - Method in class alluxio.thrift.FileSystemMasterClientService.getNewBlockIdForFile_result
 
unsetSuccess() - Method in class alluxio.thrift.FileSystemMasterClientService.getStatus_result
 
unsetSuccess() - Method in class alluxio.thrift.FileSystemMasterClientService.listStatus_result
 
unsetSuccess() - Method in class alluxio.thrift.FileSystemMasterClientService.loadMetadata_result
 
unsetSuccess() - Method in class alluxio.thrift.FileSystemMasterClientService.mount_result
 
unsetSuccess() - Method in class alluxio.thrift.FileSystemMasterClientService.remove_result
 
unsetSuccess() - Method in class alluxio.thrift.FileSystemMasterClientService.rename_result
 
unsetSuccess() - Method in class alluxio.thrift.FileSystemMasterClientService.scheduleAsyncPersistence_result
 
unsetSuccess() - Method in class alluxio.thrift.FileSystemMasterClientService.setAttribute_result
 
unsetSuccess() - Method in class alluxio.thrift.FileSystemMasterClientService.unmount_result
 
unsetSuccess() - Method in class alluxio.thrift.FileSystemMasterClientService.updateUfsMode_result
 
unsetSuccess() - Method in class alluxio.thrift.FileSystemMasterWorkerService.fileSystemHeartbeat_result
 
unsetSuccess() - Method in class alluxio.thrift.FileSystemMasterWorkerService.getFileInfo_result
 
unsetSuccess() - Method in class alluxio.thrift.FileSystemMasterWorkerService.getPinnedFileIds_result
 
unsetSuccess() - Method in class alluxio.thrift.FileSystemMasterWorkerService.getUfsInfo_result
 
unsetSuccess() - Method in class alluxio.thrift.FileSystemWorkerClientService.cancelUfsFile_result
 
unsetSuccess() - Method in class alluxio.thrift.FileSystemWorkerClientService.closeUfsFile_result
 
unsetSuccess() - Method in class alluxio.thrift.FileSystemWorkerClientService.completeUfsFile_result
 
unsetSuccess() - Method in class alluxio.thrift.FileSystemWorkerClientService.createUfsFile_result
 
unsetSuccess() - Method in class alluxio.thrift.FileSystemWorkerClientService.openUfsFile_result
 
unsetSuccess() - Method in class alluxio.thrift.FileSystemWorkerClientService.sessionFileSystemHeartbeat_result
 
unsetSuccess() - Method in class alluxio.thrift.KeyValueMasterClientService.completePartition_result
 
unsetSuccess() - Method in class alluxio.thrift.KeyValueMasterClientService.completeStore_result
 
unsetSuccess() - Method in class alluxio.thrift.KeyValueMasterClientService.createStore_result
 
unsetSuccess() - Method in class alluxio.thrift.KeyValueMasterClientService.deleteStore_result
 
unsetSuccess() - Method in class alluxio.thrift.KeyValueMasterClientService.getPartitionInfo_result
 
unsetSuccess() - Method in class alluxio.thrift.KeyValueMasterClientService.mergeStore_result
 
unsetSuccess() - Method in class alluxio.thrift.KeyValueMasterClientService.renameStore_result
 
unsetSuccess() - Method in class alluxio.thrift.KeyValueWorkerClientService.get_result
 
unsetSuccess() - Method in class alluxio.thrift.KeyValueWorkerClientService.getNextKeys_result
 
unsetSuccess() - Method in class alluxio.thrift.KeyValueWorkerClientService.getSize_result
 
unsetSuccess() - Method in class alluxio.thrift.LineageMasterClientService.createLineage_result
 
unsetSuccess() - Method in class alluxio.thrift.LineageMasterClientService.deleteLineage_result
 
unsetSuccess() - Method in class alluxio.thrift.LineageMasterClientService.getLineageInfoList_result
 
unsetSuccess() - Method in class alluxio.thrift.LineageMasterClientService.reinitializeFile_result
 
unsetSuccess() - Method in class alluxio.thrift.LineageMasterClientService.reportLostFile_result
 
unsetSuccess() - Method in class alluxio.thrift.MetaMasterClientService.backup_result
 
unsetSuccess() - Method in class alluxio.thrift.MetaMasterClientService.getConfigReport_result
 
unsetSuccess() - Method in class alluxio.thrift.MetaMasterClientService.getConfiguration_result
 
unsetSuccess() - Method in class alluxio.thrift.MetaMasterClientService.getMasterInfo_result
 
unsetSuccess() - Method in class alluxio.thrift.MetaMasterClientService.getMetrics_result
 
unsetSuccess() - Method in class alluxio.thrift.MetaMasterMasterService.getMasterId_result
 
unsetSuccess() - Method in class alluxio.thrift.MetaMasterMasterService.masterHeartbeat_result
 
unsetSuccess() - Method in class alluxio.thrift.MetaMasterMasterService.registerMaster_result
 
unsetSuccess() - Method in class alluxio.thrift.MetricsMasterClientService.metricsHeartbeat_result
 
unsetSuccess() - Method in class alluxio.thrift.RequestSpaceTResponse
 
unsetSuccess() - Method in class alluxio.thrift.UnlockBlockTResponse
 
unsetSynced() - Method in class alluxio.thrift.SyncMetadataTResponse
 
unsetSyncIntervalMs() - Method in class alluxio.thrift.FileSystemMasterCommonTOptions
 
unsetTags() - Method in class alluxio.thrift.Metric
 
unsetTargetDirectory() - Method in class alluxio.thrift.BackupTOptions
 
unsetTempUfsFileId() - Method in class alluxio.thrift.FileSystemWorkerClientService.cancelUfsFile_args
 
unsetTempUfsFileId() - Method in class alluxio.thrift.FileSystemWorkerClientService.closeUfsFile_args
 
unsetTempUfsFileId() - Method in class alluxio.thrift.FileSystemWorkerClientService.completeUfsFile_args
 
unsetTierAlias() - Method in class alluxio.thrift.BlockLocation
 
unsetTierAlias() - Method in class alluxio.thrift.BlockMasterWorkerService.commitBlock_args
 
unsetTieredIdentity() - Method in class alluxio.thrift.WorkerNetAddress
 
unsetTierName() - Method in class alluxio.thrift.LocalityTier
 
unsetTiers() - Method in class alluxio.thrift.TieredIdentity
 
unsetToPath() - Method in class alluxio.thrift.KeyValueMasterClientService.mergeStore_args
 
unsetTotalBytesOnTiers() - Method in class alluxio.thrift.BlockMasterWorkerService.registerWorker_args
 
unsetTtl() - Method in class alluxio.thrift.CreateDirectoryTOptions
 
unsetTtl() - Method in class alluxio.thrift.CreateFileTOptions
 
unsetTtl() - Method in class alluxio.thrift.FileInfo
 
unsetTtl() - Method in class alluxio.thrift.LineageMasterClientService.reinitializeFile_args
 
unsetTtl() - Method in class alluxio.thrift.SetAttributeTOptions
 
unsetTtlAction() - Method in class alluxio.thrift.CreateDirectoryTOptions
 
unsetTtlAction() - Method in class alluxio.thrift.CreateFileTOptions
 
unsetTtlAction() - Method in class alluxio.thrift.FileInfo
 
unsetTtlAction() - Method in class alluxio.thrift.LineageMasterClientService.reinitializeFile_args
 
unsetTtlAction() - Method in class alluxio.thrift.SetAttributeTOptions
 
UnsetTtlCommand - Class in alluxio.cli.fs.command
Unsets the TTL value for the given path.
UnsetTtlCommand(FileSystem) - Constructor for class alluxio.cli.fs.command.UnsetTtlCommand
 
unsetUfsCapacityBytes() - Method in class alluxio.thrift.MountPointInfo
 
unsetUfsFingerprint() - Method in class alluxio.thrift.FileInfo
 
unsetUfsInfo() - Method in class alluxio.thrift.GetUfsInfoTResponse
 
unsetUfsLength() - Method in class alluxio.thrift.CompleteFileTOptions
 
unsetUfsLocations() - Method in class alluxio.thrift.FileBlockInfo
 
unsetUfsMode() - Method in class alluxio.thrift.UpdateUfsModeTOptions
 
unsetUfsPath() - Method in class alluxio.thrift.FileInfo
 
unsetUfsPath() - Method in class alluxio.thrift.FileSystemMasterClientService.loadMetadata_args
 
unsetUfsPath() - Method in class alluxio.thrift.FileSystemMasterClientService.mount_args
 
unsetUfsPath() - Method in class alluxio.thrift.FileSystemMasterClientService.updateUfsMode_args
 
unsetUfsPath() - Method in class alluxio.thrift.FileSystemWorkerClientService.createUfsFile_args
 
unsetUfsPath() - Method in class alluxio.thrift.FileSystemWorkerClientService.openUfsFile_args
 
unsetUfsPath() - Method in class alluxio.thrift.LockBlockTOptions
 
unsetUfsStringLocations() - Method in class alluxio.thrift.FileBlockInfo
 
unsetUfsType() - Method in class alluxio.thrift.MountPointInfo
 
unsetUfsUri() - Method in class alluxio.thrift.MountPointInfo
 
unsetUfsUsedBytes() - Method in class alluxio.thrift.MountPointInfo
 
unsetUnchecked() - Method in class alluxio.thrift.DeleteTOptions
 
unsetUpTimeMs() - Method in class alluxio.thrift.MasterInfo
 
unsetUri() - Method in class alluxio.thrift.UfsInfo
 
unsetUsedBytes() - Method in class alluxio.thrift.BlockMasterInfo
 
unsetUsedBytes() - Method in class alluxio.thrift.WorkerInfo
 
unsetUsedBytesOnTier() - Method in class alluxio.thrift.BlockMasterWorkerService.commitBlock_args
 
unsetUsedBytesOnTiers() - Method in class alluxio.thrift.BlockMasterInfo
 
unsetUsedBytesOnTiers() - Method in class alluxio.thrift.BlockMasterWorkerService.blockHeartbeat_args
 
unsetUsedBytesOnTiers() - Method in class alluxio.thrift.BlockMasterWorkerService.registerWorker_args
 
unsetUsedBytesOnTiers() - Method in class alluxio.thrift.WorkerInfo
 
unsetValue() - Method in class alluxio.thrift.ConfigProperty
 
unsetValue() - Method in class alluxio.thrift.LocalityTier
 
unsetValue() - Method in class alluxio.thrift.Metric
 
unsetValue() - Method in class alluxio.thrift.OptionalString
 
unsetValues() - Method in class alluxio.thrift.InconsistentProperty
 
unsetVersion() - Method in class alluxio.thrift.GetServiceVersionTResponse
 
unsetVersion() - Method in class alluxio.thrift.MasterInfo
 
unsetWarns() - Method in class alluxio.thrift.ConfigCheckReport
 
unsetWebPort() - Method in class alluxio.thrift.MasterInfo
 
unsetWebPort() - Method in class alluxio.thrift.WorkerNetAddress
 
unsetWorkerAddress() - Method in class alluxio.thrift.BlockLocation
 
unsetWorkerAddresses() - Method in class alluxio.thrift.MasterInfo
 
unsetWorkerId() - Method in class alluxio.thrift.BlockLocation
 
unsetWorkerId() - Method in class alluxio.thrift.BlockMasterWorkerService.blockHeartbeat_args
 
unsetWorkerId() - Method in class alluxio.thrift.BlockMasterWorkerService.commitBlock_args
 
unsetWorkerId() - Method in class alluxio.thrift.BlockMasterWorkerService.registerWorker_args
 
unsetWorkerId() - Method in class alluxio.thrift.FileSystemMasterWorkerService.fileSystemHeartbeat_args
 
unsetWorkerId() - Method in class alluxio.thrift.GetWorkerIdTResponse
 
unsetWorkerInfoList() - Method in class alluxio.thrift.GetWorkerInfoListTResponse
 
unsetWorkerNetAddress() - Method in class alluxio.thrift.BlockMasterWorkerService.getWorkerId_args
 
unsetWorkerRange() - Method in class alluxio.thrift.GetWorkerReportTOptions
 
unsetWriteTier() - Method in class alluxio.thrift.BlockWorkerClientService.requestBlockLocation_args
 
unsetZookeeperAddresses() - Method in class alluxio.thrift.MasterInfo
 
UnsupportedMessageHandler - Class in alluxio.worker.netty
Netty handler which replies to the client with an unknown message error for message types which are no longer supported.
UnsupportedMessageHandler() - Constructor for class alluxio.worker.netty.UnsupportedMessageHandler
Constructs a new unsupported message handler.
unwrap(byte[], int, int) - Method in class alluxio.security.authentication.PlainSaslServer
 
unwrapResponse(Protocol.Response) - Static method in class alluxio.util.CommonUtils
unwrapResponseFrom(Protocol.Response, Channel) - Static method in class alluxio.util.CommonUtils
Unwraps a Protocol.Response associated with a channel.
update(URI) - Method in class alluxio.master.journalv0.ufs.UfsCheckpointManager
Updates the checkpoint to the specified URI.
UPDATE_UFS_MODE_FIELD_NUMBER - Static variable in class alluxio.proto.journal.Journal.JournalEntry
 
updateBlockStoreLocation(long, BlockStoreLocation) - Method in class alluxio.worker.block.evictor.AbstractEvictor
Updates the block store location if the evictor wants to free space in a specific location.
updateBlockStoreLocation(long, BlockStoreLocation) - Method in class alluxio.worker.block.evictor.PartialLRUEvictor
 
updateConf(PropertyKey, String) - Method in class alluxio.multi.process.Master
Updates the master's configuration.
updateDeployMode(MultiProcessCluster.DeployMode) - Method in class alluxio.multi.process.MultiProcessCluster
Updates the cluster's deploy mode.
updateLastUpdatedTimeMs() - Method in class alluxio.master.block.meta.MasterWorkerInfo
Updates the last updated time of the worker in ms.
updateLastUpdatedTimeMs() - Method in class alluxio.master.meta.MasterInfo
Updates the last updated time of the master in ms.
updateLength(long) - Method in class alluxio.master.block.meta.MasterBlockInfo
Updates the length, if and only if the length was previously unknown.
updateMasterConf(PropertyKey, String) - Method in class alluxio.multi.process.MultiProcessCluster
Updates master configuration for all masters.
updatePinList(Set<Long>) - Method in interface alluxio.worker.block.BlockWorker
Sets the pinlist for the underlying block store.
updatePinList(Set<Long>) - Method in class alluxio.worker.block.DefaultBlockWorker
 
updatePinnedInodes(Set<Long>) - Method in interface alluxio.worker.block.BlockStore
Update the pinned inodes.
updatePinnedInodes(Set<Long>) - Method in class alluxio.worker.block.TieredBlockStore
Updates the pinned blocks.
updateToRemovedBlock(boolean, long) - Method in class alluxio.master.block.meta.MasterWorkerInfo
Adds or removes a block from the to-be-removed blocks set of the worker.
updateUfsMode(AlluxioURI, UpdateUfsModeOptions) - Method in interface alluxio.client.file.FileSystemMasterClient
Updates the operation mode for the given ufs path.
updateUfsMode(AlluxioURI, UpdateUfsModeOptions) - Method in class alluxio.client.file.RetryHandlingFileSystemMasterClient
 
updateUfsMode(AlluxioURI, UnderFileSystem.UfsMode) - Method in class alluxio.master.file.DefaultFileSystemMaster
 
updateUfsMode(AlluxioURI, UnderFileSystem.UfsMode) - Method in interface alluxio.master.file.FileSystemMaster
Update the operation mode for the given ufs path under one or more mount points.
updateUfsMode(String, UpdateUfsModeTOptions) - Method in class alluxio.master.file.FileSystemMasterClientServiceHandler
 
updateUfsMode(String, UpdateUfsModeTOptions, AsyncMethodCallback) - Method in class alluxio.thrift.FileSystemMasterClientService.AsyncClient
 
updateUfsMode(String, UpdateUfsModeTOptions, AsyncMethodCallback) - Method in interface alluxio.thrift.FileSystemMasterClientService.AsyncIface
 
updateUfsMode() - Constructor for class alluxio.thrift.FileSystemMasterClientService.AsyncProcessor.updateUfsMode
 
updateUfsMode(String, UpdateUfsModeTOptions) - Method in class alluxio.thrift.FileSystemMasterClientService.Client
 
updateUfsMode(String, UpdateUfsModeTOptions) - Method in interface alluxio.thrift.FileSystemMasterClientService.Iface
Updates the ufs mode for a ufs path under one or more mount points.
updateUfsMode() - Constructor for class alluxio.thrift.FileSystemMasterClientService.Processor.updateUfsMode
 
updateUfsMode_args() - Constructor for class alluxio.thrift.FileSystemMasterClientService.updateUfsMode_args
 
updateUfsMode_args(String, UpdateUfsModeTOptions) - Constructor for class alluxio.thrift.FileSystemMasterClientService.updateUfsMode_args
 
updateUfsMode_args(FileSystemMasterClientService.updateUfsMode_args) - Constructor for class alluxio.thrift.FileSystemMasterClientService.updateUfsMode_args
Performs a deep copy on other.
updateUfsMode_call(String, UpdateUfsModeTOptions, AsyncMethodCallback, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class alluxio.thrift.FileSystemMasterClientService.AsyncClient.updateUfsMode_call
 
updateUfsMode_result() - Constructor for class alluxio.thrift.FileSystemMasterClientService.updateUfsMode_result
 
updateUfsMode_result(UpdateUfsModeTResponse, AlluxioTException) - Constructor for class alluxio.thrift.FileSystemMasterClientService.updateUfsMode_result
 
updateUfsMode_result(FileSystemMasterClientService.updateUfsMode_result) - Constructor for class alluxio.thrift.FileSystemMasterClientService.updateUfsMode_result
Performs a deep copy on other.
UpdateUfsModeOptions - Class in alluxio.client.file.options
Method options for updating operation mode of a ufs path.
UpdateUfsModeOptions(UpdateUfsModeTOptions) - Constructor for class alluxio.client.file.options.UpdateUfsModeOptions
Constructs a mount options from thrift options.
UpdateUfsModeTOptions - Class in alluxio.thrift
 
UpdateUfsModeTOptions() - Constructor for class alluxio.thrift.UpdateUfsModeTOptions
 
UpdateUfsModeTOptions(UpdateUfsModeTOptions) - Constructor for class alluxio.thrift.UpdateUfsModeTOptions
Performs a deep copy on other.
UpdateUfsModeTOptions._Fields - Enum in alluxio.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
UpdateUfsModeTResponse - Class in alluxio.thrift
 
UpdateUfsModeTResponse() - Constructor for class alluxio.thrift.UpdateUfsModeTResponse
 
UpdateUfsModeTResponse(UpdateUfsModeTResponse) - Constructor for class alluxio.thrift.UpdateUfsModeTResponse
Performs a deep copy on other.
UpdateUfsModeTResponse._Fields - Enum in alluxio.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
updateUsedBytes(Map<String, Long>) - Method in class alluxio.master.block.meta.MasterWorkerInfo
Sets the used space of the worker in bytes.
updateUsedBytes(String, long) - Method in class alluxio.master.block.meta.MasterWorkerInfo
Sets the used space of the worker in bytes.
updateValues(Map<MetricsFilter, Set<Metric>>) - Method in class alluxio.metrics.aggregator.SingleTagValueAggregator
 
updateValues(Map<MetricsFilter, Set<Metric>>) - Method in interface alluxio.metrics.MultiValueMetricsAggregator
Updates the aggregated values from the filtered metrics.
URI - Interface in alluxio
This interface represents a URI.
URI.Factory - Class in alluxio
Factory for URI.
URIStatus - Class in alluxio.client.file
Wrapper around FileInfo.
URIStatus(FileInfo) - Constructor for class alluxio.client.file.URIStatus
Constructs an instance of this class from a FileInfo.
URIUtils - Class in alluxio.util
Utility methods for working with URIs.
usage() - Static method in class alluxio.cli.fsadmin.command.DoctorCommand
 
usage() - Static method in class alluxio.cli.fsadmin.command.ReportCommand
 
useDisplayValue(boolean) - Method in class alluxio.ConfigurationValueOptions
 
User - Class in alluxio.security
This class represents a user in Alluxio.
User(String) - Constructor for class alluxio.security.User
Constructs a new user with a name.
USER_APP_ID - Static variable in class alluxio.PropertyKey.Name
 
USER_APP_ID - Static variable in class alluxio.PropertyKey
 
USER_BLOCK_MASTER_CLIENT_POOL_GC_INTERVAL_MS - Static variable in class alluxio.PropertyKey.Name
 
USER_BLOCK_MASTER_CLIENT_POOL_GC_INTERVAL_MS - Static variable in class alluxio.PropertyKey
 
USER_BLOCK_MASTER_CLIENT_POOL_GC_THRESHOLD_MS - Static variable in class alluxio.PropertyKey.Name
 
USER_BLOCK_MASTER_CLIENT_POOL_GC_THRESHOLD_MS - Static variable in class alluxio.PropertyKey
 
USER_BLOCK_MASTER_CLIENT_POOL_SIZE_MAX - Static variable in class alluxio.PropertyKey.Name
 
USER_BLOCK_MASTER_CLIENT_POOL_SIZE_MAX - Static variable in class alluxio.PropertyKey
 
USER_BLOCK_MASTER_CLIENT_POOL_SIZE_MIN - Static variable in class alluxio.PropertyKey.Name
 
USER_BLOCK_MASTER_CLIENT_POOL_SIZE_MIN - Static variable in class alluxio.PropertyKey
 
USER_BLOCK_REMOTE_READ_BUFFER_SIZE_BYTES - Static variable in class alluxio.PropertyKey.Name
 
USER_BLOCK_REMOTE_READ_BUFFER_SIZE_BYTES - Static variable in class alluxio.PropertyKey
 
USER_BLOCK_REMOTE_READER_CLASS - Static variable in class alluxio.PropertyKey.Name
 
USER_BLOCK_REMOTE_READER_CLASS - Static variable in class alluxio.PropertyKey
Deprecated.
It will be removed in 2.0.0.
USER_BLOCK_REMOTE_WRITER_CLASS - Static variable in class alluxio.PropertyKey.Name
 
USER_BLOCK_REMOTE_WRITER_CLASS - Static variable in class alluxio.PropertyKey
Deprecated.
It will be removed in 2.0.0.
USER_BLOCK_SIZE_BYTES_DEFAULT - Static variable in class alluxio.PropertyKey.Name
 
USER_BLOCK_SIZE_BYTES_DEFAULT - Static variable in class alluxio.PropertyKey
 
USER_BLOCK_WORKER_CLIENT_POOL_GC_THRESHOLD_MS - Static variable in class alluxio.PropertyKey.Name
 
USER_BLOCK_WORKER_CLIENT_POOL_GC_THRESHOLD_MS - Static variable in class alluxio.PropertyKey
 
USER_BLOCK_WORKER_CLIENT_POOL_SIZE_MAX - Static variable in class alluxio.PropertyKey.Name
 
USER_BLOCK_WORKER_CLIENT_POOL_SIZE_MAX - Static variable in class alluxio.PropertyKey
 
USER_BLOCK_WORKER_CLIENT_READ_RETRY - Static variable in class alluxio.PropertyKey.Name
 
USER_BLOCK_WORKER_CLIENT_READ_RETRY - Static variable in class alluxio.PropertyKey
 
USER_BLOCK_WORKER_CLIENT_THREADS - Static variable in class alluxio.PropertyKey.Name
 
USER_BLOCK_WORKER_CLIENT_THREADS - Static variable in class alluxio.PropertyKey
 
USER_CHANNEL_TYPE - Static variable in class alluxio.util.network.NettyUtils
 
USER_CONF_CLUSTER_DEFAULT_ENABLED - Static variable in class alluxio.PropertyKey.Name
 
USER_CONF_CLUSTER_DEFAULT_ENABLED - Static variable in class alluxio.PropertyKey
 
USER_DATE_FORMAT_PATTERN - Static variable in class alluxio.PropertyKey.Name
 
USER_DATE_FORMAT_PATTERN - Static variable in class alluxio.PropertyKey
 
USER_FAILED_SPACE_REQUEST_LIMITS - Static variable in class alluxio.PropertyKey.Name
 
USER_FAILED_SPACE_REQUEST_LIMITS - Static variable in class alluxio.PropertyKey
 
USER_FIELD_NUMBER - Static variable in class alluxio.proto.dataserver.Protocol.OpenUfsBlockOptions
 
USER_FILE_BUFFER_BYTES - Static variable in class alluxio.PropertyKey.Name
 
USER_FILE_BUFFER_BYTES - Static variable in class alluxio.PropertyKey
 
USER_FILE_CACHE_PARTIALLY_READ_BLOCK - Static variable in class alluxio.PropertyKey.Name
 
USER_FILE_CACHE_PARTIALLY_READ_BLOCK - Static variable in class alluxio.PropertyKey
Deprecated.
It will be removed in 2.0.0.
USER_FILE_COPY_FROM_LOCAL_WRITE_LOCATION_POLICY - Static variable in class alluxio.PropertyKey.Name
 
USER_FILE_COPY_FROM_LOCAL_WRITE_LOCATION_POLICY - Static variable in class alluxio.PropertyKey
 
USER_FILE_DELETE_UNCHECKED - Static variable in class alluxio.PropertyKey.Name
 
USER_FILE_DELETE_UNCHECKED - Static variable in class alluxio.PropertyKey
 
USER_FILE_MASTER_CLIENT_POOL_GC_INTERVAL_MS - Static variable in class alluxio.PropertyKey.Name
 
USER_FILE_MASTER_CLIENT_POOL_GC_INTERVAL_MS - Static variable in class alluxio.PropertyKey
 
USER_FILE_MASTER_CLIENT_POOL_GC_THRESHOLD_MS - Static variable in class alluxio.PropertyKey.Name
 
USER_FILE_MASTER_CLIENT_POOL_GC_THRESHOLD_MS - Static variable in class alluxio.PropertyKey
 
USER_FILE_MASTER_CLIENT_POOL_SIZE_MAX - Static variable in class alluxio.PropertyKey.Name
 
USER_FILE_MASTER_CLIENT_POOL_SIZE_MAX - Static variable in class alluxio.PropertyKey
 
USER_FILE_MASTER_CLIENT_POOL_SIZE_MIN - Static variable in class alluxio.PropertyKey.Name
 
USER_FILE_MASTER_CLIENT_POOL_SIZE_MIN - Static variable in class alluxio.PropertyKey
 
USER_FILE_METADATA_LOAD_TYPE - Static variable in class alluxio.PropertyKey.Name
 
USER_FILE_METADATA_LOAD_TYPE - Static variable in class alluxio.PropertyKey
 
USER_FILE_METADATA_SYNC_INTERVAL - Static variable in class alluxio.PropertyKey.Name
 
USER_FILE_METADATA_SYNC_INTERVAL - Static variable in class alluxio.PropertyKey
 
USER_FILE_PASSIVE_CACHE_ENABLED - Static variable in class alluxio.PropertyKey.Name
 
USER_FILE_PASSIVE_CACHE_ENABLED - Static variable in class alluxio.PropertyKey
 
USER_FILE_READ_TYPE_DEFAULT - Static variable in class alluxio.PropertyKey.Name
 
USER_FILE_READ_TYPE_DEFAULT - Static variable in class alluxio.PropertyKey
 
USER_FILE_SEEK_BUFFER_SIZE_BYTES - Static variable in class alluxio.PropertyKey.Name
 
USER_FILE_SEEK_BUFFER_SIZE_BYTES - Static variable in class alluxio.PropertyKey
 
USER_FILE_WAITCOMPLETED_POLL_MS - Static variable in class alluxio.PropertyKey.Name
 
USER_FILE_WAITCOMPLETED_POLL_MS - Static variable in class alluxio.PropertyKey
 
USER_FILE_WRITE_AVOID_EVICTION_POLICY_RESERVED_BYTES - Static variable in class alluxio.PropertyKey.Name
 
USER_FILE_WRITE_AVOID_EVICTION_POLICY_RESERVED_BYTES - Static variable in class alluxio.PropertyKey
 
USER_FILE_WRITE_LOCATION_POLICY - Static variable in class alluxio.PropertyKey.Name
 
USER_FILE_WRITE_LOCATION_POLICY - Static variable in class alluxio.PropertyKey
 
USER_FILE_WRITE_TIER_DEFAULT - Static variable in class alluxio.PropertyKey.Name
 
USER_FILE_WRITE_TIER_DEFAULT - Static variable in class alluxio.PropertyKey
 
USER_FILE_WRITE_TYPE_DEFAULT - Static variable in class alluxio.PropertyKey.Name
 
USER_FILE_WRITE_TYPE_DEFAULT - Static variable in class alluxio.PropertyKey
 
USER_HEARTBEAT_INTERVAL_MS - Static variable in class alluxio.PropertyKey.Name
 
USER_HEARTBEAT_INTERVAL_MS - Static variable in class alluxio.PropertyKey
 
USER_HOSTNAME - Static variable in class alluxio.PropertyKey.Name
 
USER_HOSTNAME - Static variable in class alluxio.PropertyKey
Deprecated.
USER_LINEAGE_ENABLED - Static variable in class alluxio.PropertyKey.Name
 
USER_LINEAGE_ENABLED - Static variable in class alluxio.PropertyKey
 
USER_LINEAGE_MASTER_CLIENT_THREADS - Static variable in class alluxio.PropertyKey.Name
 
USER_LINEAGE_MASTER_CLIENT_THREADS - Static variable in class alluxio.PropertyKey
 
USER_LOCAL_READER_PACKET_SIZE_BYTES - Static variable in class alluxio.PropertyKey.Name
 
USER_LOCAL_READER_PACKET_SIZE_BYTES - Static variable in class alluxio.PropertyKey
 
USER_LOCAL_WRITER_PACKET_SIZE_BYTES - Static variable in class alluxio.PropertyKey.Name
 
USER_LOCAL_WRITER_PACKET_SIZE_BYTES - Static variable in class alluxio.PropertyKey
 
USER_METRICS_COLLECTION_ENABLED - Static variable in class alluxio.PropertyKey.Name
 
USER_METRICS_COLLECTION_ENABLED - Static variable in class alluxio.PropertyKey
 
USER_METRICS_HEARTBEAT_INTERVAL_MS - Static variable in class alluxio.PropertyKey.Name
 
USER_METRICS_HEARTBEAT_INTERVAL_MS - Static variable in class alluxio.PropertyKey
 
USER_NETWORK_NETTY_CHANNEL - Static variable in class alluxio.PropertyKey.Name
 
USER_NETWORK_NETTY_CHANNEL - Static variable in class alluxio.PropertyKey
 
USER_NETWORK_NETTY_CHANNEL_POOL_DISABLED - Static variable in class alluxio.PropertyKey.Name
 
USER_NETWORK_NETTY_CHANNEL_POOL_DISABLED - Static variable in class alluxio.PropertyKey
 
USER_NETWORK_NETTY_CHANNEL_POOL_GC_THRESHOLD_MS - Static variable in class alluxio.PropertyKey.Name
 
USER_NETWORK_NETTY_CHANNEL_POOL_GC_THRESHOLD_MS - Static variable in class alluxio.PropertyKey
 
USER_NETWORK_NETTY_CHANNEL_POOL_SIZE_MAX - Static variable in class alluxio.PropertyKey.Name
 
USER_NETWORK_NETTY_CHANNEL_POOL_SIZE_MAX - Static variable in class alluxio.PropertyKey
 
USER_NETWORK_NETTY_CHANNEL_POOL_SIZE_MIN - Static variable in class alluxio.PropertyKey.Name
 
USER_NETWORK_NETTY_CHANNEL_POOL_SIZE_MIN - Static variable in class alluxio.PropertyKey
 
USER_NETWORK_NETTY_READER_BUFFER_SIZE_PACKETS - Static variable in class alluxio.PropertyKey.Name
 
USER_NETWORK_NETTY_READER_BUFFER_SIZE_PACKETS - Static variable in class alluxio.PropertyKey
 
USER_NETWORK_NETTY_READER_CANCEL_ENABLED - Static variable in class alluxio.PropertyKey.Name
 
USER_NETWORK_NETTY_READER_PACKET_SIZE_BYTES - Static variable in class alluxio.PropertyKey.Name
 
USER_NETWORK_NETTY_READER_PACKET_SIZE_BYTES - Static variable in class alluxio.PropertyKey
 
USER_NETWORK_NETTY_TIMEOUT_MS - Static variable in class alluxio.PropertyKey.Name
 
USER_NETWORK_NETTY_TIMEOUT_MS - Static variable in class alluxio.PropertyKey
 
USER_NETWORK_NETTY_WORKER_THREADS - Static variable in class alluxio.PropertyKey.Name
 
USER_NETWORK_NETTY_WORKER_THREADS - Static variable in class alluxio.PropertyKey
 
USER_NETWORK_NETTY_WRITER_BUFFER_SIZE_PACKETS - Static variable in class alluxio.PropertyKey.Name
 
USER_NETWORK_NETTY_WRITER_BUFFER_SIZE_PACKETS - Static variable in class alluxio.PropertyKey
 
USER_NETWORK_NETTY_WRITER_CLOSE_TIMEOUT_MS - Static variable in class alluxio.PropertyKey.Name
 
USER_NETWORK_NETTY_WRITER_CLOSE_TIMEOUT_MS - Static variable in class alluxio.PropertyKey
 
USER_NETWORK_NETTY_WRITER_PACKET_SIZE_BYTES - Static variable in class alluxio.PropertyKey.Name
 
USER_NETWORK_NETTY_WRITER_PACKET_SIZE_BYTES - Static variable in class alluxio.PropertyKey
 
USER_NETWORK_SOCKET_TIMEOUT - Static variable in class alluxio.PropertyKey.Name
 
USER_NETWORK_SOCKET_TIMEOUT - Static variable in class alluxio.PropertyKey
 
USER_RPC_RETRY_BASE_SLEEP_MS - Static variable in class alluxio.PropertyKey.Name
 
USER_RPC_RETRY_BASE_SLEEP_MS - Static variable in class alluxio.PropertyKey
 
USER_RPC_RETRY_MAX_DURATION - Static variable in class alluxio.PropertyKey.Name
 
USER_RPC_RETRY_MAX_DURATION - Static variable in class alluxio.PropertyKey
 
USER_RPC_RETRY_MAX_NUM_RETRY - Static variable in class alluxio.PropertyKey.Name
 
USER_RPC_RETRY_MAX_NUM_RETRY - Static variable in class alluxio.PropertyKey
Deprecated.
since version 1.8 and will be removed in version 2.0.
USER_RPC_RETRY_MAX_SLEEP_MS - Static variable in class alluxio.PropertyKey.Name
 
USER_RPC_RETRY_MAX_SLEEP_MS - Static variable in class alluxio.PropertyKey
 
USER_SHORT_CIRCUIT_ENABLED - Static variable in class alluxio.PropertyKey.Name
 
USER_SHORT_CIRCUIT_ENABLED - Static variable in class alluxio.PropertyKey
 
USER_UFS_BLOCK_READ_CONCURRENCY_MAX - Static variable in class alluxio.PropertyKey.Name
 
USER_UFS_BLOCK_READ_CONCURRENCY_MAX - Static variable in class alluxio.PropertyKey
 
USER_UFS_BLOCK_READ_LOCATION_POLICY - Static variable in class alluxio.PropertyKey.Name
 
USER_UFS_BLOCK_READ_LOCATION_POLICY - Static variable in class alluxio.PropertyKey
 
USER_UFS_BLOCK_READ_LOCATION_POLICY_DETERMINISTIC_HASH_SHARDS - Static variable in class alluxio.PropertyKey.Name
 
USER_UFS_BLOCK_READ_LOCATION_POLICY_DETERMINISTIC_HASH_SHARDS - Static variable in class alluxio.PropertyKey
 
USER_UFS_DELEGATION_ENABLED - Static variable in class alluxio.PropertyKey.Name
 
USER_UFS_DELEGATION_READ_BUFFER_SIZE_BYTES - Static variable in class alluxio.PropertyKey.Name
 
USER_UFS_DELEGATION_READ_BUFFER_SIZE_BYTES - Static variable in class alluxio.PropertyKey
Deprecated.
It will be removed in 2.0.0.
USER_UFS_DELEGATION_WRITE_BUFFER_SIZE_BYTES - Static variable in class alluxio.PropertyKey.Name
 
USER_UFS_DELEGATION_WRITE_BUFFER_SIZE_BYTES - Static variable in class alluxio.PropertyKey
Deprecated.
It will be removed in 2.0.0.
USER_UFS_FILE_READER_CLASS - Static variable in class alluxio.PropertyKey.Name
 
USER_UFS_FILE_READER_CLASS - Static variable in class alluxio.PropertyKey
Deprecated.
It will be removed in 2.0.0.
USER_UFS_FILE_WRITER_CLASS - Static variable in class alluxio.PropertyKey.Name
 
USER_UFS_FILE_WRITER_CLASS - Static variable in class alluxio.PropertyKey
Deprecated.
It will be removed in 2.0.0.
useRawValue(boolean) - Method in class alluxio.ConfigurationValueOptions
 
userEventTriggered(ChannelHandlerContext, Object) - Method in class alluxio.network.netty.IdleWriteHandler
 
userEventTriggered(ChannelHandlerContext, Object) - Method in class alluxio.worker.netty.IdleReadHandler
 
userKeySet() - Method in class alluxio.conf.AlluxioProperties
 
UserLimitValidationTask - Class in alluxio.cli.validation
Task for validating system limit for current user.
Utils - Class in alluxio.cli.validation
Utilities for validating Alluxio environment.
Utils - Class in alluxio.multi.process
Utility methods for external test cluster classes.

V

validate() - Method in interface alluxio.AlluxioConfiguration
Validates the configuration.
validate(String...) - Static method in class alluxio.cli.ValidateEnv
Validates environment.
validate(Map<String, String>) - Method in class alluxio.cli.validation.ClusterConfConsistencyValidationTask
 
validate(Map<String, String>) - Method in class alluxio.cli.validation.HdfsValidationTask
 
validate(Map<String, String>) - Method in class alluxio.cli.validation.PortAvailabilityValidationTask
 
validate(Map<String, String>) - Method in class alluxio.cli.validation.RamDiskMountPrivilegeValidationTask
 
validate(Map<String, String>) - Method in class alluxio.cli.validation.SecureHdfsValidationTask
 
validate(Map<String, String>) - Method in class alluxio.cli.validation.SshValidationTask
 
validate(Map<String, String>) - Method in class alluxio.cli.validation.StorageSpaceValidationTask
 
validate(Map<String, String>) - Method in class alluxio.cli.validation.UfsDirectoryValidationTask
 
validate(Map<String, String>) - Method in class alluxio.cli.validation.UfsSuperUserValidationTask
 
validate(Map<String, String>) - Method in class alluxio.cli.validation.UserLimitValidationTask
 
validate(Map<String, String>) - Method in interface alluxio.cli.validation.ValidationTask
Runs the validation task.
validate() - Method in class alluxio.conf.InstancedConfiguration
 
validate() - Static method in class alluxio.Configuration
Validates the configuration.
validate() - Method in class alluxio.network.protocol.RPCMessage
Validates the message.
validate() - Method in class alluxio.network.protocol.RPCProtoMessage
 
validate() - Method in class alluxio.thrift.AccessBlockTOptions
 
validate() - Method in class alluxio.thrift.AccessBlockTResponse
 
validate() - Method in class alluxio.thrift.AlluxioService.getServiceVersion_args
 
validate() - Method in class alluxio.thrift.AlluxioService.getServiceVersion_result
 
validate() - Method in exception alluxio.thrift.AlluxioTException
 
validate() - Method in class alluxio.thrift.BackupTOptions
 
validate() - Method in class alluxio.thrift.BackupTResponse
 
validate() - Method in class alluxio.thrift.BlockHeartbeatTOptions
 
validate() - Method in class alluxio.thrift.BlockHeartbeatTResponse
 
validate() - Method in class alluxio.thrift.BlockInfo
 
validate() - Method in class alluxio.thrift.BlockLocation
 
validate() - Method in class alluxio.thrift.BlockMasterClientService.getBlockInfo_args
 
validate() - Method in class alluxio.thrift.BlockMasterClientService.getBlockInfo_result
 
validate() - Method in class alluxio.thrift.BlockMasterClientService.getBlockMasterInfo_args
 
validate() - Method in class alluxio.thrift.BlockMasterClientService.getBlockMasterInfo_result
 
validate() - Method in class alluxio.thrift.BlockMasterClientService.getCapacityBytes_args
 
validate() - Method in class alluxio.thrift.BlockMasterClientService.getCapacityBytes_result
 
validate() - Method in class alluxio.thrift.BlockMasterClientService.getUsedBytes_args
 
validate() - Method in class alluxio.thrift.BlockMasterClientService.getUsedBytes_result
 
validate() - Method in class alluxio.thrift.BlockMasterClientService.getWorkerInfoList_args
 
validate() - Method in class alluxio.thrift.BlockMasterClientService.getWorkerInfoList_result
 
validate() - Method in class alluxio.thrift.BlockMasterClientService.getWorkerReport_args
 
validate() - Method in class alluxio.thrift.BlockMasterClientService.getWorkerReport_result
 
validate() - Method in class alluxio.thrift.BlockMasterInfo
 
validate() - Method in class alluxio.thrift.BlockMasterWorkerService.blockHeartbeat_args
 
validate() - Method in class alluxio.thrift.BlockMasterWorkerService.blockHeartbeat_result
 
validate() - Method in class alluxio.thrift.BlockMasterWorkerService.commitBlock_args
 
validate() - Method in class alluxio.thrift.BlockMasterWorkerService.commitBlock_result
 
validate() - Method in class alluxio.thrift.BlockMasterWorkerService.getWorkerId_args
 
validate() - Method in class alluxio.thrift.BlockMasterWorkerService.getWorkerId_result
 
validate() - Method in class alluxio.thrift.BlockMasterWorkerService.registerWorker_args
 
validate() - Method in class alluxio.thrift.BlockMasterWorkerService.registerWorker_result
 
validate() - Method in class alluxio.thrift.BlockWorkerClientService.accessBlock_args
 
validate() - Method in class alluxio.thrift.BlockWorkerClientService.accessBlock_result
 
validate() - Method in class alluxio.thrift.BlockWorkerClientService.cacheBlock_args
 
validate() - Method in class alluxio.thrift.BlockWorkerClientService.cacheBlock_result
 
validate() - Method in class alluxio.thrift.BlockWorkerClientService.cancelBlock_args
 
validate() - Method in class alluxio.thrift.BlockWorkerClientService.cancelBlock_result
 
validate() - Method in class alluxio.thrift.BlockWorkerClientService.lockBlock_args
 
validate() - Method in class alluxio.thrift.BlockWorkerClientService.lockBlock_result
 
validate() - Method in class alluxio.thrift.BlockWorkerClientService.promoteBlock_args
 
validate() - Method in class alluxio.thrift.BlockWorkerClientService.promoteBlock_result
 
validate() - Method in class alluxio.thrift.BlockWorkerClientService.removeBlock_args
 
validate() - Method in class alluxio.thrift.BlockWorkerClientService.removeBlock_result
 
validate() - Method in class alluxio.thrift.BlockWorkerClientService.requestBlockLocation_args
 
validate() - Method in class alluxio.thrift.BlockWorkerClientService.requestBlockLocation_result
 
validate() - Method in class alluxio.thrift.BlockWorkerClientService.requestSpace_args
 
validate() - Method in class alluxio.thrift.BlockWorkerClientService.requestSpace_result
 
validate() - Method in class alluxio.thrift.BlockWorkerClientService.sessionBlockHeartbeat_args
 
validate() - Method in class alluxio.thrift.BlockWorkerClientService.sessionBlockHeartbeat_result
 
validate() - Method in class alluxio.thrift.BlockWorkerClientService.unlockBlock_args
 
validate() - Method in class alluxio.thrift.BlockWorkerClientService.unlockBlock_result
 
validate() - Method in class alluxio.thrift.CacheBlockTOptions
 
validate() - Method in class alluxio.thrift.CacheBlockTResponse
 
validate() - Method in class alluxio.thrift.CancelBlockTOptions
 
validate() - Method in class alluxio.thrift.CancelBlockTResponse
 
validate() - Method in class alluxio.thrift.CancelUfsFileTOptions
 
validate() - Method in class alluxio.thrift.CancelUfsFileTResponse
 
validate() - Method in class alluxio.thrift.CheckConsistencyTOptions
 
validate() - Method in class alluxio.thrift.CheckConsistencyTResponse
 
validate() - Method in class alluxio.thrift.CloseUfsFileTOptions
 
validate() - Method in class alluxio.thrift.CloseUfsFileTResponse
 
validate() - Method in class alluxio.thrift.Command
 
validate() - Method in class alluxio.thrift.CommandLineJobInfo
 
validate() - Method in class alluxio.thrift.CommitBlockTOptions
 
validate() - Method in class alluxio.thrift.CommitBlockTResponse
 
validate() - Method in class alluxio.thrift.CompleteFileTOptions
 
validate() - Method in class alluxio.thrift.CompleteFileTResponse
 
validate() - Method in class alluxio.thrift.CompletePartitionTOptions
 
validate() - Method in class alluxio.thrift.CompletePartitionTResponse
 
validate() - Method in class alluxio.thrift.CompleteStoreTOptions
 
validate() - Method in class alluxio.thrift.CompleteStoreTResponse
 
validate() - Method in class alluxio.thrift.CompleteUfsFileTOptions
 
validate() - Method in class alluxio.thrift.CompleteUfsFileTReponse
 
validate() - Method in class alluxio.thrift.ConfigCheckReport
 
validate() - Method in class alluxio.thrift.ConfigProperty
 
validate() - Method in class alluxio.thrift.CreateDirectoryTOptions
 
validate() - Method in class alluxio.thrift.CreateDirectoryTResponse
 
validate() - Method in class alluxio.thrift.CreateFileTOptions
 
validate() - Method in class alluxio.thrift.CreateFileTResponse
 
validate() - Method in class alluxio.thrift.CreateLineageTOptions
 
validate() - Method in class alluxio.thrift.CreateLineageTResponse
 
validate() - Method in class alluxio.thrift.CreateStoreTOptions
 
validate() - Method in class alluxio.thrift.CreateStoreTResponse
 
validate() - Method in class alluxio.thrift.CreateUfsFileTOptions
 
validate() - Method in class alluxio.thrift.CreateUfsFileTResponse
 
validate() - Method in class alluxio.thrift.DeleteLineageTOptions
 
validate() - Method in class alluxio.thrift.DeleteLineageTResponse
 
validate() - Method in class alluxio.thrift.DeleteStoreTOptions
 
validate() - Method in class alluxio.thrift.DeleteStoreTResponse
 
validate() - Method in class alluxio.thrift.DeleteTOptions
 
validate() - Method in class alluxio.thrift.DeleteTResponse
 
validate() - Method in class alluxio.thrift.DependencyInfo
 
validate() - Method in class alluxio.thrift.FileBlockInfo
 
validate() - Method in class alluxio.thrift.FileInfo
 
validate() - Method in class alluxio.thrift.FileSystemCommand
 
validate() - Method in class alluxio.thrift.FileSystemHeartbeatTOptions
 
validate() - Method in class alluxio.thrift.FileSystemHeartbeatTResponse
 
validate() - Method in class alluxio.thrift.FileSystemMasterClientService.checkConsistency_args
 
validate() - Method in class alluxio.thrift.FileSystemMasterClientService.checkConsistency_result
 
validate() - Method in class alluxio.thrift.FileSystemMasterClientService.completeFile_args
 
validate() - Method in class alluxio.thrift.FileSystemMasterClientService.completeFile_result
 
validate() - Method in class alluxio.thrift.FileSystemMasterClientService.createDirectory_args
 
validate() - Method in class alluxio.thrift.FileSystemMasterClientService.createDirectory_result
 
validate() - Method in class alluxio.thrift.FileSystemMasterClientService.createFile_args
 
validate() - Method in class alluxio.thrift.FileSystemMasterClientService.createFile_result
 
validate() - Method in class alluxio.thrift.FileSystemMasterClientService.free_args
 
validate() - Method in class alluxio.thrift.FileSystemMasterClientService.free_result
 
validate() - Method in class alluxio.thrift.FileSystemMasterClientService.getFilePath_args
 
validate() - Method in class alluxio.thrift.FileSystemMasterClientService.getFilePath_result
 
validate() - Method in class alluxio.thrift.FileSystemMasterClientService.getMountTable_args
 
validate() - Method in class alluxio.thrift.FileSystemMasterClientService.getMountTable_result
 
validate() - Method in class alluxio.thrift.FileSystemMasterClientService.getNewBlockIdForFile_args
 
validate() - Method in class alluxio.thrift.FileSystemMasterClientService.getNewBlockIdForFile_result
 
validate() - Method in class alluxio.thrift.FileSystemMasterClientService.getStatus_args
 
validate() - Method in class alluxio.thrift.FileSystemMasterClientService.getStatus_result
 
validate() - Method in class alluxio.thrift.FileSystemMasterClientService.listStatus_args
 
validate() - Method in class alluxio.thrift.FileSystemMasterClientService.listStatus_result
 
validate() - Method in class alluxio.thrift.FileSystemMasterClientService.loadMetadata_args
 
validate() - Method in class alluxio.thrift.FileSystemMasterClientService.loadMetadata_result
 
validate() - Method in class alluxio.thrift.FileSystemMasterClientService.mount_args
 
validate() - Method in class alluxio.thrift.FileSystemMasterClientService.mount_result
 
validate() - Method in class alluxio.thrift.FileSystemMasterClientService.remove_args
 
validate() - Method in class alluxio.thrift.FileSystemMasterClientService.remove_result
 
validate() - Method in class alluxio.thrift.FileSystemMasterClientService.rename_args
 
validate() - Method in class alluxio.thrift.FileSystemMasterClientService.rename_result
 
validate() - Method in class alluxio.thrift.FileSystemMasterClientService.scheduleAsyncPersistence_args
 
validate() - Method in class alluxio.thrift.FileSystemMasterClientService.scheduleAsyncPersistence_result
 
validate() - Method in class alluxio.thrift.FileSystemMasterClientService.setAttribute_args
 
validate() - Method in class alluxio.thrift.FileSystemMasterClientService.setAttribute_result
 
validate() - Method in class alluxio.thrift.FileSystemMasterClientService.unmount_args
 
validate() - Method in class alluxio.thrift.FileSystemMasterClientService.unmount_result
 
validate() - Method in class alluxio.thrift.FileSystemMasterClientService.updateUfsMode_args
 
validate() - Method in class alluxio.thrift.FileSystemMasterClientService.updateUfsMode_result
 
validate() - Method in class alluxio.thrift.FileSystemMasterCommonTOptions
 
validate() - Method in class alluxio.thrift.FileSystemMasterWorkerService.fileSystemHeartbeat_args
 
validate() - Method in class alluxio.thrift.FileSystemMasterWorkerService.fileSystemHeartbeat_result
 
validate() - Method in class alluxio.thrift.FileSystemMasterWorkerService.getFileInfo_args
 
validate() - Method in class alluxio.thrift.FileSystemMasterWorkerService.getFileInfo_result
 
validate() - Method in class alluxio.thrift.FileSystemMasterWorkerService.getPinnedFileIds_args
 
validate() - Method in class alluxio.thrift.FileSystemMasterWorkerService.getPinnedFileIds_result
 
validate() - Method in class alluxio.thrift.FileSystemMasterWorkerService.getUfsInfo_args
 
validate() - Method in class alluxio.thrift.FileSystemMasterWorkerService.getUfsInfo_result
 
validate() - Method in class alluxio.thrift.FileSystemWorkerClientService.cancelUfsFile_args
 
validate() - Method in class alluxio.thrift.FileSystemWorkerClientService.cancelUfsFile_result
 
validate() - Method in class alluxio.thrift.FileSystemWorkerClientService.closeUfsFile_args
 
validate() - Method in class alluxio.thrift.FileSystemWorkerClientService.closeUfsFile_result
 
validate() - Method in class alluxio.thrift.FileSystemWorkerClientService.completeUfsFile_args
 
validate() - Method in class alluxio.thrift.FileSystemWorkerClientService.completeUfsFile_result
 
validate() - Method in class alluxio.thrift.FileSystemWorkerClientService.createUfsFile_args
 
validate() - Method in class alluxio.thrift.FileSystemWorkerClientService.createUfsFile_result
 
validate() - Method in class alluxio.thrift.FileSystemWorkerClientService.openUfsFile_args
 
validate() - Method in class alluxio.thrift.FileSystemWorkerClientService.openUfsFile_result
 
validate() - Method in class alluxio.thrift.FileSystemWorkerClientService.sessionFileSystemHeartbeat_args
 
validate() - Method in class alluxio.thrift.FileSystemWorkerClientService.sessionFileSystemHeartbeat_result
 
validate() - Method in class alluxio.thrift.FreeTOptions
 
validate() - Method in class alluxio.thrift.FreeTResponse
 
validate() - Method in class alluxio.thrift.GetBlockInfoTOptions
 
validate() - Method in class alluxio.thrift.GetBlockInfoTResponse
 
validate() - Method in class alluxio.thrift.GetBlockMasterInfoTOptions
 
validate() - Method in class alluxio.thrift.GetBlockMasterInfoTResponse
 
validate() - Method in class alluxio.thrift.GetCapacityBytesTOptions
 
validate() - Method in class alluxio.thrift.GetCapacityBytesTResponse
 
validate() - Method in class alluxio.thrift.GetConfigReportTOptions
 
validate() - Method in class alluxio.thrift.GetConfigReportTResponse
 
validate() - Method in class alluxio.thrift.GetConfigurationTOptions
 
validate() - Method in class alluxio.thrift.GetConfigurationTResponse
 
validate() - Method in class alluxio.thrift.GetFileInfoTOptions
 
validate() - Method in class alluxio.thrift.GetFileInfoTResponse
 
validate() - Method in class alluxio.thrift.GetFilePathTOptions
 
validate() - Method in class alluxio.thrift.GetFilePathTResponse
 
validate() - Method in class alluxio.thrift.GetLineageInfoListTOptions
 
validate() - Method in class alluxio.thrift.GetLineageInfoListTResponse
 
validate() - Method in class alluxio.thrift.GetMasterIdTOptions
 
validate() - Method in class alluxio.thrift.GetMasterIdTResponse
 
validate() - Method in class alluxio.thrift.GetMasterInfoTOptions
 
validate() - Method in class alluxio.thrift.GetMasterInfoTResponse
 
validate() - Method in class alluxio.thrift.GetMetricsTOptions
 
validate() - Method in class alluxio.thrift.GetMetricsTResponse
 
validate() - Method in class alluxio.thrift.GetMountTableTResponse
 
validate() - Method in class alluxio.thrift.GetNewBlockIdForFileTOptions
 
validate() - Method in class alluxio.thrift.GetNewBlockIdForFileTResponse
 
validate() - Method in class alluxio.thrift.GetNextKeysTOptions
 
validate() - Method in class alluxio.thrift.GetNextKeysTResponse
 
validate() - Method in class alluxio.thrift.GetPartitionInfoTOptions
 
validate() - Method in class alluxio.thrift.GetPartitionInfoTResponse
 
validate() - Method in class alluxio.thrift.GetPinnedFileIdsTOptions
 
validate() - Method in class alluxio.thrift.GetPinnedFileIdsTResponse
 
validate() - Method in class alluxio.thrift.GetServiceVersionTOptions
 
validate() - Method in class alluxio.thrift.GetServiceVersionTResponse
 
validate() - Method in class alluxio.thrift.GetSizeTOptions
 
validate() - Method in class alluxio.thrift.GetSizeTResponse
 
validate() - Method in class alluxio.thrift.GetStatusTOptions
 
validate() - Method in class alluxio.thrift.GetStatusTResponse
 
validate() - Method in class alluxio.thrift.GetTOptions
 
validate() - Method in class alluxio.thrift.GetTResponse
 
validate() - Method in class alluxio.thrift.GetUfsInfoTOptions
 
validate() - Method in class alluxio.thrift.GetUfsInfoTResponse
 
validate() - Method in class alluxio.thrift.GetUsedBytesTOptions
 
validate() - Method in class alluxio.thrift.GetUsedBytesTResponse
 
validate() - Method in class alluxio.thrift.GetWorkerIdTOptions
 
validate() - Method in class alluxio.thrift.GetWorkerIdTResponse
 
validate() - Method in class alluxio.thrift.GetWorkerInfoListTOptions
 
validate() - Method in class alluxio.thrift.GetWorkerInfoListTResponse
 
validate() - Method in class alluxio.thrift.GetWorkerReportTOptions
 
validate() - Method in class alluxio.thrift.InconsistentProperty
 
validate() - Method in class alluxio.thrift.JobConfInfo
 
validate() - Method in class alluxio.thrift.KeyValueMasterClientService.completePartition_args
 
validate() - Method in class alluxio.thrift.KeyValueMasterClientService.completePartition_result
 
validate() - Method in class alluxio.thrift.KeyValueMasterClientService.completeStore_args
 
validate() - Method in class alluxio.thrift.KeyValueMasterClientService.completeStore_result
 
validate() - Method in class alluxio.thrift.KeyValueMasterClientService.createStore_args
 
validate() - Method in class alluxio.thrift.KeyValueMasterClientService.createStore_result
 
validate() - Method in class alluxio.thrift.KeyValueMasterClientService.deleteStore_args
 
validate() - Method in class alluxio.thrift.KeyValueMasterClientService.deleteStore_result
 
validate() - Method in class alluxio.thrift.KeyValueMasterClientService.getPartitionInfo_args
 
validate() - Method in class alluxio.thrift.KeyValueMasterClientService.getPartitionInfo_result
 
validate() - Method in class alluxio.thrift.KeyValueMasterClientService.mergeStore_args
 
validate() - Method in class alluxio.thrift.KeyValueMasterClientService.mergeStore_result
 
validate() - Method in class alluxio.thrift.KeyValueMasterClientService.renameStore_args
 
validate() - Method in class alluxio.thrift.KeyValueMasterClientService.renameStore_result
 
validate() - Method in class alluxio.thrift.KeyValueWorkerClientService.get_args
 
validate() - Method in class alluxio.thrift.KeyValueWorkerClientService.get_result
 
validate() - Method in class alluxio.thrift.KeyValueWorkerClientService.getNextKeys_args
 
validate() - Method in class alluxio.thrift.KeyValueWorkerClientService.getNextKeys_result
 
validate() - Method in class alluxio.thrift.KeyValueWorkerClientService.getSize_args
 
validate() - Method in class alluxio.thrift.KeyValueWorkerClientService.getSize_result
 
validate() - Method in class alluxio.thrift.LineageInfo
 
validate() - Method in class alluxio.thrift.LineageMasterClientService.createLineage_args
 
validate() - Method in class alluxio.thrift.LineageMasterClientService.createLineage_result
 
validate() - Method in class alluxio.thrift.LineageMasterClientService.deleteLineage_args
 
validate() - Method in class alluxio.thrift.LineageMasterClientService.deleteLineage_result
 
validate() - Method in class alluxio.thrift.LineageMasterClientService.getLineageInfoList_args
 
validate() - Method in class alluxio.thrift.LineageMasterClientService.getLineageInfoList_result
 
validate() - Method in class alluxio.thrift.LineageMasterClientService.reinitializeFile_args
 
validate() - Method in class alluxio.thrift.LineageMasterClientService.reinitializeFile_result
 
validate() - Method in class alluxio.thrift.LineageMasterClientService.reportLostFile_args
 
validate() - Method in class alluxio.thrift.LineageMasterClientService.reportLostFile_result
 
validate() - Method in class alluxio.thrift.ListStatusTOptions
 
validate() - Method in class alluxio.thrift.ListStatusTResponse
 
validate() - Method in class alluxio.thrift.LoadMetadataTOptions
 
validate() - Method in class alluxio.thrift.LoadMetadataTResponse
 
validate() - Method in class alluxio.thrift.LocalityTier
 
validate() - Method in class alluxio.thrift.LockBlockTOptions
 
validate() - Method in class alluxio.thrift.LockBlockTResponse
 
validate() - Method in class alluxio.thrift.MasterHeartbeatTOptions
 
validate() - Method in class alluxio.thrift.MasterHeartbeatTResponse
 
validate() - Method in class alluxio.thrift.MasterInfo
 
validate() - Method in class alluxio.thrift.MasterNetAddress
 
validate() - Method in class alluxio.thrift.MergeStoreTOptions
 
validate() - Method in class alluxio.thrift.MergeStoreTResponse
 
validate() - Method in class alluxio.thrift.MetaMasterClientService.backup_args
 
validate() - Method in class alluxio.thrift.MetaMasterClientService.backup_result
 
validate() - Method in class alluxio.thrift.MetaMasterClientService.getConfigReport_args
 
validate() - Method in class alluxio.thrift.MetaMasterClientService.getConfigReport_result
 
validate() - Method in class alluxio.thrift.MetaMasterClientService.getConfiguration_args
 
validate() - Method in class alluxio.thrift.MetaMasterClientService.getConfiguration_result
 
validate() - Method in class alluxio.thrift.MetaMasterClientService.getMasterInfo_args
 
validate() - Method in class alluxio.thrift.MetaMasterClientService.getMasterInfo_result
 
validate() - Method in class alluxio.thrift.MetaMasterClientService.getMetrics_args
 
validate() - Method in class alluxio.thrift.MetaMasterClientService.getMetrics_result
 
validate() - Method in class alluxio.thrift.MetaMasterMasterService.getMasterId_args
 
validate() - Method in class alluxio.thrift.MetaMasterMasterService.getMasterId_result
 
validate() - Method in class alluxio.thrift.MetaMasterMasterService.masterHeartbeat_args
 
validate() - Method in class alluxio.thrift.MetaMasterMasterService.masterHeartbeat_result
 
validate() - Method in class alluxio.thrift.MetaMasterMasterService.registerMaster_args
 
validate() - Method in class alluxio.thrift.MetaMasterMasterService.registerMaster_result
 
validate() - Method in class alluxio.thrift.Metric
 
validate() - Method in class alluxio.thrift.MetricsHeartbeatTOptions
 
validate() - Method in class alluxio.thrift.MetricsHeartbeatTResponse
 
validate() - Method in class alluxio.thrift.MetricsMasterClientService.metricsHeartbeat_args
 
validate() - Method in class alluxio.thrift.MetricsMasterClientService.metricsHeartbeat_result
 
validate() - Method in class alluxio.thrift.MetricValue
 
validate() - Method in class alluxio.thrift.MountPointInfo
 
validate() - Method in class alluxio.thrift.MountTOptions
 
validate() - Method in class alluxio.thrift.MountTResponse
 
validate() - Method in class alluxio.thrift.OpenUfsFileTOptions
 
validate() - Method in class alluxio.thrift.OpenUfsFileTResponse
 
validate() - Method in class alluxio.thrift.OptionalString
 
validate() - Method in class alluxio.thrift.PartitionInfo
 
validate() - Method in class alluxio.thrift.PersistCommandOptions
 
validate() - Method in class alluxio.thrift.PersistFile
 
validate() - Method in class alluxio.thrift.PromoteBlockTOptions
 
validate() - Method in class alluxio.thrift.PromoteBlockTResponse
 
validate() - Method in class alluxio.thrift.RegisterMasterTOptions
 
validate() - Method in class alluxio.thrift.RegisterMasterTResponse
 
validate() - Method in class alluxio.thrift.RegisterWorkerTOptions
 
validate() - Method in class alluxio.thrift.RegisterWorkerTResponse
 
validate() - Method in class alluxio.thrift.ReinitializeFileTOptions
 
validate() - Method in class alluxio.thrift.ReinitializeFileTResponse
 
validate() - Method in class alluxio.thrift.RemoveBlockTOptions
 
validate() - Method in class alluxio.thrift.RemoveBlockTResponse
 
validate() - Method in class alluxio.thrift.RenameStoreTOptions
 
validate() - Method in class alluxio.thrift.RenameStoreTResponse
 
validate() - Method in class alluxio.thrift.RenameTOptions
 
validate() - Method in class alluxio.thrift.RenameTResponse
 
validate() - Method in class alluxio.thrift.ReportLostFileTOptions
 
validate() - Method in class alluxio.thrift.ReportLostFileTResponse
 
validate() - Method in class alluxio.thrift.RequestBlockLocationTOptions
 
validate() - Method in class alluxio.thrift.RequestBlockLocationTResponse
 
validate() - Method in class alluxio.thrift.RequestSpaceTOptions
 
validate() - Method in class alluxio.thrift.RequestSpaceTResponse
 
validate() - Method in class alluxio.thrift.ScheduleAsyncPersistenceTOptions
 
validate() - Method in class alluxio.thrift.ScheduleAsyncPersistenceTResponse
 
validate() - Method in class alluxio.thrift.SessionBlockHeartbeatTOptions
 
validate() - Method in class alluxio.thrift.SessionBlockHeartbeatTResponse
 
validate() - Method in class alluxio.thrift.SessionFileSystemHeartbeatTOptions
 
validate() - Method in class alluxio.thrift.SessionFileSystemHeartbeatTResponse
 
validate() - Method in class alluxio.thrift.SetAttributeTOptions
 
validate() - Method in class alluxio.thrift.SetAttributeTResponse
 
validate() - Method in class alluxio.thrift.SyncMetadataTOptions
 
validate() - Method in class alluxio.thrift.SyncMetadataTResponse
 
validate() - Method in class alluxio.thrift.TieredIdentity
 
validate() - Method in class alluxio.thrift.UfsInfo
 
validate() - Method in class alluxio.thrift.UnlockBlockTOptions
 
validate() - Method in class alluxio.thrift.UnlockBlockTResponse
 
validate() - Method in class alluxio.thrift.UnmountTOptions
 
validate() - Method in class alluxio.thrift.UnmountTResponse
 
validate() - Method in class alluxio.thrift.UpdateUfsModeTOptions
 
validate() - Method in class alluxio.thrift.UpdateUfsModeTResponse
 
validate() - Method in class alluxio.thrift.WorkerInfo
 
validate() - Method in class alluxio.thrift.WorkerNetAddress
 
validate() - Method in class alluxio.worker.block.BlockLockManager
Checks the internal state of the manager to make sure invariants hold.
validateArgs(CommandLine) - Method in interface alluxio.cli.Command
Checks if the arguments are valid or throw InvalidArgumentException.
validateArgs(CommandLine) - Method in class alluxio.cli.extensions.command.InstallCommand
 
validateArgs(CommandLine) - Method in class alluxio.cli.extensions.command.LsCommand
 
validateArgs(CommandLine) - Method in class alluxio.cli.extensions.command.UninstallCommand
 
validateArgs(CommandLine) - Method in class alluxio.cli.fs.command.CatCommand
 
validateArgs(CommandLine) - Method in class alluxio.cli.fs.command.CheckConsistencyCommand
 
validateArgs(CommandLine) - Method in class alluxio.cli.fs.command.ChecksumCommand
 
validateArgs(CommandLine) - Method in class alluxio.cli.fs.command.ChgrpCommand
 
validateArgs(CommandLine) - Method in class alluxio.cli.fs.command.ChmodCommand
 
validateArgs(CommandLine) - Method in class alluxio.cli.fs.command.ChownCommand
 
validateArgs(CommandLine) - Method in class alluxio.cli.fs.command.CopyFromLocalCommand
 
validateArgs(CommandLine) - Method in class alluxio.cli.fs.command.CopyToLocalCommand
 
validateArgs(CommandLine) - Method in class alluxio.cli.fs.command.CountCommand
 
validateArgs(CommandLine) - Method in class alluxio.cli.fs.command.CpCommand
 
validateArgs(CommandLine) - Method in class alluxio.cli.fs.command.CreateLineageCommand
 
validateArgs(CommandLine) - Method in class alluxio.cli.fs.command.DeleteLineageCommand
 
validateArgs(CommandLine) - Method in class alluxio.cli.fs.command.DuCommand
 
validateArgs(CommandLine) - Method in class alluxio.cli.fs.command.FileInfoCommand
Deprecated.
 
validateArgs(CommandLine) - Method in class alluxio.cli.fs.command.FreeCommand
 
validateArgs(CommandLine) - Method in class alluxio.cli.fs.command.GetCapacityBytesCommand
 
validateArgs(CommandLine) - Method in class alluxio.cli.fs.command.GetUsedBytesCommand
 
validateArgs(CommandLine) - Method in class alluxio.cli.fs.command.HeadCommand
 
validateArgs(CommandLine) - Method in class alluxio.cli.fs.command.HelpCommand
 
validateArgs(CommandLine) - Method in class alluxio.cli.fs.command.LeaderCommand
 
validateArgs(CommandLine) - Method in class alluxio.cli.fs.command.ListLineagesCommand
 
validateArgs(CommandLine) - Method in class alluxio.cli.fs.command.LoadCommand
 
validateArgs(CommandLine) - Method in class alluxio.cli.fs.command.LoadMetadataCommand
Deprecated.
 
validateArgs(CommandLine) - Method in class alluxio.cli.fs.command.LocationCommand
 
validateArgs(CommandLine) - Method in class alluxio.cli.fs.command.LsCommand
 
validateArgs(CommandLine) - Method in class alluxio.cli.fs.command.MasterInfoCommand
 
validateArgs(CommandLine) - Method in class alluxio.cli.fs.command.MkdirCommand
 
validateArgs(CommandLine) - Method in class alluxio.cli.fs.command.MountCommand
 
validateArgs(CommandLine) - Method in class alluxio.cli.fs.command.MvCommand
 
validateArgs(CommandLine) - Method in class alluxio.cli.fs.command.PersistCommand
 
validateArgs(CommandLine) - Method in class alluxio.cli.fs.command.PinCommand
 
validateArgs(CommandLine) - Method in class alluxio.cli.fs.command.ReportCommand
 
validateArgs(CommandLine) - Method in class alluxio.cli.fs.command.RmCommand
 
validateArgs(CommandLine) - Method in class alluxio.cli.fs.command.SetTtlCommand
 
validateArgs(CommandLine) - Method in class alluxio.cli.fs.command.StatCommand
 
validateArgs(CommandLine) - Method in class alluxio.cli.fs.command.TailCommand
 
validateArgs(CommandLine) - Method in class alluxio.cli.fs.command.TestCommand
 
validateArgs(CommandLine) - Method in class alluxio.cli.fs.command.TouchCommand
 
validateArgs(CommandLine) - Method in class alluxio.cli.fs.command.UnmountCommand
 
validateArgs(CommandLine) - Method in class alluxio.cli.fs.command.UnpinCommand
 
validateArgs(CommandLine) - Method in class alluxio.cli.fs.command.UnsetTtlCommand
 
validateArgs(CommandLine) - Method in class alluxio.cli.fsadmin.command.BackupCommand
 
validateArgs(CommandLine) - Method in class alluxio.cli.fsadmin.command.DoctorCommand
 
validateArgs(CommandLine) - Method in class alluxio.cli.fsadmin.command.GetBlockInfoCommand
 
validateArgs(CommandLine) - Method in class alluxio.cli.fsadmin.command.ReportCommand
 
validateArgs(CommandLine) - Method in class alluxio.cli.fsadmin.command.UfsCommand
 
validateBlocks(Function<Long, Boolean>, boolean) - Method in interface alluxio.master.block.BlockMaster
Validates the integrity of blocks with respect to the validator.
validateBlocks(Function<Long, Boolean>, boolean) - Method in class alluxio.master.block.DefaultBlockMaster
 
ValidateConf - Class in alluxio.cli
Validate the Alluxio configuration.
ValidateEnv - Class in alluxio.cli
Utility for checking Alluxio environment.
validateInodeBlocks(boolean) - Method in class alluxio.master.file.DefaultFileSystemMaster
 
validateInodeBlocks(boolean) - Method in interface alluxio.master.file.FileSystemMaster
Checks the integrity of the inodes with respect to the blocks of the system.
validateLock(long, long, long) - Method in class alluxio.worker.block.BlockLockManager
Validates the lock is hold by the given session for the given block.
validatePath(String) - Static method in class alluxio.cli.fs.FileSystemShellUtils
Validates the path, verifying that it contains the Constants.HEADER or Constants.HEADER_FT and a hostname:port specified.
validatePath(String) - Static method in class alluxio.underfs.BaseUnderFileSystem
Clean the path by creating a URI and turning it back to a string.
validatePath(String) - Static method in class alluxio.util.io.PathUtils
Checks if the given path is properly formed.
ValidationTask - Interface in alluxio.cli.validation
Interface for a validation task run by validateEnv command.
ValidationTask.TaskResult - Enum in alluxio.cli.validation
Result of a validation task.
VALUE_FIELD_NUMBER - Static variable in class alluxio.proto.journal.File.StringPairEntry
 
valueAsString(String) - Static method in class alluxio.util.ConfigurationUtils
 
valueOf(String) - Static method in enum alluxio.checker.CheckerUtils.Status
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum alluxio.checker.HiveIntegrationChecker.Mode
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum alluxio.cli.Format.Mode
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum alluxio.cli.validation.ValidationTask.TaskResult
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum alluxio.client.AlluxioStorageType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum alluxio.client.block.options.GetWorkerReportOptions.WorkerInfoField
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum alluxio.client.block.options.GetWorkerReportOptions.WorkerRange
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum alluxio.client.block.stream.BlockInStream.BlockInStreamSource
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum alluxio.client.lineage.LineageContext
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum alluxio.client.ReadType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum alluxio.client.UnderStorageType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum alluxio.client.WriteType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum alluxio.conf.Source.Type
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum alluxio.exception.ExceptionMessage
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum alluxio.exception.PreconditionMessage
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum alluxio.exception.status.Status
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum alluxio.master.file.meta.InodeTree.LockMode
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum alluxio.master.file.meta.PersistenceState
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum alluxio.master.file.options.DescendantType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum alluxio.master.file.StartupConsistencyCheck.Status
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum alluxio.master.journal.JournalSystem.Mode
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum alluxio.master.journal.JournalType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum alluxio.master.PrimarySelector.State
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum alluxio.master.PrimarySelectorClient.ZookeeperConnectionErrorPolicy
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum alluxio.metrics.MetricsSystem.InstanceType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum alluxio.metrics.WorkerMetrics.UfsOps
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum alluxio.multi.process.MultiProcessCluster.DeployMode
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum alluxio.network.ChannelType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum alluxio.network.protocol.RPCMessage.Type
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum alluxio.PropertyKey.ConsistencyCheckLevel
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum alluxio.PropertyKey.DisplayType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum alluxio.PropertyKey.Template
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum alluxio.proto.dataserver.Protocol.ReadResponse.Type
Returns the enum constant of this type with the specified name.
valueOf(int) - Static method in enum alluxio.proto.dataserver.Protocol.ReadResponse.Type
 
valueOf(Descriptors.EnumValueDescriptor) - Static method in enum alluxio.proto.dataserver.Protocol.ReadResponse.Type
 
valueOf(String) - Static method in enum alluxio.proto.dataserver.Protocol.RequestType
Returns the enum constant of this type with the specified name.
valueOf(int) - Static method in enum alluxio.proto.dataserver.Protocol.RequestType
 
valueOf(Descriptors.EnumValueDescriptor) - Static method in enum alluxio.proto.dataserver.Protocol.RequestType
 
valueOf(String) - Static method in enum alluxio.proto.journal.File.PTtlAction
Returns the enum constant of this type with the specified name.
valueOf(int) - Static method in enum alluxio.proto.journal.File.PTtlAction
 
valueOf(Descriptors.EnumValueDescriptor) - Static method in enum alluxio.proto.journal.File.PTtlAction
 
valueOf(String) - Static method in enum alluxio.proto.journal.File.UfsMode
Returns the enum constant of this type with the specified name.
valueOf(int) - Static method in enum alluxio.proto.journal.File.UfsMode
 
valueOf(Descriptors.EnumValueDescriptor) - Static method in enum alluxio.proto.journal.File.UfsMode
 
valueOf(String) - Static method in enum alluxio.proto.status.Status.PStatus
Returns the enum constant of this type with the specified name.
valueOf(int) - Static method in enum alluxio.proto.status.Status.PStatus
 
valueOf(Descriptors.EnumValueDescriptor) - Static method in enum alluxio.proto.status.Status.PStatus
 
valueOf(String) - Static method in enum alluxio.security.authentication.AuthType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum alluxio.security.authorization.Mode.Bits
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum alluxio.thrift.AccessBlockTOptions._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum alluxio.thrift.AccessBlockTResponse._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum alluxio.thrift.AlluxioService.getServiceVersion_args._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum alluxio.thrift.AlluxioService.getServiceVersion_result._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum alluxio.thrift.AlluxioTException._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum alluxio.thrift.BackupTOptions._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum alluxio.thrift.BackupTResponse._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum alluxio.thrift.BlockHeartbeatTOptions._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum alluxio.thrift.BlockHeartbeatTResponse._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum alluxio.thrift.BlockInfo._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum alluxio.thrift.BlockLocation._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum alluxio.thrift.BlockMasterClientService.getBlockInfo_args._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum alluxio.thrift.BlockMasterClientService.getBlockInfo_result._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum alluxio.thrift.BlockMasterClientService.getBlockMasterInfo_args._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum alluxio.thrift.BlockMasterClientService.getBlockMasterInfo_result._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum alluxio.thrift.BlockMasterClientService.getCapacityBytes_args._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum alluxio.thrift.BlockMasterClientService.getCapacityBytes_result._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum alluxio.thrift.BlockMasterClientService.getUsedBytes_args._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum alluxio.thrift.BlockMasterClientService.getUsedBytes_result._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum alluxio.thrift.BlockMasterClientService.getWorkerInfoList_args._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum alluxio.thrift.BlockMasterClientService.getWorkerInfoList_result._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum alluxio.thrift.BlockMasterClientService.getWorkerReport_args._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum alluxio.thrift.BlockMasterClientService.getWorkerReport_result._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum alluxio.thrift.BlockMasterInfo._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum alluxio.thrift.BlockMasterInfoField
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum alluxio.thrift.BlockMasterWorkerService.blockHeartbeat_args._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum alluxio.thrift.BlockMasterWorkerService.blockHeartbeat_result._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum alluxio.thrift.BlockMasterWorkerService.commitBlock_args._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum alluxio.thrift.BlockMasterWorkerService.commitBlock_result._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum alluxio.thrift.BlockMasterWorkerService.getWorkerId_args._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum alluxio.thrift.BlockMasterWorkerService.getWorkerId_result._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum alluxio.thrift.BlockMasterWorkerService.registerWorker_args._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum alluxio.thrift.BlockMasterWorkerService.registerWorker_result._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum alluxio.thrift.BlockWorkerClientService.accessBlock_args._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum alluxio.thrift.BlockWorkerClientService.accessBlock_result._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum alluxio.thrift.BlockWorkerClientService.cacheBlock_args._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum alluxio.thrift.BlockWorkerClientService.cacheBlock_result._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum alluxio.thrift.BlockWorkerClientService.cancelBlock_args._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum alluxio.thrift.BlockWorkerClientService.cancelBlock_result._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum alluxio.thrift.BlockWorkerClientService.lockBlock_args._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum alluxio.thrift.BlockWorkerClientService.lockBlock_result._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum alluxio.thrift.BlockWorkerClientService.promoteBlock_args._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum alluxio.thrift.BlockWorkerClientService.promoteBlock_result._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum alluxio.thrift.BlockWorkerClientService.removeBlock_args._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum alluxio.thrift.BlockWorkerClientService.removeBlock_result._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum alluxio.thrift.BlockWorkerClientService.requestBlockLocation_args._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum alluxio.thrift.BlockWorkerClientService.requestBlockLocation_result._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum alluxio.thrift.BlockWorkerClientService.requestSpace_args._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum alluxio.thrift.BlockWorkerClientService.requestSpace_result._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum alluxio.thrift.BlockWorkerClientService.sessionBlockHeartbeat_args._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum alluxio.thrift.BlockWorkerClientService.sessionBlockHeartbeat_result._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum alluxio.thrift.BlockWorkerClientService.unlockBlock_args._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum alluxio.thrift.BlockWorkerClientService.unlockBlock_result._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum alluxio.thrift.CacheBlockTOptions._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum alluxio.thrift.CacheBlockTResponse._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum alluxio.thrift.CancelBlockTOptions._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum alluxio.thrift.CancelBlockTResponse._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum alluxio.thrift.CancelUfsFileTOptions._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum alluxio.thrift.CancelUfsFileTResponse._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum alluxio.thrift.CheckConsistencyTOptions._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum alluxio.thrift.CheckConsistencyTResponse._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum alluxio.thrift.CloseUfsFileTOptions._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum alluxio.thrift.CloseUfsFileTResponse._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum alluxio.thrift.Command._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum alluxio.thrift.CommandLineJobInfo._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum alluxio.thrift.CommandType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum alluxio.thrift.CommitBlockTOptions._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum alluxio.thrift.CommitBlockTResponse._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum alluxio.thrift.CompleteFileTOptions._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum alluxio.thrift.CompleteFileTResponse._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum alluxio.thrift.CompletePartitionTOptions._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum alluxio.thrift.CompletePartitionTResponse._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum alluxio.thrift.CompleteStoreTOptions._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum alluxio.thrift.CompleteStoreTResponse._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum alluxio.thrift.CompleteUfsFileTOptions._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum alluxio.thrift.CompleteUfsFileTReponse._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum alluxio.thrift.ConfigCheckReport._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum alluxio.thrift.ConfigProperty._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum alluxio.thrift.ConfigStatus
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum alluxio.thrift.CreateDirectoryTOptions._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum alluxio.thrift.CreateDirectoryTResponse._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum alluxio.thrift.CreateFileTOptions._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum alluxio.thrift.CreateFileTResponse._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum alluxio.thrift.CreateLineageTOptions._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum alluxio.thrift.CreateLineageTResponse._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum alluxio.thrift.CreateStoreTOptions._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum alluxio.thrift.CreateStoreTResponse._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum alluxio.thrift.CreateUfsFileTOptions._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum alluxio.thrift.CreateUfsFileTResponse._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum alluxio.thrift.DeleteLineageTOptions._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum alluxio.thrift.DeleteLineageTResponse._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum alluxio.thrift.DeleteStoreTOptions._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum alluxio.thrift.DeleteStoreTResponse._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum alluxio.thrift.DeleteTOptions._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum alluxio.thrift.DeleteTResponse._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum alluxio.thrift.DependencyInfo._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum alluxio.thrift.FileBlockInfo._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum alluxio.thrift.FileInfo._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum alluxio.thrift.FileSystemCommand._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum alluxio.thrift.FileSystemCommandOptions._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum alluxio.thrift.FileSystemHeartbeatTOptions._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum alluxio.thrift.FileSystemHeartbeatTResponse._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum alluxio.thrift.FileSystemMasterClientService.checkConsistency_args._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum alluxio.thrift.FileSystemMasterClientService.checkConsistency_result._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum alluxio.thrift.FileSystemMasterClientService.completeFile_args._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum alluxio.thrift.FileSystemMasterClientService.completeFile_result._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum alluxio.thrift.FileSystemMasterClientService.createDirectory_args._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum alluxio.thrift.FileSystemMasterClientService.createDirectory_result._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum alluxio.thrift.FileSystemMasterClientService.createFile_args._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum alluxio.thrift.FileSystemMasterClientService.createFile_result._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum alluxio.thrift.FileSystemMasterClientService.free_args._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum alluxio.thrift.FileSystemMasterClientService.free_result._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum alluxio.thrift.FileSystemMasterClientService.getFilePath_args._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum alluxio.thrift.FileSystemMasterClientService.getFilePath_result._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum alluxio.thrift.FileSystemMasterClientService.getMountTable_args._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum alluxio.thrift.FileSystemMasterClientService.getMountTable_result._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum alluxio.thrift.FileSystemMasterClientService.getNewBlockIdForFile_args._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum alluxio.thrift.FileSystemMasterClientService.getNewBlockIdForFile_result._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum alluxio.thrift.FileSystemMasterClientService.getStatus_args._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum alluxio.thrift.FileSystemMasterClientService.getStatus_result._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum alluxio.thrift.FileSystemMasterClientService.listStatus_args._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum alluxio.thrift.FileSystemMasterClientService.listStatus_result._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum alluxio.thrift.FileSystemMasterClientService.loadMetadata_args._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum alluxio.thrift.FileSystemMasterClientService.loadMetadata_result._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum alluxio.thrift.FileSystemMasterClientService.mount_args._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum alluxio.thrift.FileSystemMasterClientService.mount_result._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum alluxio.thrift.FileSystemMasterClientService.remove_args._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum alluxio.thrift.FileSystemMasterClientService.remove_result._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum alluxio.thrift.FileSystemMasterClientService.rename_args._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum alluxio.thrift.FileSystemMasterClientService.rename_result._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum alluxio.thrift.FileSystemMasterClientService.scheduleAsyncPersistence_args._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum alluxio.thrift.FileSystemMasterClientService.scheduleAsyncPersistence_result._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum alluxio.thrift.FileSystemMasterClientService.setAttribute_args._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum alluxio.thrift.FileSystemMasterClientService.setAttribute_result._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum alluxio.thrift.FileSystemMasterClientService.unmount_args._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum alluxio.thrift.FileSystemMasterClientService.unmount_result._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum alluxio.thrift.FileSystemMasterClientService.updateUfsMode_args._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum alluxio.thrift.FileSystemMasterClientService.updateUfsMode_result._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum alluxio.thrift.FileSystemMasterCommonTOptions._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum alluxio.thrift.FileSystemMasterWorkerService.fileSystemHeartbeat_args._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum alluxio.thrift.FileSystemMasterWorkerService.fileSystemHeartbeat_result._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum alluxio.thrift.FileSystemMasterWorkerService.getFileInfo_args._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum alluxio.thrift.FileSystemMasterWorkerService.getFileInfo_result._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum alluxio.thrift.FileSystemMasterWorkerService.getPinnedFileIds_args._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum alluxio.thrift.FileSystemMasterWorkerService.getPinnedFileIds_result._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum alluxio.thrift.FileSystemMasterWorkerService.getUfsInfo_args._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum alluxio.thrift.FileSystemMasterWorkerService.getUfsInfo_result._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum alluxio.thrift.FileSystemWorkerClientService.cancelUfsFile_args._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum alluxio.thrift.FileSystemWorkerClientService.cancelUfsFile_result._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum alluxio.thrift.FileSystemWorkerClientService.closeUfsFile_args._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum alluxio.thrift.FileSystemWorkerClientService.closeUfsFile_result._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum alluxio.thrift.FileSystemWorkerClientService.completeUfsFile_args._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum alluxio.thrift.FileSystemWorkerClientService.completeUfsFile_result._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum alluxio.thrift.FileSystemWorkerClientService.createUfsFile_args._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum alluxio.thrift.FileSystemWorkerClientService.createUfsFile_result._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum alluxio.thrift.FileSystemWorkerClientService.openUfsFile_args._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum alluxio.thrift.FileSystemWorkerClientService.openUfsFile_result._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum alluxio.thrift.FileSystemWorkerClientService.sessionFileSystemHeartbeat_args._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum alluxio.thrift.FileSystemWorkerClientService.sessionFileSystemHeartbeat_result._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum alluxio.thrift.FreeTOptions._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum alluxio.thrift.FreeTResponse._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum alluxio.thrift.GetBlockInfoTOptions._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum alluxio.thrift.GetBlockInfoTResponse._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum alluxio.thrift.GetBlockMasterInfoTOptions._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum alluxio.thrift.GetBlockMasterInfoTResponse._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum alluxio.thrift.GetCapacityBytesTOptions._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum alluxio.thrift.GetCapacityBytesTResponse._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum alluxio.thrift.GetConfigReportTOptions._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum alluxio.thrift.GetConfigReportTResponse._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum alluxio.thrift.GetConfigurationTOptions._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum alluxio.thrift.GetConfigurationTResponse._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum alluxio.thrift.GetFileInfoTOptions._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum alluxio.thrift.GetFileInfoTResponse._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum alluxio.thrift.GetFilePathTOptions._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum alluxio.thrift.GetFilePathTResponse._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum alluxio.thrift.GetLineageInfoListTOptions._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum alluxio.thrift.GetLineageInfoListTResponse._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum alluxio.thrift.GetMasterIdTOptions._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum alluxio.thrift.GetMasterIdTResponse._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum alluxio.thrift.GetMasterInfoTOptions._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum alluxio.thrift.GetMasterInfoTResponse._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum alluxio.thrift.GetMetricsTOptions._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum alluxio.thrift.GetMetricsTResponse._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum alluxio.thrift.GetMountTableTResponse._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum alluxio.thrift.GetNewBlockIdForFileTOptions._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum alluxio.thrift.GetNewBlockIdForFileTResponse._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum alluxio.thrift.GetNextKeysTOptions._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum alluxio.thrift.GetNextKeysTResponse._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum alluxio.thrift.GetPartitionInfoTOptions._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum alluxio.thrift.GetPartitionInfoTResponse._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum alluxio.thrift.GetPinnedFileIdsTOptions._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum alluxio.thrift.GetPinnedFileIdsTResponse._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum alluxio.thrift.GetServiceVersionTOptions._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum alluxio.thrift.GetServiceVersionTResponse._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum alluxio.thrift.GetSizeTOptions._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum alluxio.thrift.GetSizeTResponse._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum alluxio.thrift.GetStatusTOptions._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum alluxio.thrift.GetStatusTResponse._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum alluxio.thrift.GetTOptions._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum alluxio.thrift.GetTResponse._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum alluxio.thrift.GetUfsInfoTOptions._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum alluxio.thrift.GetUfsInfoTResponse._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum alluxio.thrift.GetUsedBytesTOptions._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum alluxio.thrift.GetUsedBytesTResponse._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum alluxio.thrift.GetWorkerIdTOptions._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum alluxio.thrift.GetWorkerIdTResponse._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum alluxio.thrift.GetWorkerInfoListTOptions._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum alluxio.thrift.GetWorkerInfoListTResponse._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum alluxio.thrift.GetWorkerReportTOptions._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum alluxio.thrift.InconsistentProperty._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum alluxio.thrift.JobConfInfo._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum alluxio.thrift.KeyValueMasterClientService.completePartition_args._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum alluxio.thrift.KeyValueMasterClientService.completePartition_result._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum alluxio.thrift.KeyValueMasterClientService.completeStore_args._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum alluxio.thrift.KeyValueMasterClientService.completeStore_result._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum alluxio.thrift.KeyValueMasterClientService.createStore_args._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum alluxio.thrift.KeyValueMasterClientService.createStore_result._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum alluxio.thrift.KeyValueMasterClientService.deleteStore_args._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum alluxio.thrift.KeyValueMasterClientService.deleteStore_result._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum alluxio.thrift.KeyValueMasterClientService.getPartitionInfo_args._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum alluxio.thrift.KeyValueMasterClientService.getPartitionInfo_result._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum alluxio.thrift.KeyValueMasterClientService.mergeStore_args._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum alluxio.thrift.KeyValueMasterClientService.mergeStore_result._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum alluxio.thrift.KeyValueMasterClientService.renameStore_args._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum alluxio.thrift.KeyValueMasterClientService.renameStore_result._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum alluxio.thrift.KeyValueWorkerClientService.get_args._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum alluxio.thrift.KeyValueWorkerClientService.get_result._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum alluxio.thrift.KeyValueWorkerClientService.getNextKeys_args._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum alluxio.thrift.KeyValueWorkerClientService.getNextKeys_result._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum alluxio.thrift.KeyValueWorkerClientService.getSize_args._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum alluxio.thrift.KeyValueWorkerClientService.getSize_result._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum alluxio.thrift.LineageInfo._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum alluxio.thrift.LineageMasterClientService.createLineage_args._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum alluxio.thrift.LineageMasterClientService.createLineage_result._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum alluxio.thrift.LineageMasterClientService.deleteLineage_args._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum alluxio.thrift.LineageMasterClientService.deleteLineage_result._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum alluxio.thrift.LineageMasterClientService.getLineageInfoList_args._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum alluxio.thrift.LineageMasterClientService.getLineageInfoList_result._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum alluxio.thrift.LineageMasterClientService.reinitializeFile_args._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum alluxio.thrift.LineageMasterClientService.reinitializeFile_result._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum alluxio.thrift.LineageMasterClientService.reportLostFile_args._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum alluxio.thrift.LineageMasterClientService.reportLostFile_result._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum alluxio.thrift.ListStatusTOptions._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum alluxio.thrift.ListStatusTResponse._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum alluxio.thrift.LoadMetadataTOptions._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum alluxio.thrift.LoadMetadataTResponse._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum alluxio.thrift.LoadMetadataTType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum alluxio.thrift.LocalityTier._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum alluxio.thrift.LockBlockStatus
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum alluxio.thrift.LockBlockTOptions._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum alluxio.thrift.LockBlockTResponse._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum alluxio.thrift.MasterHeartbeatTOptions._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum alluxio.thrift.MasterHeartbeatTResponse._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum alluxio.thrift.MasterInfo._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum alluxio.thrift.MasterInfoField
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum alluxio.thrift.MasterNetAddress._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum alluxio.thrift.MergeStoreTOptions._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum alluxio.thrift.MergeStoreTResponse._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum alluxio.thrift.MetaCommand
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum alluxio.thrift.MetaMasterClientService.backup_args._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum alluxio.thrift.MetaMasterClientService.backup_result._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum alluxio.thrift.MetaMasterClientService.getConfigReport_args._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum alluxio.thrift.MetaMasterClientService.getConfigReport_result._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum alluxio.thrift.MetaMasterClientService.getConfiguration_args._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum alluxio.thrift.MetaMasterClientService.getConfiguration_result._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum alluxio.thrift.MetaMasterClientService.getMasterInfo_args._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum alluxio.thrift.MetaMasterClientService.getMasterInfo_result._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum alluxio.thrift.MetaMasterClientService.getMetrics_args._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum alluxio.thrift.MetaMasterClientService.getMetrics_result._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum alluxio.thrift.MetaMasterMasterService.getMasterId_args._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum alluxio.thrift.MetaMasterMasterService.getMasterId_result._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum alluxio.thrift.MetaMasterMasterService.masterHeartbeat_args._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum alluxio.thrift.MetaMasterMasterService.masterHeartbeat_result._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum alluxio.thrift.MetaMasterMasterService.registerMaster_args._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum alluxio.thrift.MetaMasterMasterService.registerMaster_result._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum alluxio.thrift.Metric._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum alluxio.thrift.MetricsHeartbeatTOptions._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum alluxio.thrift.MetricsHeartbeatTResponse._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum alluxio.thrift.MetricsMasterClientService.metricsHeartbeat_args._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum alluxio.thrift.MetricsMasterClientService.metricsHeartbeat_result._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum alluxio.thrift.MetricValue._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum alluxio.thrift.MountPointInfo._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum alluxio.thrift.MountTOptions._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum alluxio.thrift.MountTResponse._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum alluxio.thrift.OpenUfsFileTOptions._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum alluxio.thrift.OpenUfsFileTResponse._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum alluxio.thrift.OptionalString._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum alluxio.thrift.PartitionInfo._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum alluxio.thrift.PersistCommandOptions._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum alluxio.thrift.PersistFile._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum alluxio.thrift.PromoteBlockTOptions._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum alluxio.thrift.PromoteBlockTResponse._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum alluxio.thrift.RegisterMasterTOptions._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum alluxio.thrift.RegisterMasterTResponse._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum alluxio.thrift.RegisterWorkerTOptions._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum alluxio.thrift.RegisterWorkerTResponse._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum alluxio.thrift.ReinitializeFileTOptions._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum alluxio.thrift.ReinitializeFileTResponse._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum alluxio.thrift.RemoveBlockTOptions._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum alluxio.thrift.RemoveBlockTResponse._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum alluxio.thrift.RenameStoreTOptions._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum alluxio.thrift.RenameStoreTResponse._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum alluxio.thrift.RenameTOptions._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum alluxio.thrift.RenameTResponse._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum alluxio.thrift.ReportLostFileTOptions._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum alluxio.thrift.ReportLostFileTResponse._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum alluxio.thrift.RequestBlockLocationTOptions._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum alluxio.thrift.RequestBlockLocationTResponse._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum alluxio.thrift.RequestSpaceTOptions._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum alluxio.thrift.RequestSpaceTResponse._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum alluxio.thrift.ScheduleAsyncPersistenceTOptions._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum alluxio.thrift.ScheduleAsyncPersistenceTResponse._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum alluxio.thrift.Scope
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum alluxio.thrift.SessionBlockHeartbeatTOptions._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum alluxio.thrift.SessionBlockHeartbeatTResponse._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum alluxio.thrift.SessionFileSystemHeartbeatTOptions._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum alluxio.thrift.SessionFileSystemHeartbeatTResponse._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum alluxio.thrift.SetAttributeTOptions._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum alluxio.thrift.SetAttributeTResponse._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum alluxio.thrift.SyncMetadataTOptions._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum alluxio.thrift.SyncMetadataTResponse._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum alluxio.thrift.TieredIdentity._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum alluxio.thrift.TStatus
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum alluxio.thrift.TTtlAction
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum alluxio.thrift.UfsInfo._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum alluxio.thrift.UfsMode
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum alluxio.thrift.UnlockBlockTOptions._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum alluxio.thrift.UnlockBlockTResponse._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum alluxio.thrift.UnmountTOptions._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum alluxio.thrift.UnmountTResponse._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum alluxio.thrift.UpdateUfsModeTOptions._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum alluxio.thrift.UpdateUfsModeTResponse._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum alluxio.thrift.WorkerInfo._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum alluxio.thrift.WorkerInfoField
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum alluxio.thrift.WorkerNetAddress._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum alluxio.thrift.WorkerRange
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum alluxio.underfs.Fingerprint.Tag
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum alluxio.underfs.Fingerprint.Type
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum alluxio.underfs.UnderFileSystem.SpaceType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum alluxio.underfs.UnderFileSystem.UfsMode
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum alluxio.util.CommonUtils.ProcessType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum alluxio.util.network.NetworkAddressUtils.ServiceType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum alluxio.wire.BlockMasterInfo.BlockMasterInfoField
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum alluxio.wire.ConfigCheckReport.ConfigStatus
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum alluxio.wire.LoadMetadataType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum alluxio.wire.MasterInfo.MasterInfoField
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum alluxio.wire.Scope
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum alluxio.wire.TtlAction
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum alluxio.worker.block.BlockLockType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum alluxio.worker.block.evictor.Evictor.Mode
Returns the enum constant of this type with the specified name.
values() - Static method in enum alluxio.checker.CheckerUtils.Status
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum alluxio.checker.HiveIntegrationChecker.Mode
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum alluxio.cli.Format.Mode
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum alluxio.cli.validation.ValidationTask.TaskResult
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum alluxio.client.AlluxioStorageType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum alluxio.client.block.options.GetWorkerReportOptions.WorkerInfoField
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum alluxio.client.block.options.GetWorkerReportOptions.WorkerRange
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum alluxio.client.block.stream.BlockInStream.BlockInStreamSource
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum alluxio.client.lineage.LineageContext
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum alluxio.client.ReadType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum alluxio.client.UnderStorageType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum alluxio.client.WriteType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum alluxio.conf.Source.Type
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum alluxio.exception.ExceptionMessage
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum alluxio.exception.PreconditionMessage
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum alluxio.exception.status.Status
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum alluxio.master.file.meta.InodeTree.LockMode
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum alluxio.master.file.meta.PersistenceState
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum alluxio.master.file.options.DescendantType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum alluxio.master.file.StartupConsistencyCheck.Status
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum alluxio.master.journal.JournalSystem.Mode
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum alluxio.master.journal.JournalType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum alluxio.master.PrimarySelector.State
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum alluxio.master.PrimarySelectorClient.ZookeeperConnectionErrorPolicy
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum alluxio.metrics.MetricsSystem.InstanceType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum alluxio.metrics.WorkerMetrics.UfsOps
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum alluxio.multi.process.MultiProcessCluster.DeployMode
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum alluxio.network.ChannelType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum alluxio.network.protocol.RPCMessage.Type
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum alluxio.PropertyKey.ConsistencyCheckLevel
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum alluxio.PropertyKey.DisplayType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum alluxio.PropertyKey.Template
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum alluxio.proto.dataserver.Protocol.ReadResponse.Type
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum alluxio.proto.dataserver.Protocol.RequestType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum alluxio.proto.journal.File.PTtlAction
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum alluxio.proto.journal.File.UfsMode
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum alluxio.proto.status.Status.PStatus
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum alluxio.security.authentication.AuthType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum alluxio.security.authorization.Mode.Bits
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum alluxio.thrift.AccessBlockTOptions._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum alluxio.thrift.AccessBlockTResponse._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum alluxio.thrift.AlluxioService.getServiceVersion_args._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum alluxio.thrift.AlluxioService.getServiceVersion_result._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum alluxio.thrift.AlluxioTException._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum alluxio.thrift.BackupTOptions._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum alluxio.thrift.BackupTResponse._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum alluxio.thrift.BlockHeartbeatTOptions._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum alluxio.thrift.BlockHeartbeatTResponse._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum alluxio.thrift.BlockInfo._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum alluxio.thrift.BlockLocation._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum alluxio.thrift.BlockMasterClientService.getBlockInfo_args._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum alluxio.thrift.BlockMasterClientService.getBlockInfo_result._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum alluxio.thrift.BlockMasterClientService.getBlockMasterInfo_args._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum alluxio.thrift.BlockMasterClientService.getBlockMasterInfo_result._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum alluxio.thrift.BlockMasterClientService.getCapacityBytes_args._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum alluxio.thrift.BlockMasterClientService.getCapacityBytes_result._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum alluxio.thrift.BlockMasterClientService.getUsedBytes_args._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum alluxio.thrift.BlockMasterClientService.getUsedBytes_result._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum alluxio.thrift.BlockMasterClientService.getWorkerInfoList_args._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum alluxio.thrift.BlockMasterClientService.getWorkerInfoList_result._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum alluxio.thrift.BlockMasterClientService.getWorkerReport_args._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum alluxio.thrift.BlockMasterClientService.getWorkerReport_result._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum alluxio.thrift.BlockMasterInfo._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum alluxio.thrift.BlockMasterInfoField
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum alluxio.thrift.BlockMasterWorkerService.blockHeartbeat_args._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum alluxio.thrift.BlockMasterWorkerService.blockHeartbeat_result._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum alluxio.thrift.BlockMasterWorkerService.commitBlock_args._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum alluxio.thrift.BlockMasterWorkerService.commitBlock_result._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum alluxio.thrift.BlockMasterWorkerService.getWorkerId_args._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum alluxio.thrift.BlockMasterWorkerService.getWorkerId_result._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum alluxio.thrift.BlockMasterWorkerService.registerWorker_args._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum alluxio.thrift.BlockMasterWorkerService.registerWorker_result._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum alluxio.thrift.BlockWorkerClientService.accessBlock_args._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum alluxio.thrift.BlockWorkerClientService.accessBlock_result._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum alluxio.thrift.BlockWorkerClientService.cacheBlock_args._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum alluxio.thrift.BlockWorkerClientService.cacheBlock_result._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum alluxio.thrift.BlockWorkerClientService.cancelBlock_args._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum alluxio.thrift.BlockWorkerClientService.cancelBlock_result._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum alluxio.thrift.BlockWorkerClientService.lockBlock_args._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum alluxio.thrift.BlockWorkerClientService.lockBlock_result._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum alluxio.thrift.BlockWorkerClientService.promoteBlock_args._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum alluxio.thrift.BlockWorkerClientService.promoteBlock_result._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum alluxio.thrift.BlockWorkerClientService.removeBlock_args._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum alluxio.thrift.BlockWorkerClientService.removeBlock_result._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum alluxio.thrift.BlockWorkerClientService.requestBlockLocation_args._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum alluxio.thrift.BlockWorkerClientService.requestBlockLocation_result._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum alluxio.thrift.BlockWorkerClientService.requestSpace_args._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum alluxio.thrift.BlockWorkerClientService.requestSpace_result._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum alluxio.thrift.BlockWorkerClientService.sessionBlockHeartbeat_args._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum alluxio.thrift.BlockWorkerClientService.sessionBlockHeartbeat_result._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum alluxio.thrift.BlockWorkerClientService.unlockBlock_args._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum alluxio.thrift.BlockWorkerClientService.unlockBlock_result._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum alluxio.thrift.CacheBlockTOptions._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum alluxio.thrift.CacheBlockTResponse._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum alluxio.thrift.CancelBlockTOptions._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum alluxio.thrift.CancelBlockTResponse._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum alluxio.thrift.CancelUfsFileTOptions._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum alluxio.thrift.CancelUfsFileTResponse._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum alluxio.thrift.CheckConsistencyTOptions._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum alluxio.thrift.CheckConsistencyTResponse._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum alluxio.thrift.CloseUfsFileTOptions._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum alluxio.thrift.CloseUfsFileTResponse._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum alluxio.thrift.Command._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum alluxio.thrift.CommandLineJobInfo._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum alluxio.thrift.CommandType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum alluxio.thrift.CommitBlockTOptions._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum alluxio.thrift.CommitBlockTResponse._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum alluxio.thrift.CompleteFileTOptions._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum alluxio.thrift.CompleteFileTResponse._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum alluxio.thrift.CompletePartitionTOptions._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum alluxio.thrift.CompletePartitionTResponse._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum alluxio.thrift.CompleteStoreTOptions._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum alluxio.thrift.CompleteStoreTResponse._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum alluxio.thrift.CompleteUfsFileTOptions._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum alluxio.thrift.CompleteUfsFileTReponse._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum alluxio.thrift.ConfigCheckReport._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum alluxio.thrift.ConfigProperty._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum alluxio.thrift.ConfigStatus
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum alluxio.thrift.CreateDirectoryTOptions._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum alluxio.thrift.CreateDirectoryTResponse._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum alluxio.thrift.CreateFileTOptions._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum alluxio.thrift.CreateFileTResponse._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum alluxio.thrift.CreateLineageTOptions._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum alluxio.thrift.CreateLineageTResponse._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum alluxio.thrift.CreateStoreTOptions._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum alluxio.thrift.CreateStoreTResponse._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum alluxio.thrift.CreateUfsFileTOptions._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum alluxio.thrift.CreateUfsFileTResponse._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum alluxio.thrift.DeleteLineageTOptions._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum alluxio.thrift.DeleteLineageTResponse._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum alluxio.thrift.DeleteStoreTOptions._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum alluxio.thrift.DeleteStoreTResponse._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum alluxio.thrift.DeleteTOptions._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum alluxio.thrift.DeleteTResponse._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum alluxio.thrift.DependencyInfo._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum alluxio.thrift.FileBlockInfo._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum alluxio.thrift.FileInfo._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum alluxio.thrift.FileSystemCommand._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum alluxio.thrift.FileSystemCommandOptions._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum alluxio.thrift.FileSystemHeartbeatTOptions._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum alluxio.thrift.FileSystemHeartbeatTResponse._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum alluxio.thrift.FileSystemMasterClientService.checkConsistency_args._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum alluxio.thrift.FileSystemMasterClientService.checkConsistency_result._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum alluxio.thrift.FileSystemMasterClientService.completeFile_args._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum alluxio.thrift.FileSystemMasterClientService.completeFile_result._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum alluxio.thrift.FileSystemMasterClientService.createDirectory_args._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum alluxio.thrift.FileSystemMasterClientService.createDirectory_result._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum alluxio.thrift.FileSystemMasterClientService.createFile_args._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum alluxio.thrift.FileSystemMasterClientService.createFile_result._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum alluxio.thrift.FileSystemMasterClientService.free_args._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum alluxio.thrift.FileSystemMasterClientService.free_result._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum alluxio.thrift.FileSystemMasterClientService.getFilePath_args._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum alluxio.thrift.FileSystemMasterClientService.getFilePath_result._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum alluxio.thrift.FileSystemMasterClientService.getMountTable_args._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum alluxio.thrift.FileSystemMasterClientService.getMountTable_result._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum alluxio.thrift.FileSystemMasterClientService.getNewBlockIdForFile_args._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum alluxio.thrift.FileSystemMasterClientService.getNewBlockIdForFile_result._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum alluxio.thrift.FileSystemMasterClientService.getStatus_args._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum alluxio.thrift.FileSystemMasterClientService.getStatus_result._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum alluxio.thrift.FileSystemMasterClientService.listStatus_args._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum alluxio.thrift.FileSystemMasterClientService.listStatus_result._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum alluxio.thrift.FileSystemMasterClientService.loadMetadata_args._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum alluxio.thrift.FileSystemMasterClientService.loadMetadata_result._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum alluxio.thrift.FileSystemMasterClientService.mount_args._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum alluxio.thrift.FileSystemMasterClientService.mount_result._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum alluxio.thrift.FileSystemMasterClientService.remove_args._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum alluxio.thrift.FileSystemMasterClientService.remove_result._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum alluxio.thrift.FileSystemMasterClientService.rename_args._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum alluxio.thrift.FileSystemMasterClientService.rename_result._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum alluxio.thrift.FileSystemMasterClientService.scheduleAsyncPersistence_args._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum alluxio.thrift.FileSystemMasterClientService.scheduleAsyncPersistence_result._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum alluxio.thrift.FileSystemMasterClientService.setAttribute_args._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum alluxio.thrift.FileSystemMasterClientService.setAttribute_result._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum alluxio.thrift.FileSystemMasterClientService.unmount_args._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum alluxio.thrift.FileSystemMasterClientService.unmount_result._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum alluxio.thrift.FileSystemMasterClientService.updateUfsMode_args._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum alluxio.thrift.FileSystemMasterClientService.updateUfsMode_result._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum alluxio.thrift.FileSystemMasterCommonTOptions._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum alluxio.thrift.FileSystemMasterWorkerService.fileSystemHeartbeat_args._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum alluxio.thrift.FileSystemMasterWorkerService.fileSystemHeartbeat_result._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum alluxio.thrift.FileSystemMasterWorkerService.getFileInfo_args._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum alluxio.thrift.FileSystemMasterWorkerService.getFileInfo_result._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum alluxio.thrift.FileSystemMasterWorkerService.getPinnedFileIds_args._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum alluxio.thrift.FileSystemMasterWorkerService.getPinnedFileIds_result._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum alluxio.thrift.FileSystemMasterWorkerService.getUfsInfo_args._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum alluxio.thrift.FileSystemMasterWorkerService.getUfsInfo_result._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum alluxio.thrift.FileSystemWorkerClientService.cancelUfsFile_args._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum alluxio.thrift.FileSystemWorkerClientService.cancelUfsFile_result._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum alluxio.thrift.FileSystemWorkerClientService.closeUfsFile_args._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum alluxio.thrift.FileSystemWorkerClientService.closeUfsFile_result._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum alluxio.thrift.FileSystemWorkerClientService.completeUfsFile_args._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum alluxio.thrift.FileSystemWorkerClientService.completeUfsFile_result._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum alluxio.thrift.FileSystemWorkerClientService.createUfsFile_args._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum alluxio.thrift.FileSystemWorkerClientService.createUfsFile_result._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum alluxio.thrift.FileSystemWorkerClientService.openUfsFile_args._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum alluxio.thrift.FileSystemWorkerClientService.openUfsFile_result._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum alluxio.thrift.FileSystemWorkerClientService.sessionFileSystemHeartbeat_args._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum alluxio.thrift.FileSystemWorkerClientService.sessionFileSystemHeartbeat_result._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum alluxio.thrift.FreeTOptions._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum alluxio.thrift.FreeTResponse._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum alluxio.thrift.GetBlockInfoTOptions._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum alluxio.thrift.GetBlockInfoTResponse._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum alluxio.thrift.GetBlockMasterInfoTOptions._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum alluxio.thrift.GetBlockMasterInfoTResponse._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum alluxio.thrift.GetCapacityBytesTOptions._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum alluxio.thrift.GetCapacityBytesTResponse._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum alluxio.thrift.GetConfigReportTOptions._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum alluxio.thrift.GetConfigReportTResponse._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum alluxio.thrift.GetConfigurationTOptions._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum alluxio.thrift.GetConfigurationTResponse._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum alluxio.thrift.GetFileInfoTOptions._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum alluxio.thrift.GetFileInfoTResponse._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum alluxio.thrift.GetFilePathTOptions._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum alluxio.thrift.GetFilePathTResponse._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum alluxio.thrift.GetLineageInfoListTOptions._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum alluxio.thrift.GetLineageInfoListTResponse._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum alluxio.thrift.GetMasterIdTOptions._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum alluxio.thrift.GetMasterIdTResponse._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum alluxio.thrift.GetMasterInfoTOptions._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum alluxio.thrift.GetMasterInfoTResponse._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum alluxio.thrift.GetMetricsTOptions._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum alluxio.thrift.GetMetricsTResponse._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum alluxio.thrift.GetMountTableTResponse._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum alluxio.thrift.GetNewBlockIdForFileTOptions._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum alluxio.thrift.GetNewBlockIdForFileTResponse._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum alluxio.thrift.GetNextKeysTOptions._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum alluxio.thrift.GetNextKeysTResponse._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum alluxio.thrift.GetPartitionInfoTOptions._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum alluxio.thrift.GetPartitionInfoTResponse._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum alluxio.thrift.GetPinnedFileIdsTOptions._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum alluxio.thrift.GetPinnedFileIdsTResponse._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum alluxio.thrift.GetServiceVersionTOptions._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum alluxio.thrift.GetServiceVersionTResponse._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum alluxio.thrift.GetSizeTOptions._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum alluxio.thrift.GetSizeTResponse._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum alluxio.thrift.GetStatusTOptions._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum alluxio.thrift.GetStatusTResponse._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum alluxio.thrift.GetTOptions._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum alluxio.thrift.GetTResponse._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum alluxio.thrift.GetUfsInfoTOptions._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum alluxio.thrift.GetUfsInfoTResponse._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum alluxio.thrift.GetUsedBytesTOptions._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum alluxio.thrift.GetUsedBytesTResponse._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum alluxio.thrift.GetWorkerIdTOptions._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum alluxio.thrift.GetWorkerIdTResponse._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum alluxio.thrift.GetWorkerInfoListTOptions._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum alluxio.thrift.GetWorkerInfoListTResponse._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum alluxio.thrift.GetWorkerReportTOptions._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum alluxio.thrift.InconsistentProperty._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum alluxio.thrift.JobConfInfo._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum alluxio.thrift.KeyValueMasterClientService.completePartition_args._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum alluxio.thrift.KeyValueMasterClientService.completePartition_result._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum alluxio.thrift.KeyValueMasterClientService.completeStore_args._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum alluxio.thrift.KeyValueMasterClientService.completeStore_result._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum alluxio.thrift.KeyValueMasterClientService.createStore_args._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum alluxio.thrift.KeyValueMasterClientService.createStore_result._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum alluxio.thrift.KeyValueMasterClientService.deleteStore_args._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum alluxio.thrift.KeyValueMasterClientService.deleteStore_result._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum alluxio.thrift.KeyValueMasterClientService.getPartitionInfo_args._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum alluxio.thrift.KeyValueMasterClientService.getPartitionInfo_result._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum alluxio.thrift.KeyValueMasterClientService.mergeStore_args._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum alluxio.thrift.KeyValueMasterClientService.mergeStore_result._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum alluxio.thrift.KeyValueMasterClientService.renameStore_args._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum alluxio.thrift.KeyValueMasterClientService.renameStore_result._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum alluxio.thrift.KeyValueWorkerClientService.get_args._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum alluxio.thrift.KeyValueWorkerClientService.get_result._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum alluxio.thrift.KeyValueWorkerClientService.getNextKeys_args._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum alluxio.thrift.KeyValueWorkerClientService.getNextKeys_result._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum alluxio.thrift.KeyValueWorkerClientService.getSize_args._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum alluxio.thrift.KeyValueWorkerClientService.getSize_result._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum alluxio.thrift.LineageInfo._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum alluxio.thrift.LineageMasterClientService.createLineage_args._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum alluxio.thrift.LineageMasterClientService.createLineage_result._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum alluxio.thrift.LineageMasterClientService.deleteLineage_args._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum alluxio.thrift.LineageMasterClientService.deleteLineage_result._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum alluxio.thrift.LineageMasterClientService.getLineageInfoList_args._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum alluxio.thrift.LineageMasterClientService.getLineageInfoList_result._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum alluxio.thrift.LineageMasterClientService.reinitializeFile_args._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum alluxio.thrift.LineageMasterClientService.reinitializeFile_result._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum alluxio.thrift.LineageMasterClientService.reportLostFile_args._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum alluxio.thrift.LineageMasterClientService.reportLostFile_result._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum alluxio.thrift.ListStatusTOptions._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum alluxio.thrift.ListStatusTResponse._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum alluxio.thrift.LoadMetadataTOptions._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum alluxio.thrift.LoadMetadataTResponse._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum alluxio.thrift.LoadMetadataTType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum alluxio.thrift.LocalityTier._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum alluxio.thrift.LockBlockStatus
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum alluxio.thrift.LockBlockTOptions._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum alluxio.thrift.LockBlockTResponse._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum alluxio.thrift.MasterHeartbeatTOptions._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum alluxio.thrift.MasterHeartbeatTResponse._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum alluxio.thrift.MasterInfo._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum alluxio.thrift.MasterInfoField
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum alluxio.thrift.MasterNetAddress._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum alluxio.thrift.MergeStoreTOptions._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum alluxio.thrift.MergeStoreTResponse._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum alluxio.thrift.MetaCommand
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum alluxio.thrift.MetaMasterClientService.backup_args._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum alluxio.thrift.MetaMasterClientService.backup_result._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum alluxio.thrift.MetaMasterClientService.getConfigReport_args._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum alluxio.thrift.MetaMasterClientService.getConfigReport_result._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum alluxio.thrift.MetaMasterClientService.getConfiguration_args._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum alluxio.thrift.MetaMasterClientService.getConfiguration_result._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum alluxio.thrift.MetaMasterClientService.getMasterInfo_args._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum alluxio.thrift.MetaMasterClientService.getMasterInfo_result._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum alluxio.thrift.MetaMasterClientService.getMetrics_args._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum alluxio.thrift.MetaMasterClientService.getMetrics_result._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum alluxio.thrift.MetaMasterMasterService.getMasterId_args._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum alluxio.thrift.MetaMasterMasterService.getMasterId_result._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum alluxio.thrift.MetaMasterMasterService.masterHeartbeat_args._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum alluxio.thrift.MetaMasterMasterService.masterHeartbeat_result._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum alluxio.thrift.MetaMasterMasterService.registerMaster_args._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum alluxio.thrift.MetaMasterMasterService.registerMaster_result._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum alluxio.thrift.Metric._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum alluxio.thrift.MetricsHeartbeatTOptions._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum alluxio.thrift.MetricsHeartbeatTResponse._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum alluxio.thrift.MetricsMasterClientService.metricsHeartbeat_args._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum alluxio.thrift.MetricsMasterClientService.metricsHeartbeat_result._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum alluxio.thrift.MetricValue._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum alluxio.thrift.MountPointInfo._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum alluxio.thrift.MountTOptions._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum alluxio.thrift.MountTResponse._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum alluxio.thrift.OpenUfsFileTOptions._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum alluxio.thrift.OpenUfsFileTResponse._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum alluxio.thrift.OptionalString._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum alluxio.thrift.PartitionInfo._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum alluxio.thrift.PersistCommandOptions._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum alluxio.thrift.PersistFile._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum alluxio.thrift.PromoteBlockTOptions._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum alluxio.thrift.PromoteBlockTResponse._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum alluxio.thrift.RegisterMasterTOptions._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum alluxio.thrift.RegisterMasterTResponse._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum alluxio.thrift.RegisterWorkerTOptions._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum alluxio.thrift.RegisterWorkerTResponse._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum alluxio.thrift.ReinitializeFileTOptions._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum alluxio.thrift.ReinitializeFileTResponse._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum alluxio.thrift.RemoveBlockTOptions._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum alluxio.thrift.RemoveBlockTResponse._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum alluxio.thrift.RenameStoreTOptions._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum alluxio.thrift.RenameStoreTResponse._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum alluxio.thrift.RenameTOptions._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum alluxio.thrift.RenameTResponse._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum alluxio.thrift.ReportLostFileTOptions._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum alluxio.thrift.ReportLostFileTResponse._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum alluxio.thrift.RequestBlockLocationTOptions._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum alluxio.thrift.RequestBlockLocationTResponse._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum alluxio.thrift.RequestSpaceTOptions._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum alluxio.thrift.RequestSpaceTResponse._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum alluxio.thrift.ScheduleAsyncPersistenceTOptions._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum alluxio.thrift.ScheduleAsyncPersistenceTResponse._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum alluxio.thrift.Scope
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum alluxio.thrift.SessionBlockHeartbeatTOptions._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum alluxio.thrift.SessionBlockHeartbeatTResponse._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum alluxio.thrift.SessionFileSystemHeartbeatTOptions._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum alluxio.thrift.SessionFileSystemHeartbeatTResponse._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum alluxio.thrift.SetAttributeTOptions._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum alluxio.thrift.SetAttributeTResponse._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum alluxio.thrift.SyncMetadataTOptions._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum alluxio.thrift.SyncMetadataTResponse._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum alluxio.thrift.TieredIdentity._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum alluxio.thrift.TStatus
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum alluxio.thrift.TTtlAction
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum alluxio.thrift.UfsInfo._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum alluxio.thrift.UfsMode
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum alluxio.thrift.UnlockBlockTOptions._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum alluxio.thrift.UnlockBlockTResponse._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum alluxio.thrift.UnmountTOptions._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum alluxio.thrift.UnmountTResponse._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum alluxio.thrift.UpdateUfsModeTOptions._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum alluxio.thrift.UpdateUfsModeTResponse._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum alluxio.thrift.WorkerInfo._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum alluxio.thrift.WorkerInfoField
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum alluxio.thrift.WorkerNetAddress._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum alluxio.thrift.WorkerRange
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum alluxio.underfs.Fingerprint.Tag
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum alluxio.underfs.Fingerprint.Type
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum alluxio.underfs.UnderFileSystem.SpaceType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum alluxio.underfs.UnderFileSystem.UfsMode
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum alluxio.util.CommonUtils.ProcessType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum alluxio.util.network.NetworkAddressUtils.ServiceType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum alluxio.wire.BlockMasterInfo.BlockMasterInfoField
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum alluxio.wire.ConfigCheckReport.ConfigStatus
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum alluxio.wire.LoadMetadataType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum alluxio.wire.MasterInfo.MasterInfoField
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum alluxio.wire.Scope
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum alluxio.wire.TtlAction
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum alluxio.worker.block.BlockLockType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum alluxio.worker.block.evictor.Evictor.Mode
Returns an array containing the constants of this enum type, in the order they are declared.
Version - Class in alluxio.cli
The version of the current build.
VERSION - Static variable in class alluxio.master.journal.ufs.UfsJournal
The journal version.
VERSION - Static variable in class alluxio.ProjectConstants
 
VERSION - Static variable in class alluxio.PropertyKey.Name
 
VERSION - Static variable in class alluxio.PropertyKey
 
VERSION - Static variable in class alluxio.RuntimeConstants
The version of this Alluxio instance.
VERSION - Static variable in class alluxio.security.authentication.PlainSaslServerProvider
 

W

waitCompleted(FileSystem, AlluxioURI) - Static method in class alluxio.client.file.FileSystemUtils
Shortcut for waitCompleted(fs, uri, -1, TimeUnit.MILLISECONDS), i.e., wait for an indefinite amount of time.
waitCompleted(FileSystem, AlluxioURI, long, TimeUnit) - Static method in class alluxio.client.file.FileSystemUtils
Waits for a file to be marked as completed.
waitFor(String, Supplier<Boolean>) - Static method in class alluxio.util.CommonUtils
Waits for a condition to be satisfied.
waitFor(String, Function<Void, Boolean>) - Static method in class alluxio.util.CommonUtils
Waits for a condition to be satisfied.
waitFor(String, Function<Void, Boolean>, WaitForOptions) - Static method in class alluxio.util.CommonUtils
Waits for a condition to be satisfied.
waitForAllNodesRegistered(int) - Method in class alluxio.multi.process.MultiProcessCluster
Waits for the number of live nodes in server configuration store reached the number of nodes in this cluster and gets meta master client.
waitForAndKillPrimaryMaster(int) - Method in class alluxio.multi.process.MultiProcessCluster
Kills the primary master.
waitForNewMaster(int) - Method in class alluxio.master.MultiMasterLocalAlluxioCluster
Waits for a new master to start until a timeout occurs.
WaitForOptions - Class in alluxio.util
waitForReady(int) - Method in class alluxio.logserver.AlluxioLogServerProcess
 
waitForReady(int) - Method in class alluxio.master.AlluxioMasterProcess
 
waitForReady(int) - Method in class alluxio.master.AlluxioSecondaryMaster
 
waitForReady(Process) - Static method in class alluxio.master.TestUtils
 
waitForReady(int) - Method in interface alluxio.Process
Waits until the process is ready to serve requests.
waitForReady(int) - Method in class alluxio.proxy.AlluxioProxyProcess
 
waitForReady(int) - Method in class alluxio.worker.AlluxioWorkerProcess
 
waitForResult(String, Function<Void, T>, WaitForOptions) - Static method in class alluxio.util.CommonUtils
Waits for an operation to return a non-null value with a specified timeout.
waitForState(PrimarySelector.State) - Method in class alluxio.master.AbstractPrimarySelector
 
waitForState(PrimarySelector.State) - Method in interface alluxio.master.PrimarySelector
Blocks until the primary selector enters the specified state.
warmUpLoop() - Static method in class alluxio.util.CommonUtils
Common empty loop utility that serves the purpose of warming up the JVM before performance microbenchmarks.
warn(String) - Method in class alluxio.util.logging.SamplingLogger
 
warn(String, Object) - Method in class alluxio.util.logging.SamplingLogger
 
warn(String, Object...) - Method in class alluxio.util.logging.SamplingLogger
 
warn(String, Object, Object) - Method in class alluxio.util.logging.SamplingLogger
 
warn(String, Throwable) - Method in class alluxio.util.logging.SamplingLogger
 
warn(Marker, String) - Method in class alluxio.util.logging.SamplingLogger
 
warn(Marker, String, Object) - Method in class alluxio.util.logging.SamplingLogger
 
warn(Marker, String, Object, Object) - Method in class alluxio.util.logging.SamplingLogger
 
warn(Marker, String, Object...) - Method in class alluxio.util.logging.SamplingLogger
 
warn(Marker, String, Throwable) - Method in class alluxio.util.logging.SamplingLogger
 
WasbUnderFileSystem - Class in alluxio.underfs.wasb
An UnderFileSystem uses the Microsoft Azure Blob Storage.
WasbUnderFileSystem(AlluxioURI, UnderFileSystemConfiguration, Configuration) - Constructor for class alluxio.underfs.wasb.WasbUnderFileSystem
Constructs a new Wasb UnderFileSystem.
WasbUnderFileSystemFactory - Class in alluxio.underfs.wasb
Factory for creating WasbUnderFileSystem.
WasbUnderFileSystemFactory() - Constructor for class alluxio.underfs.wasb.WasbUnderFileSystemFactory
Constructs a new WasbUnderFileSystemFactory.
WEB_RESOURCES - Static variable in class alluxio.PropertyKey.Name
 
WEB_RESOURCES - Static variable in class alluxio.PropertyKey
 
WEB_TEMP_PATH - Static variable in class alluxio.PropertyKey.Name
 
WEB_TEMP_PATH - Static variable in class alluxio.PropertyKey
 
WEB_THREADS - Static variable in class alluxio.PropertyKey.Name
 
WEB_THREADS - Static variable in class alluxio.PropertyKey
 
WebInterfaceAbstractMetricsServlet - Class in alluxio.web
Abstract class that provides a common method for parsing metrics data.
WebInterfaceAbstractMetricsServlet() - Constructor for class alluxio.web.WebInterfaceAbstractMetricsServlet
Creates a new instance of WebInterfaceAbstractMetricsServlet.
WebInterfaceBrowseLogsServlet - Class in alluxio.web
Servlet that provides data for browsing log files.
WebInterfaceBrowseLogsServlet(boolean) - Constructor for class alluxio.web.WebInterfaceBrowseLogsServlet
Creates a new instance of WebInterfaceBrowseLogsServlet.
WebInterfaceBrowseServlet - Class in alluxio.web
Servlet that provides data for browsing the file system.
WebInterfaceBrowseServlet(MasterProcess) - Constructor for class alluxio.web.WebInterfaceBrowseServlet
Creates a new instance of WebInterfaceBrowseServlet.
WebInterfaceConfigurationServlet - Class in alluxio.web
Servlet that provides data for displaying the system's configuration.
WebInterfaceConfigurationServlet(FileSystemMaster, MetaMaster) - Constructor for class alluxio.web.WebInterfaceConfigurationServlet
Creates a new instance of WebInterfaceConfigurationServlet.
WebInterfaceDependencyServlet - Class in alluxio.web
Servlet for dependencies, such as parent and children file names in the web interface.
WebInterfaceDependencyServlet(MasterProcess) - Constructor for class alluxio.web.WebInterfaceDependencyServlet
Creates a new instance of WebInterfaceDependencyServlet.
WebInterfaceDownloadLocalServlet - Class in alluxio.web
Servlet for downloading a local file.
WebInterfaceDownloadLocalServlet() - Constructor for class alluxio.web.WebInterfaceDownloadLocalServlet
Creates a new instance of WebInterfaceDownloadLocalServlet.
WebInterfaceDownloadServlet - Class in alluxio.web
Servlet for downloading a file.
WebInterfaceDownloadServlet(FileSystemMaster) - Constructor for class alluxio.web.WebInterfaceDownloadServlet
Creates a new instance of WebInterfaceDownloadServlet.
WebInterfaceGeneralServlet - Class in alluxio.web
Servlet that provides data for viewing the general status of the filesystem.
WebInterfaceGeneralServlet(MasterProcess) - Constructor for class alluxio.web.WebInterfaceGeneralServlet
Creates a new instance of WebInterfaceGeneralServlet.
WebInterfaceGeneralServlet.StorageTierInfo - Class in alluxio.web
Class to make referencing tiered storage information more intuitive.
WebInterfaceHeaderServlet - Class in alluxio.web
Servlet that provides data for the header navigation bar.
WebInterfaceHeaderServlet() - Constructor for class alluxio.web.WebInterfaceHeaderServlet
Creates a new instance of WebInterfaceHeaderServlet.
WebInterfaceMasterMetricsServlet - Class in alluxio.web
Servlet that provides data for viewing the master metrics values.
WebInterfaceMasterMetricsServlet() - Constructor for class alluxio.web.WebInterfaceMasterMetricsServlet
WebInterfaceMemoryServlet - Class in alluxio.web
Servlet that provides data for displaying which files are currently in memory.
WebInterfaceMemoryServlet(MasterProcess) - Constructor for class alluxio.web.WebInterfaceMemoryServlet
Creates a new instance of WebInterfaceMemoryServlet.
WebInterfaceWorkerBlockInfoServlet - Class in alluxio.web
Servlet that provides data for displaying block info of a worker.
WebInterfaceWorkerBlockInfoServlet(BlockWorker) - Constructor for class alluxio.web.WebInterfaceWorkerBlockInfoServlet
Creates a new instance of WebInterfaceWorkerBlockInfoServlet.
WebInterfaceWorkerGeneralServlet - Class in alluxio.web
Servlets that shows a worker's general information, including tiered storage details.
WebInterfaceWorkerGeneralServlet(BlockWorker, InetSocketAddress, long) - Constructor for class alluxio.web.WebInterfaceWorkerGeneralServlet
Creates a new instance of WebInterfaceWorkerGeneralServlet.
WebInterfaceWorkerGeneralServlet.UIStorageDir - Class in alluxio.web
Displays information about a storage directory in the UI.
WebInterfaceWorkerGeneralServlet.UIUsageOnTier - Class in alluxio.web
A wrapper class of the usage info per tier for displaying in the UI.
WebInterfaceWorkerGeneralServlet.UIWorkerInfo - Class in alluxio.web
Displays information about a worker in the UI.
WebInterfaceWorkerMetricsServlet - Class in alluxio.web
Servlet that provides data for viewing the worker metrics values.
WebInterfaceWorkerMetricsServlet() - Constructor for class alluxio.web.WebInterfaceWorkerMetricsServlet
WebInterfaceWorkersServlet - Class in alluxio.web
Servlet that provides data for displaying detail info of all workers.
WebInterfaceWorkersServlet(BlockMaster) - Constructor for class alluxio.web.WebInterfaceWorkersServlet
Creates a new instance of WebInterfaceWorkersServlet.
WebInterfaceWorkersServlet.NodeInfo - Class in alluxio.web
Class to make referencing worker nodes more intuitive.
WebServer - Class in alluxio.web
Class that bootstraps and starts a web server.
WebServer(String, InetSocketAddress) - Constructor for class alluxio.web.WebServer
Creates a new instance of WebServer.
WILDCARD - Static variable in class alluxio.AlluxioURI
 
WILDCARD_ADDRESS - Static variable in class alluxio.util.network.NetworkAddressUtils
 
WINDOWS - Static variable in class alluxio.util.network.NetworkAddressUtils
Checks if the underlying OS is Windows.
withAlluxioMasterName(String) - Method in class alluxio.master.MasterHealthCheckClient.Builder
 
withInitialSleep(Duration) - Method in class alluxio.retry.ExponentialTimeBoundedRetry.Builder
 
withMasterInquireClient(MasterInquireClient) - Method in class alluxio.master.MasterClientConfig
 
withMaxDuration(Duration) - Method in class alluxio.retry.ExponentialTimeBoundedRetry.Builder
 
withMaxSleep(Duration) - Method in class alluxio.retry.ExponentialTimeBoundedRetry.Builder
 
withProcessCheck(boolean) - Method in class alluxio.master.MasterHealthCheckClient.Builder
 
withSubject(Subject) - Method in class alluxio.master.MasterClientConfig
 
withTimeCtx(TimeContext) - Method in class alluxio.retry.ExponentialTimeBoundedRetry.Builder
 
withZone(ZoneId) - Method in class alluxio.clock.ElapsedTimeClock
 
withZone(ZoneId) - Method in class alluxio.clock.SystemClock
 
WORK_DIR - Static variable in class alluxio.PropertyKey.Name
 
WORK_DIR - Static variable in class alluxio.PropertyKey
 
Worker(int, int, int, ByteBuffer) - Constructor for class alluxio.examples.Performance.Worker
 
Worker - Class in alluxio.multi.process
Class for running and interacting with an Alluxio worker in a separate process.
Worker(File, Map<PropertyKey, String>) - Constructor for class alluxio.multi.process.Worker
 
Worker - Interface in alluxio.worker
Interface of an Alluxio worker.
WORKER_ALLOCATOR_CLASS - Static variable in class alluxio.PropertyKey.Name
 
WORKER_ALLOCATOR_CLASS - Static variable in class alluxio.PropertyKey
 
WORKER_BIND_HOST - Static variable in class alluxio.PropertyKey.Name
 
WORKER_BIND_HOST - Static variable in class alluxio.PropertyKey
 
WORKER_BLOCK_HEARTBEAT_INTERVAL_MS - Static variable in class alluxio.PropertyKey.Name
 
WORKER_BLOCK_HEARTBEAT_INTERVAL_MS - Static variable in class alluxio.PropertyKey
 
WORKER_BLOCK_HEARTBEAT_TIMEOUT_MS - Static variable in class alluxio.PropertyKey.Name
 
WORKER_BLOCK_HEARTBEAT_TIMEOUT_MS - Static variable in class alluxio.PropertyKey
 
WORKER_BLOCK_MASTER_CLIENT_POOL_SIZE - Static variable in class alluxio.PropertyKey.Name
 
WORKER_BLOCK_MASTER_CLIENT_POOL_SIZE - Static variable in class alluxio.PropertyKey
 
WORKER_BLOCK_SYNC - Static variable in class alluxio.heartbeat.HeartbeatContext
 
WORKER_BLOCK_THREADS_MAX - Static variable in class alluxio.PropertyKey.Name
 
WORKER_BLOCK_THREADS_MAX - Static variable in class alluxio.PropertyKey
 
WORKER_BLOCK_THREADS_MIN - Static variable in class alluxio.PropertyKey.Name
 
WORKER_BLOCK_THREADS_MIN - Static variable in class alluxio.PropertyKey
 
WORKER_CHANNEL_TYPE - Static variable in class alluxio.util.network.NettyUtils
 
WORKER_CLIENT - Static variable in class alluxio.heartbeat.HeartbeatContext
 
WORKER_DATA_BIND_HOST - Static variable in class alluxio.PropertyKey.Name
 
WORKER_DATA_BIND_HOST - Static variable in class alluxio.PropertyKey
 
WORKER_DATA_FOLDER - Static variable in class alluxio.PropertyKey.Name
 
WORKER_DATA_FOLDER - Static variable in class alluxio.PropertyKey
 
WORKER_DATA_FOLDER_PERMISSIONS - Static variable in class alluxio.PropertyKey.Name
 
WORKER_DATA_FOLDER_PERMISSIONS - Static variable in class alluxio.PropertyKey
 
WORKER_DATA_HOSTNAME - Static variable in class alluxio.PropertyKey.Name
 
WORKER_DATA_HOSTNAME - Static variable in class alluxio.PropertyKey
 
WORKER_DATA_PORT - Static variable in class alluxio.PropertyKey.Name
 
WORKER_DATA_PORT - Static variable in class alluxio.PropertyKey
 
WORKER_DATA_SERVER_CLASS - Static variable in class alluxio.PropertyKey.Name
 
WORKER_DATA_SERVER_CLASS - Static variable in class alluxio.PropertyKey
 
WORKER_DATA_SERVER_DOMAIN_SOCKET_ADDRESS - Static variable in class alluxio.PropertyKey.Name
 
WORKER_DATA_SERVER_DOMAIN_SOCKET_ADDRESS - Static variable in class alluxio.PropertyKey
 
WORKER_DATA_SERVER_DOMAIN_SOCKET_AS_UUID - Static variable in class alluxio.PropertyKey.Name
 
WORKER_DATA_SERVER_DOMAIN_SOCKET_AS_UUID - Static variable in class alluxio.PropertyKey
 
WORKER_DATA_TMP_FOLDER - Static variable in class alluxio.PropertyKey.Name
 
WORKER_DATA_TMP_FOLDER - Static variable in class alluxio.PropertyKey
 
WORKER_DATA_TMP_SUBDIR_MAX - Static variable in class alluxio.PropertyKey.Name
 
WORKER_DATA_TMP_SUBDIR_MAX - Static variable in class alluxio.PropertyKey
 
WORKER_EVICTOR_CLASS - Static variable in class alluxio.PropertyKey.Name
 
WORKER_EVICTOR_CLASS - Static variable in class alluxio.PropertyKey
 
WORKER_EVICTOR_LRFU_ATTENUATION_FACTOR - Static variable in class alluxio.PropertyKey.Name
 
WORKER_EVICTOR_LRFU_ATTENUATION_FACTOR - Static variable in class alluxio.PropertyKey
 
WORKER_EVICTOR_LRFU_STEP_FACTOR - Static variable in class alluxio.PropertyKey.Name
 
WORKER_EVICTOR_LRFU_STEP_FACTOR - Static variable in class alluxio.PropertyKey
 
WORKER_FILE_BUFFER_SIZE - Static variable in class alluxio.PropertyKey.Name
 
WORKER_FILE_BUFFER_SIZE - Static variable in class alluxio.PropertyKey
 
WORKER_FILE_PERSIST_POOL_SIZE - Static variable in class alluxio.PropertyKey.Name
 
WORKER_FILE_PERSIST_POOL_SIZE - Static variable in class alluxio.PropertyKey
 
WORKER_FILE_PERSIST_RATE_LIMIT - Static variable in class alluxio.PropertyKey.Name
 
WORKER_FILE_PERSIST_RATE_LIMIT - Static variable in class alluxio.PropertyKey
 
WORKER_FILE_PERSIST_RATE_LIMIT_ENABLED - Static variable in class alluxio.PropertyKey.Name
 
WORKER_FILE_PERSIST_RATE_LIMIT_ENABLED - Static variable in class alluxio.PropertyKey
 
WORKER_FILESYSTEM_HEARTBEAT_INTERVAL_MS - Static variable in class alluxio.PropertyKey.Name
 
WORKER_FILESYSTEM_HEARTBEAT_INTERVAL_MS - Static variable in class alluxio.PropertyKey
 
WORKER_FILESYSTEM_MASTER_SYNC - Static variable in class alluxio.heartbeat.HeartbeatContext
 
WORKER_FREE_SPACE_TIMEOUT - Static variable in class alluxio.PropertyKey.Name
 
WORKER_FREE_SPACE_TIMEOUT - Static variable in class alluxio.PropertyKey
 
WORKER_HOSTNAME - Static variable in class alluxio.PropertyKey.Name
 
WORKER_HOSTNAME - Static variable in class alluxio.PropertyKey
 
WORKER_JVM_MONITOR_ENABLED - Static variable in class alluxio.PropertyKey.Name
 
WORKER_JVM_MONITOR_ENABLED - Static variable in class alluxio.PropertyKey
 
WORKER_KEYTAB_FILE - Static variable in class alluxio.PropertyKey.Name
 
WORKER_KEYTAB_FILE - Static variable in class alluxio.PropertyKey
 
WORKER_MASTER_CONNECT_RETRY_TIMEOUT - Static variable in class alluxio.PropertyKey.Name
 
WORKER_MASTER_CONNECT_RETRY_TIMEOUT - Static variable in class alluxio.PropertyKey
 
WORKER_MEMORY_SIZE - Static variable in class alluxio.PropertyKey.Name
 
WORKER_MEMORY_SIZE - Static variable in class alluxio.PropertyKey
 
WORKER_NETWORK_NETTY_ASYNC_CACHE_MANAGER_THREADS_MAX - Static variable in class alluxio.PropertyKey.Name
 
WORKER_NETWORK_NETTY_ASYNC_CACHE_MANAGER_THREADS_MAX - Static variable in class alluxio.PropertyKey
 
WORKER_NETWORK_NETTY_BACKLOG - Static variable in class alluxio.PropertyKey.Name
 
WORKER_NETWORK_NETTY_BACKLOG - Static variable in class alluxio.PropertyKey
 
WORKER_NETWORK_NETTY_BLOCK_READER_THREADS_MAX - Static variable in class alluxio.PropertyKey.Name
 
WORKER_NETWORK_NETTY_BLOCK_READER_THREADS_MAX - Static variable in class alluxio.PropertyKey
 
WORKER_NETWORK_NETTY_BLOCK_WRITER_THREADS_MAX - Static variable in class alluxio.PropertyKey.Name
 
WORKER_NETWORK_NETTY_BLOCK_WRITER_THREADS_MAX - Static variable in class alluxio.PropertyKey
 
WORKER_NETWORK_NETTY_BOSS_THREADS - Static variable in class alluxio.PropertyKey.Name
 
WORKER_NETWORK_NETTY_BOSS_THREADS - Static variable in class alluxio.PropertyKey
 
WORKER_NETWORK_NETTY_BUFFER_RECEIVE - Static variable in class alluxio.PropertyKey.Name
 
WORKER_NETWORK_NETTY_BUFFER_RECEIVE - Static variable in class alluxio.PropertyKey
 
WORKER_NETWORK_NETTY_BUFFER_SEND - Static variable in class alluxio.PropertyKey.Name
 
WORKER_NETWORK_NETTY_BUFFER_SEND - Static variable in class alluxio.PropertyKey
 
WORKER_NETWORK_NETTY_CHANNEL - Static variable in class alluxio.PropertyKey.Name
 
WORKER_NETWORK_NETTY_CHANNEL - Static variable in class alluxio.PropertyKey
 
WORKER_NETWORK_NETTY_FILE_READER_THREADS_MAX - Static variable in class alluxio.PropertyKey.Name
 
WORKER_NETWORK_NETTY_FILE_TRANSFER_TYPE - Static variable in class alluxio.PropertyKey.Name
 
WORKER_NETWORK_NETTY_FILE_TRANSFER_TYPE - Static variable in class alluxio.PropertyKey
 
WORKER_NETWORK_NETTY_FILE_WRITER_THREADS_MAX - Static variable in class alluxio.PropertyKey.Name
 
WORKER_NETWORK_NETTY_FILE_WRITER_THREADS_MAX - Static variable in class alluxio.PropertyKey
 
WORKER_NETWORK_NETTY_READER_BUFFER_SIZE_PACKETS - Static variable in class alluxio.PropertyKey.Name
 
WORKER_NETWORK_NETTY_READER_BUFFER_SIZE_PACKETS - Static variable in class alluxio.PropertyKey
 
WORKER_NETWORK_NETTY_RPC_THREADS_MAX - Static variable in class alluxio.PropertyKey.Name
 
WORKER_NETWORK_NETTY_RPC_THREADS_MAX - Static variable in class alluxio.PropertyKey
 
WORKER_NETWORK_NETTY_SHUTDOWN_QUIET_PERIOD - Static variable in class alluxio.PropertyKey.Name
 
WORKER_NETWORK_NETTY_SHUTDOWN_QUIET_PERIOD - Static variable in class alluxio.PropertyKey
 
WORKER_NETWORK_NETTY_SHUTDOWN_TIMEOUT - Static variable in class alluxio.PropertyKey.Name
 
WORKER_NETWORK_NETTY_SHUTDOWN_TIMEOUT - Static variable in class alluxio.PropertyKey
 
WORKER_NETWORK_NETTY_WATERMARK_HIGH - Static variable in class alluxio.PropertyKey.Name
 
WORKER_NETWORK_NETTY_WATERMARK_HIGH - Static variable in class alluxio.PropertyKey
 
WORKER_NETWORK_NETTY_WATERMARK_LOW - Static variable in class alluxio.PropertyKey.Name
 
WORKER_NETWORK_NETTY_WATERMARK_LOW - Static variable in class alluxio.PropertyKey
 
WORKER_NETWORK_NETTY_WORKER_THREADS - Static variable in class alluxio.PropertyKey.Name
 
WORKER_NETWORK_NETTY_WORKER_THREADS - Static variable in class alluxio.PropertyKey
 
WORKER_NETWORK_NETTY_WRITER_BUFFER_SIZE_PACKETS - Static variable in class alluxio.PropertyKey.Name
 
WORKER_NETWORK_NETTY_WRITER_BUFFER_SIZE_PACKETS - Static variable in class alluxio.PropertyKey
 
WORKER_PIN_LIST_SYNC - Static variable in class alluxio.heartbeat.HeartbeatContext
 
WORKER_PRINCIPAL - Static variable in class alluxio.PropertyKey.Name
 
WORKER_PRINCIPAL - Static variable in class alluxio.PropertyKey
 
WORKER_RPC_PORT - Static variable in class alluxio.PropertyKey.Name
 
WORKER_RPC_PORT - Static variable in class alluxio.PropertyKey
 
WORKER_SESSION_TIMEOUT_MS - Static variable in class alluxio.PropertyKey.Name
 
WORKER_SESSION_TIMEOUT_MS - Static variable in class alluxio.PropertyKey
 
WORKER_SPACE_RESERVER - Static variable in class alluxio.heartbeat.HeartbeatContext
 
WORKER_TIERED_STORE_BLOCK_LOCK_READERS - Static variable in class alluxio.PropertyKey.Name
 
WORKER_TIERED_STORE_BLOCK_LOCK_READERS - Static variable in class alluxio.PropertyKey
 
WORKER_TIERED_STORE_BLOCK_LOCKS - Static variable in class alluxio.PropertyKey.Name
 
WORKER_TIERED_STORE_BLOCK_LOCKS - Static variable in class alluxio.PropertyKey
 
WORKER_TIERED_STORE_LEVEL0_ALIAS - Static variable in class alluxio.PropertyKey
 
WORKER_TIERED_STORE_LEVEL0_DIRS_PATH - Static variable in class alluxio.PropertyKey
 
WORKER_TIERED_STORE_LEVEL0_DIRS_QUOTA - Static variable in class alluxio.PropertyKey
 
WORKER_TIERED_STORE_LEVEL0_HIGH_WATERMARK_RATIO - Static variable in class alluxio.PropertyKey
 
WORKER_TIERED_STORE_LEVEL0_LOW_WATERMARK_RATIO - Static variable in class alluxio.PropertyKey
 
WORKER_TIERED_STORE_LEVEL0_RESERVED_RATIO - Static variable in class alluxio.PropertyKey
Deprecated.
It will be removed in 2.0.0.
WORKER_TIERED_STORE_LEVEL1_ALIAS - Static variable in class alluxio.PropertyKey
 
WORKER_TIERED_STORE_LEVEL1_DIRS_PATH - Static variable in class alluxio.PropertyKey
 
WORKER_TIERED_STORE_LEVEL1_DIRS_QUOTA - Static variable in class alluxio.PropertyKey
 
WORKER_TIERED_STORE_LEVEL1_HIGH_WATERMARK_RATIO - Static variable in class alluxio.PropertyKey
 
WORKER_TIERED_STORE_LEVEL1_LOW_WATERMARK_RATIO - Static variable in class alluxio.PropertyKey
 
WORKER_TIERED_STORE_LEVEL1_RESERVED_RATIO - Static variable in class alluxio.PropertyKey
Deprecated.
It will be removed in 2.0.0.
WORKER_TIERED_STORE_LEVEL2_ALIAS - Static variable in class alluxio.PropertyKey
 
WORKER_TIERED_STORE_LEVEL2_DIRS_PATH - Static variable in class alluxio.PropertyKey
 
WORKER_TIERED_STORE_LEVEL2_DIRS_QUOTA - Static variable in class alluxio.PropertyKey
 
WORKER_TIERED_STORE_LEVEL2_HIGH_WATERMARK_RATIO - Static variable in class alluxio.PropertyKey
 
WORKER_TIERED_STORE_LEVEL2_LOW_WATERMARK_RATIO - Static variable in class alluxio.PropertyKey
 
WORKER_TIERED_STORE_LEVEL2_RESERVED_RATIO - Static variable in class alluxio.PropertyKey
Deprecated.
It will be removed in 2.0.0.
WORKER_TIERED_STORE_LEVELS - Static variable in class alluxio.PropertyKey.Name
 
WORKER_TIERED_STORE_LEVELS - Static variable in class alluxio.PropertyKey
 
WORKER_TIERED_STORE_RESERVER_ENABLED - Static variable in class alluxio.PropertyKey.Name
 
WORKER_TIERED_STORE_RESERVER_ENABLED - Static variable in class alluxio.PropertyKey
 
WORKER_TIERED_STORE_RESERVER_INTERVAL_MS - Static variable in class alluxio.PropertyKey.Name
 
WORKER_TIERED_STORE_RESERVER_INTERVAL_MS - Static variable in class alluxio.PropertyKey
 
WORKER_TIERED_STORE_RETRY - Static variable in class alluxio.PropertyKey.Name
 
WORKER_TIERED_STORE_RETRY - Static variable in class alluxio.PropertyKey
 
WORKER_UFS_BLOCK_OPEN_TIMEOUT_MS - Static variable in class alluxio.PropertyKey.Name
 
WORKER_UFS_BLOCK_OPEN_TIMEOUT_MS - Static variable in class alluxio.PropertyKey
 
WORKER_UFS_INSTREAM_CACHE_ENABLED - Static variable in class alluxio.PropertyKey.Name
 
WORKER_UFS_INSTREAM_CACHE_ENABLED - Static variable in class alluxio.PropertyKey
 
WORKER_UFS_INSTREAM_CACHE_EXPIRARTION_TIME - Static variable in class alluxio.PropertyKey
 
WORKER_UFS_INSTREAM_CACHE_EXPIRATION_TIME - Static variable in class alluxio.PropertyKey.Name
 
WORKER_UFS_INSTREAM_CACHE_MAX_SIZE - Static variable in class alluxio.PropertyKey.Name
 
WORKER_UFS_INSTREAM_CACHE_MAX_SIZE - Static variable in class alluxio.PropertyKey
 
WORKER_WEB_BIND_HOST - Static variable in class alluxio.PropertyKey.Name
 
WORKER_WEB_BIND_HOST - Static variable in class alluxio.PropertyKey
 
WORKER_WEB_HOSTNAME - Static variable in class alluxio.PropertyKey.Name
 
WORKER_WEB_HOSTNAME - Static variable in class alluxio.PropertyKey
 
WORKER_WEB_PORT - Static variable in class alluxio.PropertyKey.Name
 
WORKER_WEB_PORT - Static variable in class alluxio.PropertyKey
 
WorkerFactory - Interface in alluxio.worker
Interface for factory of Worker.
WorkerHealthCheckClient - Class in alluxio.worker
WorkerHealthCheckClient check if worker is serving RPC.
WorkerHealthCheckClient(InetSocketAddress, Supplier<RetryPolicy>) - Constructor for class alluxio.worker.WorkerHealthCheckClient
Creates a worker health check client.
workerHeartbeat(long, Map<String, Long>, List<Long>, Map<String, List<Long>>, List<Metric>) - Method in interface alluxio.master.block.BlockMaster
Updates metadata when a worker periodically heartbeats with the master.
workerHeartbeat(long, Map<String, Long>, List<Long>, Map<String, List<Long>>, List<Metric>) - Method in class alluxio.master.block.DefaultBlockMaster
 
workerHeartbeat(long, List<Long>, WorkerHeartbeatOptions) - Method in class alluxio.master.file.DefaultFileSystemMaster
 
workerHeartbeat(long, List<Long>, WorkerHeartbeatOptions) - Method in interface alluxio.master.file.FileSystemMaster
Instructs a worker to persist the files.
workerHeartbeat(String, List<Metric>) - Method in class alluxio.master.metrics.DefaultMetricsMaster
 
workerHeartbeat(String, List<Metric>) - Method in interface alluxio.master.metrics.MetricsMaster
Handles the worker heartbeat and puts the metrics from an instance with a hostname.
WorkerHeartbeatOptions - Class in alluxio.master.file.options
Method options for the worker to master heartbeat.
WorkerHeartbeatOptions(FileSystemHeartbeatTOptions) - Constructor for class alluxio.master.file.options.WorkerHeartbeatOptions
Constructs an instance of WorkerHeartbeatOptions from FileSystemHeartbeatTOptions.
WorkerInfo - Class in alluxio.thrift
 
WorkerInfo() - Constructor for class alluxio.thrift.WorkerInfo
 
WorkerInfo(long, WorkerNetAddress, int, String, long, long, long, Map<String, Long>, Map<String, Long>) - Constructor for class alluxio.thrift.WorkerInfo
 
WorkerInfo(WorkerInfo) - Constructor for class alluxio.thrift.WorkerInfo
Performs a deep copy on other.
WorkerInfo - Class in alluxio.wire
The worker information.
WorkerInfo() - Constructor for class alluxio.wire.WorkerInfo
Creates a new instance of WorkerInfo.
WorkerInfo._Fields - Enum in alluxio.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
WorkerInfo.LastContactSecComparator - Class in alluxio.wire
Determine order from most recently contacted to least recently contacted.
WorkerInfoField - Enum in alluxio.thrift
 
WorkerMetrics - Class in alluxio.metrics
Metrics of an Alluxio worker.
WorkerMetrics.UfsOps - Enum in alluxio.metrics
The list of under filesystem operations.
WorkerNetAddress - Class in alluxio.thrift
 
WorkerNetAddress() - Constructor for class alluxio.thrift.WorkerNetAddress
 
WorkerNetAddress(String, int, int, int, String, TieredIdentity) - Constructor for class alluxio.thrift.WorkerNetAddress
 
WorkerNetAddress(WorkerNetAddress) - Constructor for class alluxio.thrift.WorkerNetAddress
Performs a deep copy on other.
WorkerNetAddress - Class in alluxio.wire
The network address of a worker.
WorkerNetAddress() - Constructor for class alluxio.wire.WorkerNetAddress
Creates a new instance of WorkerNetAddress.
WorkerNetAddress._Fields - Enum in alluxio.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
WorkerOutOfSpaceException - Exception in alluxio.exception
The exception thrown when a worker is out of space.
WorkerOutOfSpaceException(String) - Constructor for exception alluxio.exception.WorkerOutOfSpaceException
Constructs a new exception with the specified detail message.
WorkerOutOfSpaceException(String, Throwable) - Constructor for exception alluxio.exception.WorkerOutOfSpaceException
Constructs a new exception with the specified detail message and cause.
WorkerOutOfSpaceException(ExceptionMessage, Object...) - Constructor for exception alluxio.exception.WorkerOutOfSpaceException
Constructs a new exception with the specified exception message and multiple parameters.
WorkerOutOfSpaceException(ExceptionMessage, Throwable, Object...) - Constructor for exception alluxio.exception.WorkerOutOfSpaceException
Constructs a new exception with the specified exception message, the cause and multiple parameters.
WorkerProcess - Interface in alluxio.worker
A worker in the Alluxio system.
WorkerProcess.Factory - Class in alluxio.worker
Factory for creating WorkerProcess.
WorkerRange - Enum in alluxio.thrift
 
workerRegister(long, List<String>, Map<String, Long>, Map<String, Long>, Map<String, List<Long>>, RegisterWorkerTOptions) - Method in interface alluxio.master.block.BlockMaster
Updates metadata when a worker registers with the master.
workerRegister(long, List<String>, Map<String, Long>, Map<String, Long>, Map<String, List<Long>>, RegisterWorkerTOptions) - Method in class alluxio.master.block.DefaultBlockMaster
 
WorkerRegistry - Class in alluxio.worker
A worker registry.
WorkerRegistry() - Constructor for class alluxio.worker.WorkerRegistry
Creates a new instance of WorkerRegistry.
WORKERS - Static variable in class alluxio.master.block.DefaultBlockMaster.Metrics
 
WorkerStorageTierAssoc - Class in alluxio
StorageTierAssoc for workers.
WorkerStorageTierAssoc() - Constructor for class alluxio.WorkerStorageTierAssoc
Creates a new instance of WorkerStorageTierAssoc using a Configuration.
WorkerStorageTierAssoc(List<String>) - Constructor for class alluxio.WorkerStorageTierAssoc
Creates a new instance of WorkerStorageTierAssoc using a list of storage tier aliases.
WorkerUfsManager - Class in alluxio.underfs
The default implementation of UfsManager to manage the ufs used by different worker services.
WorkerUfsManager() - Constructor for class alluxio.underfs.WorkerUfsManager
Constructs an instance of WorkerUfsManager.
WorkerWebServer - Class in alluxio.web
The Alluxio worker web server.
WorkerWebServer(InetSocketAddress, WorkerProcess, BlockWorker, String, long) - Constructor for class alluxio.web.WorkerWebServer
Creates a new instance of WorkerWebServer.
wrap(byte[], int, int) - Method in class alluxio.security.authentication.PlainSaslServer
 
write(int) - Method in class alluxio.client.block.stream.BlockOutStream
 
write(byte[]) - Method in class alluxio.client.block.stream.BlockOutStream
 
write(byte[], int, int) - Method in class alluxio.client.block.stream.BlockOutStream
 
write(int) - Method in class alluxio.client.file.FileOutStream
 
write(byte[]) - Method in class alluxio.client.file.FileOutStream
 
write(byte[], int, int) - Method in class alluxio.client.file.FileOutStream
 
write(int) - Method in class alluxio.client.lineage.DummyFileOutputStream
 
write(byte[]) - Method in class alluxio.client.lineage.DummyFileOutputStream
 
write(byte[], int, int) - Method in class alluxio.client.lineage.DummyFileOutputStream
 
write(Journal.JournalEntry) - Method in interface alluxio.master.journal.JournalWriter
Writes an entry.
write(Journal.JournalEntry) - Method in interface alluxio.master.journalv0.JournalOutputStream
Writes a Journal.JournalEntry to the journal.
write(Journal.JournalEntry) - Method in interface alluxio.master.journalv0.JournalWriter
Writes an entry to the current log stream.
write(Journal.JournalEntry) - Method in class alluxio.master.journalv0.ufs.UfsJournalWriter.EntryOutputStream
The given entry should not have its sequence number set.
write(Journal.JournalEntry) - Method in class alluxio.master.journalv0.ufs.UfsJournalWriter
 
write(byte[], int, int) - Method in class alluxio.network.thrift.BootstrapClientTransport
 
write(byte[], int, int) - Method in class alluxio.network.thrift.BootstrapServerTransport
 
write(byte[], int, int) - Method in class alluxio.network.thrift.PeekableTransport
 
WRITE - Static variable in class alluxio.proxy.StreamsRestServiceHandler
 
write(Integer, InputStream) - Method in class alluxio.proxy.StreamsRestServiceHandler
 
write(TProtocol) - Method in class alluxio.thrift.AccessBlockTOptions
 
write(TProtocol) - Method in class alluxio.thrift.AccessBlockTResponse
 
write(TProtocol) - Method in class alluxio.thrift.AlluxioService.getServiceVersion_args
 
write(TProtocol) - Method in class alluxio.thrift.AlluxioService.getServiceVersion_result
 
write(TProtocol) - Method in exception alluxio.thrift.AlluxioTException
 
write(TProtocol) - Method in class alluxio.thrift.BackupTOptions
 
write(TProtocol) - Method in class alluxio.thrift.BackupTResponse
 
write(TProtocol) - Method in class alluxio.thrift.BlockHeartbeatTOptions
 
write(TProtocol) - Method in class alluxio.thrift.BlockHeartbeatTResponse
 
write(TProtocol) - Method in class alluxio.thrift.BlockInfo
 
write(TProtocol) - Method in class alluxio.thrift.BlockLocation
 
write(TProtocol) - Method in class alluxio.thrift.BlockMasterClientService.getBlockInfo_args
 
write(TProtocol) - Method in class alluxio.thrift.BlockMasterClientService.getBlockInfo_result
 
write(TProtocol) - Method in class alluxio.thrift.BlockMasterClientService.getBlockMasterInfo_args
 
write(TProtocol) - Method in class alluxio.thrift.BlockMasterClientService.getBlockMasterInfo_result
 
write(TProtocol) - Method in class alluxio.thrift.BlockMasterClientService.getCapacityBytes_args
 
write(TProtocol) - Method in class alluxio.thrift.BlockMasterClientService.getCapacityBytes_result
 
write(TProtocol) - Method in class alluxio.thrift.BlockMasterClientService.getUsedBytes_args
 
write(TProtocol) - Method in class alluxio.thrift.BlockMasterClientService.getUsedBytes_result
 
write(TProtocol) - Method in class alluxio.thrift.BlockMasterClientService.getWorkerInfoList_args
 
write(TProtocol) - Method in class alluxio.thrift.BlockMasterClientService.getWorkerInfoList_result
 
write(TProtocol) - Method in class alluxio.thrift.BlockMasterClientService.getWorkerReport_args
 
write(TProtocol) - Method in class alluxio.thrift.BlockMasterClientService.getWorkerReport_result
 
write(TProtocol) - Method in class alluxio.thrift.BlockMasterInfo
 
write(TProtocol) - Method in class alluxio.thrift.BlockMasterWorkerService.blockHeartbeat_args
 
write(TProtocol) - Method in class alluxio.thrift.BlockMasterWorkerService.blockHeartbeat_result
 
write(TProtocol) - Method in class alluxio.thrift.BlockMasterWorkerService.commitBlock_args
 
write(TProtocol) - Method in class alluxio.thrift.BlockMasterWorkerService.commitBlock_result
 
write(TProtocol) - Method in class alluxio.thrift.BlockMasterWorkerService.getWorkerId_args
 
write(TProtocol) - Method in class alluxio.thrift.BlockMasterWorkerService.getWorkerId_result
 
write(TProtocol) - Method in class alluxio.thrift.BlockMasterWorkerService.registerWorker_args
 
write(TProtocol) - Method in class alluxio.thrift.BlockMasterWorkerService.registerWorker_result
 
write(TProtocol) - Method in class alluxio.thrift.BlockWorkerClientService.accessBlock_args
 
write(TProtocol) - Method in class alluxio.thrift.BlockWorkerClientService.accessBlock_result
 
write(TProtocol) - Method in class alluxio.thrift.BlockWorkerClientService.cacheBlock_args
 
write(TProtocol) - Method in class alluxio.thrift.BlockWorkerClientService.cacheBlock_result
 
write(TProtocol) - Method in class alluxio.thrift.BlockWorkerClientService.cancelBlock_args
 
write(TProtocol) - Method in class alluxio.thrift.BlockWorkerClientService.cancelBlock_result
 
write(TProtocol) - Method in class alluxio.thrift.BlockWorkerClientService.lockBlock_args
 
write(TProtocol) - Method in class alluxio.thrift.BlockWorkerClientService.lockBlock_result
 
write(TProtocol) - Method in class alluxio.thrift.BlockWorkerClientService.promoteBlock_args
 
write(TProtocol) - Method in class alluxio.thrift.BlockWorkerClientService.promoteBlock_result
 
write(TProtocol) - Method in class alluxio.thrift.BlockWorkerClientService.removeBlock_args
 
write(TProtocol) - Method in class alluxio.thrift.BlockWorkerClientService.removeBlock_result
 
write(TProtocol) - Method in class alluxio.thrift.BlockWorkerClientService.requestBlockLocation_args
 
write(TProtocol) - Method in class alluxio.thrift.BlockWorkerClientService.requestBlockLocation_result
 
write(TProtocol) - Method in class alluxio.thrift.BlockWorkerClientService.requestSpace_args
 
write(TProtocol) - Method in class alluxio.thrift.BlockWorkerClientService.requestSpace_result
 
write(TProtocol) - Method in class alluxio.thrift.BlockWorkerClientService.sessionBlockHeartbeat_args
 
write(TProtocol) - Method in class alluxio.thrift.BlockWorkerClientService.sessionBlockHeartbeat_result
 
write(TProtocol) - Method in class alluxio.thrift.BlockWorkerClientService.unlockBlock_args
 
write(TProtocol) - Method in class alluxio.thrift.BlockWorkerClientService.unlockBlock_result
 
write(TProtocol) - Method in class alluxio.thrift.CacheBlockTOptions
 
write(TProtocol) - Method in class alluxio.thrift.CacheBlockTResponse
 
write(TProtocol) - Method in class alluxio.thrift.CancelBlockTOptions
 
write(TProtocol) - Method in class alluxio.thrift.CancelBlockTResponse
 
write(TProtocol) - Method in class alluxio.thrift.CancelUfsFileTOptions
 
write(TProtocol) - Method in class alluxio.thrift.CancelUfsFileTResponse
 
write(TProtocol) - Method in class alluxio.thrift.CheckConsistencyTOptions
 
write(TProtocol) - Method in class alluxio.thrift.CheckConsistencyTResponse
 
write(TProtocol) - Method in class alluxio.thrift.CloseUfsFileTOptions
 
write(TProtocol) - Method in class alluxio.thrift.CloseUfsFileTResponse
 
write(TProtocol) - Method in class alluxio.thrift.Command
 
write(TProtocol) - Method in class alluxio.thrift.CommandLineJobInfo
 
write(TProtocol) - Method in class alluxio.thrift.CommitBlockTOptions
 
write(TProtocol) - Method in class alluxio.thrift.CommitBlockTResponse
 
write(TProtocol) - Method in class alluxio.thrift.CompleteFileTOptions
 
write(TProtocol) - Method in class alluxio.thrift.CompleteFileTResponse
 
write(TProtocol) - Method in class alluxio.thrift.CompletePartitionTOptions
 
write(TProtocol) - Method in class alluxio.thrift.CompletePartitionTResponse
 
write(TProtocol) - Method in class alluxio.thrift.CompleteStoreTOptions
 
write(TProtocol) - Method in class alluxio.thrift.CompleteStoreTResponse
 
write(TProtocol) - Method in class alluxio.thrift.CompleteUfsFileTOptions
 
write(TProtocol) - Method in class alluxio.thrift.CompleteUfsFileTReponse
 
write(TProtocol) - Method in class alluxio.thrift.ConfigCheckReport
 
write(TProtocol) - Method in class alluxio.thrift.ConfigProperty
 
write(TProtocol) - Method in class alluxio.thrift.CreateDirectoryTOptions
 
write(TProtocol) - Method in class alluxio.thrift.CreateDirectoryTResponse
 
write(TProtocol) - Method in class alluxio.thrift.CreateFileTOptions
 
write(TProtocol) - Method in class alluxio.thrift.CreateFileTResponse
 
write(TProtocol) - Method in class alluxio.thrift.CreateLineageTOptions
 
write(TProtocol) - Method in class alluxio.thrift.CreateLineageTResponse
 
write(TProtocol) - Method in class alluxio.thrift.CreateStoreTOptions
 
write(TProtocol) - Method in class alluxio.thrift.CreateStoreTResponse
 
write(TProtocol) - Method in class alluxio.thrift.CreateUfsFileTOptions
 
write(TProtocol) - Method in class alluxio.thrift.CreateUfsFileTResponse
 
write(TProtocol) - Method in class alluxio.thrift.DeleteLineageTOptions
 
write(TProtocol) - Method in class alluxio.thrift.DeleteLineageTResponse
 
write(TProtocol) - Method in class alluxio.thrift.DeleteStoreTOptions
 
write(TProtocol) - Method in class alluxio.thrift.DeleteStoreTResponse
 
write(TProtocol) - Method in class alluxio.thrift.DeleteTOptions
 
write(TProtocol) - Method in class alluxio.thrift.DeleteTResponse
 
write(TProtocol) - Method in class alluxio.thrift.DependencyInfo
 
write(TProtocol) - Method in class alluxio.thrift.FileBlockInfo
 
write(TProtocol) - Method in class alluxio.thrift.FileInfo
 
write(TProtocol) - Method in class alluxio.thrift.FileSystemCommand
 
write(TProtocol) - Method in class alluxio.thrift.FileSystemHeartbeatTOptions
 
write(TProtocol) - Method in class alluxio.thrift.FileSystemHeartbeatTResponse
 
write(TProtocol) - Method in class alluxio.thrift.FileSystemMasterClientService.checkConsistency_args
 
write(TProtocol) - Method in class alluxio.thrift.FileSystemMasterClientService.checkConsistency_result
 
write(TProtocol) - Method in class alluxio.thrift.FileSystemMasterClientService.completeFile_args
 
write(TProtocol) - Method in class alluxio.thrift.FileSystemMasterClientService.completeFile_result
 
write(TProtocol) - Method in class alluxio.thrift.FileSystemMasterClientService.createDirectory_args
 
write(TProtocol) - Method in class alluxio.thrift.FileSystemMasterClientService.createDirectory_result
 
write(TProtocol) - Method in class alluxio.thrift.FileSystemMasterClientService.createFile_args
 
write(TProtocol) - Method in class alluxio.thrift.FileSystemMasterClientService.createFile_result
 
write(TProtocol) - Method in class alluxio.thrift.FileSystemMasterClientService.free_args
 
write(TProtocol) - Method in class alluxio.thrift.FileSystemMasterClientService.free_result
 
write(TProtocol) - Method in class alluxio.thrift.FileSystemMasterClientService.getFilePath_args
 
write(TProtocol) - Method in class alluxio.thrift.FileSystemMasterClientService.getFilePath_result
 
write(TProtocol) - Method in class alluxio.thrift.FileSystemMasterClientService.getMountTable_args
 
write(TProtocol) - Method in class alluxio.thrift.FileSystemMasterClientService.getMountTable_result
 
write(TProtocol) - Method in class alluxio.thrift.FileSystemMasterClientService.getNewBlockIdForFile_args
 
write(TProtocol) - Method in class alluxio.thrift.FileSystemMasterClientService.getNewBlockIdForFile_result
 
write(TProtocol) - Method in class alluxio.thrift.FileSystemMasterClientService.getStatus_args
 
write(TProtocol) - Method in class alluxio.thrift.FileSystemMasterClientService.getStatus_result
 
write(TProtocol) - Method in class alluxio.thrift.FileSystemMasterClientService.listStatus_args
 
write(TProtocol) - Method in class alluxio.thrift.FileSystemMasterClientService.listStatus_result
 
write(TProtocol) - Method in class alluxio.thrift.FileSystemMasterClientService.loadMetadata_args
 
write(TProtocol) - Method in class alluxio.thrift.FileSystemMasterClientService.loadMetadata_result
 
write(TProtocol) - Method in class alluxio.thrift.FileSystemMasterClientService.mount_args
 
write(TProtocol) - Method in class alluxio.thrift.FileSystemMasterClientService.mount_result
 
write(TProtocol) - Method in class alluxio.thrift.FileSystemMasterClientService.remove_args
 
write(TProtocol) - Method in class alluxio.thrift.FileSystemMasterClientService.remove_result
 
write(TProtocol) - Method in class alluxio.thrift.FileSystemMasterClientService.rename_args
 
write(TProtocol) - Method in class alluxio.thrift.FileSystemMasterClientService.rename_result
 
write(TProtocol) - Method in class alluxio.thrift.FileSystemMasterClientService.scheduleAsyncPersistence_args
 
write(TProtocol) - Method in class alluxio.thrift.FileSystemMasterClientService.scheduleAsyncPersistence_result
 
write(TProtocol) - Method in class alluxio.thrift.FileSystemMasterClientService.setAttribute_args
 
write(TProtocol) - Method in class alluxio.thrift.FileSystemMasterClientService.setAttribute_result
 
write(TProtocol) - Method in class alluxio.thrift.FileSystemMasterClientService.unmount_args
 
write(TProtocol) - Method in class alluxio.thrift.FileSystemMasterClientService.unmount_result
 
write(TProtocol) - Method in class alluxio.thrift.FileSystemMasterClientService.updateUfsMode_args
 
write(TProtocol) - Method in class alluxio.thrift.FileSystemMasterClientService.updateUfsMode_result
 
write(TProtocol) - Method in class alluxio.thrift.FileSystemMasterCommonTOptions
 
write(TProtocol) - Method in class alluxio.thrift.FileSystemMasterWorkerService.fileSystemHeartbeat_args
 
write(TProtocol) - Method in class alluxio.thrift.FileSystemMasterWorkerService.fileSystemHeartbeat_result
 
write(TProtocol) - Method in class alluxio.thrift.FileSystemMasterWorkerService.getFileInfo_args
 
write(TProtocol) - Method in class alluxio.thrift.FileSystemMasterWorkerService.getFileInfo_result
 
write(TProtocol) - Method in class alluxio.thrift.FileSystemMasterWorkerService.getPinnedFileIds_args
 
write(TProtocol) - Method in class alluxio.thrift.FileSystemMasterWorkerService.getPinnedFileIds_result
 
write(TProtocol) - Method in class alluxio.thrift.FileSystemMasterWorkerService.getUfsInfo_args
 
write(TProtocol) - Method in class alluxio.thrift.FileSystemMasterWorkerService.getUfsInfo_result
 
write(TProtocol) - Method in class alluxio.thrift.FileSystemWorkerClientService.cancelUfsFile_args
 
write(TProtocol) - Method in class alluxio.thrift.FileSystemWorkerClientService.cancelUfsFile_result
 
write(TProtocol) - Method in class alluxio.thrift.FileSystemWorkerClientService.closeUfsFile_args
 
write(TProtocol) - Method in class alluxio.thrift.FileSystemWorkerClientService.closeUfsFile_result
 
write(TProtocol) - Method in class alluxio.thrift.FileSystemWorkerClientService.completeUfsFile_args
 
write(TProtocol) - Method in class alluxio.thrift.FileSystemWorkerClientService.completeUfsFile_result
 
write(TProtocol) - Method in class alluxio.thrift.FileSystemWorkerClientService.createUfsFile_args
 
write(TProtocol) - Method in class alluxio.thrift.FileSystemWorkerClientService.createUfsFile_result
 
write(TProtocol) - Method in class alluxio.thrift.FileSystemWorkerClientService.openUfsFile_args
 
write(TProtocol) - Method in class alluxio.thrift.FileSystemWorkerClientService.openUfsFile_result
 
write(TProtocol) - Method in class alluxio.thrift.FileSystemWorkerClientService.sessionFileSystemHeartbeat_args
 
write(TProtocol) - Method in class alluxio.thrift.FileSystemWorkerClientService.sessionFileSystemHeartbeat_result
 
write(TProtocol) - Method in class alluxio.thrift.FreeTOptions
 
write(TProtocol) - Method in class alluxio.thrift.FreeTResponse
 
write(TProtocol) - Method in class alluxio.thrift.GetBlockInfoTOptions
 
write(TProtocol) - Method in class alluxio.thrift.GetBlockInfoTResponse
 
write(TProtocol) - Method in class alluxio.thrift.GetBlockMasterInfoTOptions
 
write(TProtocol) - Method in class alluxio.thrift.GetBlockMasterInfoTResponse
 
write(TProtocol) - Method in class alluxio.thrift.GetCapacityBytesTOptions
 
write(TProtocol) - Method in class alluxio.thrift.GetCapacityBytesTResponse
 
write(TProtocol) - Method in class alluxio.thrift.GetConfigReportTOptions
 
write(TProtocol) - Method in class alluxio.thrift.GetConfigReportTResponse
 
write(TProtocol) - Method in class alluxio.thrift.GetConfigurationTOptions
 
write(TProtocol) - Method in class alluxio.thrift.GetConfigurationTResponse
 
write(TProtocol) - Method in class alluxio.thrift.GetFileInfoTOptions
 
write(TProtocol) - Method in class alluxio.thrift.GetFileInfoTResponse
 
write(TProtocol) - Method in class alluxio.thrift.GetFilePathTOptions
 
write(TProtocol) - Method in class alluxio.thrift.GetFilePathTResponse
 
write(TProtocol) - Method in class alluxio.thrift.GetLineageInfoListTOptions
 
write(TProtocol) - Method in class alluxio.thrift.GetLineageInfoListTResponse
 
write(TProtocol) - Method in class alluxio.thrift.GetMasterIdTOptions
 
write(TProtocol) - Method in class alluxio.thrift.GetMasterIdTResponse
 
write(TProtocol) - Method in class alluxio.thrift.GetMasterInfoTOptions
 
write(TProtocol) - Method in class alluxio.thrift.GetMasterInfoTResponse
 
write(TProtocol) - Method in class alluxio.thrift.GetMetricsTOptions
 
write(TProtocol) - Method in class alluxio.thrift.GetMetricsTResponse
 
write(TProtocol) - Method in class alluxio.thrift.GetMountTableTResponse
 
write(TProtocol) - Method in class alluxio.thrift.GetNewBlockIdForFileTOptions
 
write(TProtocol) - Method in class alluxio.thrift.GetNewBlockIdForFileTResponse
 
write(TProtocol) - Method in class alluxio.thrift.GetNextKeysTOptions
 
write(TProtocol) - Method in class alluxio.thrift.GetNextKeysTResponse
 
write(TProtocol) - Method in class alluxio.thrift.GetPartitionInfoTOptions
 
write(TProtocol) - Method in class alluxio.thrift.GetPartitionInfoTResponse
 
write(TProtocol) - Method in class alluxio.thrift.GetPinnedFileIdsTOptions
 
write(TProtocol) - Method in class alluxio.thrift.GetPinnedFileIdsTResponse
 
write(TProtocol) - Method in class alluxio.thrift.GetServiceVersionTOptions
 
write(TProtocol) - Method in class alluxio.thrift.GetServiceVersionTResponse
 
write(TProtocol) - Method in class alluxio.thrift.GetSizeTOptions
 
write(TProtocol) - Method in class alluxio.thrift.GetSizeTResponse
 
write(TProtocol) - Method in class alluxio.thrift.GetStatusTOptions
 
write(TProtocol) - Method in class alluxio.thrift.GetStatusTResponse
 
write(TProtocol) - Method in class alluxio.thrift.GetTOptions
 
write(TProtocol) - Method in class alluxio.thrift.GetTResponse
 
write(TProtocol) - Method in class alluxio.thrift.GetUfsInfoTOptions
 
write(TProtocol) - Method in class alluxio.thrift.GetUfsInfoTResponse
 
write(TProtocol) - Method in class alluxio.thrift.GetUsedBytesTOptions
 
write(TProtocol) - Method in class alluxio.thrift.GetUsedBytesTResponse
 
write(TProtocol) - Method in class alluxio.thrift.GetWorkerIdTOptions
 
write(TProtocol) - Method in class alluxio.thrift.GetWorkerIdTResponse
 
write(TProtocol) - Method in class alluxio.thrift.GetWorkerInfoListTOptions
 
write(TProtocol) - Method in class alluxio.thrift.GetWorkerInfoListTResponse
 
write(TProtocol) - Method in class alluxio.thrift.GetWorkerReportTOptions
 
write(TProtocol) - Method in class alluxio.thrift.InconsistentProperty
 
write(TProtocol) - Method in class alluxio.thrift.JobConfInfo
 
write(TProtocol) - Method in class alluxio.thrift.KeyValueMasterClientService.completePartition_args
 
write(TProtocol) - Method in class alluxio.thrift.KeyValueMasterClientService.completePartition_result
 
write(TProtocol) - Method in class alluxio.thrift.KeyValueMasterClientService.completeStore_args
 
write(TProtocol) - Method in class alluxio.thrift.KeyValueMasterClientService.completeStore_result
 
write(TProtocol) - Method in class alluxio.thrift.KeyValueMasterClientService.createStore_args
 
write(TProtocol) - Method in class alluxio.thrift.KeyValueMasterClientService.createStore_result
 
write(TProtocol) - Method in class alluxio.thrift.KeyValueMasterClientService.deleteStore_args
 
write(TProtocol) - Method in class alluxio.thrift.KeyValueMasterClientService.deleteStore_result
 
write(TProtocol) - Method in class alluxio.thrift.KeyValueMasterClientService.getPartitionInfo_args
 
write(TProtocol) - Method in class alluxio.thrift.KeyValueMasterClientService.getPartitionInfo_result
 
write(TProtocol) - Method in class alluxio.thrift.KeyValueMasterClientService.mergeStore_args
 
write(TProtocol) - Method in class alluxio.thrift.KeyValueMasterClientService.mergeStore_result
 
write(TProtocol) - Method in class alluxio.thrift.KeyValueMasterClientService.renameStore_args
 
write(TProtocol) - Method in class alluxio.thrift.KeyValueMasterClientService.renameStore_result
 
write(TProtocol) - Method in class alluxio.thrift.KeyValueWorkerClientService.get_args
 
write(TProtocol) - Method in class alluxio.thrift.KeyValueWorkerClientService.get_result
 
write(TProtocol) - Method in class alluxio.thrift.KeyValueWorkerClientService.getNextKeys_args
 
write(TProtocol) - Method in class alluxio.thrift.KeyValueWorkerClientService.getNextKeys_result
 
write(TProtocol) - Method in class alluxio.thrift.KeyValueWorkerClientService.getSize_args
 
write(TProtocol) - Method in class alluxio.thrift.KeyValueWorkerClientService.getSize_result
 
write(TProtocol) - Method in class alluxio.thrift.LineageInfo
 
write(TProtocol) - Method in class alluxio.thrift.LineageMasterClientService.createLineage_args
 
write(TProtocol) - Method in class alluxio.thrift.LineageMasterClientService.createLineage_result
 
write(TProtocol) - Method in class alluxio.thrift.LineageMasterClientService.deleteLineage_args
 
write(TProtocol) - Method in class alluxio.thrift.LineageMasterClientService.deleteLineage_result
 
write(TProtocol) - Method in class alluxio.thrift.LineageMasterClientService.getLineageInfoList_args
 
write(TProtocol) - Method in class alluxio.thrift.LineageMasterClientService.getLineageInfoList_result
 
write(TProtocol) - Method in class alluxio.thrift.LineageMasterClientService.reinitializeFile_args
 
write(TProtocol) - Method in class alluxio.thrift.LineageMasterClientService.reinitializeFile_result
 
write(TProtocol) - Method in class alluxio.thrift.LineageMasterClientService.reportLostFile_args
 
write(TProtocol) - Method in class alluxio.thrift.LineageMasterClientService.reportLostFile_result
 
write(TProtocol) - Method in class alluxio.thrift.ListStatusTOptions
 
write(TProtocol) - Method in class alluxio.thrift.ListStatusTResponse
 
write(TProtocol) - Method in class alluxio.thrift.LoadMetadataTOptions
 
write(TProtocol) - Method in class alluxio.thrift.LoadMetadataTResponse
 
write(TProtocol) - Method in class alluxio.thrift.LocalityTier
 
write(TProtocol) - Method in class alluxio.thrift.LockBlockTOptions
 
write(TProtocol) - Method in class alluxio.thrift.LockBlockTResponse
 
write(TProtocol) - Method in class alluxio.thrift.MasterHeartbeatTOptions
 
write(TProtocol) - Method in class alluxio.thrift.MasterHeartbeatTResponse
 
write(TProtocol) - Method in class alluxio.thrift.MasterInfo
 
write(TProtocol) - Method in class alluxio.thrift.MasterNetAddress
 
write(TProtocol) - Method in class alluxio.thrift.MergeStoreTOptions
 
write(TProtocol) - Method in class alluxio.thrift.MergeStoreTResponse
 
write(TProtocol) - Method in class alluxio.thrift.MetaMasterClientService.backup_args
 
write(TProtocol) - Method in class alluxio.thrift.MetaMasterClientService.backup_result
 
write(TProtocol) - Method in class alluxio.thrift.MetaMasterClientService.getConfigReport_args
 
write(TProtocol) - Method in class alluxio.thrift.MetaMasterClientService.getConfigReport_result
 
write(TProtocol) - Method in class alluxio.thrift.MetaMasterClientService.getConfiguration_args
 
write(TProtocol) - Method in class alluxio.thrift.MetaMasterClientService.getConfiguration_result
 
write(TProtocol) - Method in class alluxio.thrift.MetaMasterClientService.getMasterInfo_args
 
write(TProtocol) - Method in class alluxio.thrift.MetaMasterClientService.getMasterInfo_result
 
write(TProtocol) - Method in class alluxio.thrift.MetaMasterClientService.getMetrics_args
 
write(TProtocol) - Method in class alluxio.thrift.MetaMasterClientService.getMetrics_result
 
write(TProtocol) - Method in class alluxio.thrift.MetaMasterMasterService.getMasterId_args
 
write(TProtocol) - Method in class alluxio.thrift.MetaMasterMasterService.getMasterId_result
 
write(TProtocol) - Method in class alluxio.thrift.MetaMasterMasterService.masterHeartbeat_args
 
write(TProtocol) - Method in class alluxio.thrift.MetaMasterMasterService.masterHeartbeat_result
 
write(TProtocol) - Method in class alluxio.thrift.MetaMasterMasterService.registerMaster_args
 
write(TProtocol) - Method in class alluxio.thrift.MetaMasterMasterService.registerMaster_result
 
write(TProtocol) - Method in class alluxio.thrift.Metric
 
write(TProtocol) - Method in class alluxio.thrift.MetricsHeartbeatTOptions
 
write(TProtocol) - Method in class alluxio.thrift.MetricsHeartbeatTResponse
 
write(TProtocol) - Method in class alluxio.thrift.MetricsMasterClientService.metricsHeartbeat_args
 
write(TProtocol) - Method in class alluxio.thrift.MetricsMasterClientService.metricsHeartbeat_result
 
write(TProtocol) - Method in class alluxio.thrift.MetricValue
 
write(TProtocol) - Method in class alluxio.thrift.MountPointInfo
 
write(TProtocol) - Method in class alluxio.thrift.MountTOptions
 
write(TProtocol) - Method in class alluxio.thrift.MountTResponse
 
write(TProtocol) - Method in class alluxio.thrift.OpenUfsFileTOptions
 
write(TProtocol) - Method in class alluxio.thrift.OpenUfsFileTResponse
 
write(TProtocol) - Method in class alluxio.thrift.OptionalString
 
write(TProtocol) - Method in class alluxio.thrift.PartitionInfo
 
write(TProtocol) - Method in class alluxio.thrift.PersistCommandOptions
 
write(TProtocol) - Method in class alluxio.thrift.PersistFile
 
write(TProtocol) - Method in class alluxio.thrift.PromoteBlockTOptions
 
write(TProtocol) - Method in class alluxio.thrift.PromoteBlockTResponse
 
write(TProtocol) - Method in class alluxio.thrift.RegisterMasterTOptions
 
write(TProtocol) - Method in class alluxio.thrift.RegisterMasterTResponse
 
write(TProtocol) - Method in class alluxio.thrift.RegisterWorkerTOptions
 
write(TProtocol) - Method in class alluxio.thrift.RegisterWorkerTResponse
 
write(TProtocol) - Method in class alluxio.thrift.ReinitializeFileTOptions
 
write(TProtocol) - Method in class alluxio.thrift.ReinitializeFileTResponse
 
write(TProtocol) - Method in class alluxio.thrift.RemoveBlockTOptions
 
write(TProtocol) - Method in class alluxio.thrift.RemoveBlockTResponse
 
write(TProtocol) - Method in class alluxio.thrift.RenameStoreTOptions
 
write(TProtocol) - Method in class alluxio.thrift.RenameStoreTResponse
 
write(TProtocol) - Method in class alluxio.thrift.RenameTOptions
 
write(TProtocol) - Method in class alluxio.thrift.RenameTResponse
 
write(TProtocol) - Method in class alluxio.thrift.ReportLostFileTOptions
 
write(TProtocol) - Method in class alluxio.thrift.ReportLostFileTResponse
 
write(TProtocol) - Method in class alluxio.thrift.RequestBlockLocationTOptions
 
write(TProtocol) - Method in class alluxio.thrift.RequestBlockLocationTResponse
 
write(TProtocol) - Method in class alluxio.thrift.RequestSpaceTOptions
 
write(TProtocol) - Method in class alluxio.thrift.RequestSpaceTResponse
 
write(TProtocol) - Method in class alluxio.thrift.ScheduleAsyncPersistenceTOptions
 
write(TProtocol) - Method in class alluxio.thrift.ScheduleAsyncPersistenceTResponse
 
write(TProtocol) - Method in class alluxio.thrift.SessionBlockHeartbeatTOptions
 
write(TProtocol) - Method in class alluxio.thrift.SessionBlockHeartbeatTResponse
 
write(TProtocol) - Method in class alluxio.thrift.SessionFileSystemHeartbeatTOptions
 
write(TProtocol) - Method in class alluxio.thrift.SessionFileSystemHeartbeatTResponse
 
write(TProtocol) - Method in class alluxio.thrift.SetAttributeTOptions
 
write(TProtocol) - Method in class alluxio.thrift.SetAttributeTResponse
 
write(TProtocol) - Method in class alluxio.thrift.SyncMetadataTOptions
 
write(TProtocol) - Method in class alluxio.thrift.SyncMetadataTResponse
 
write(TProtocol) - Method in class alluxio.thrift.TieredIdentity
 
write(TProtocol) - Method in class alluxio.thrift.UfsInfo
 
write(TProtocol) - Method in class alluxio.thrift.UnlockBlockTOptions
 
write(TProtocol) - Method in class alluxio.thrift.UnlockBlockTResponse
 
write(TProtocol) - Method in class alluxio.thrift.UnmountTOptions
 
write(TProtocol) - Method in class alluxio.thrift.UnmountTResponse
 
write(TProtocol) - Method in class alluxio.thrift.UpdateUfsModeTOptions
 
write(TProtocol) - Method in class alluxio.thrift.UpdateUfsModeTResponse
 
write(TProtocol) - Method in class alluxio.thrift.WorkerInfo
 
write(TProtocol) - Method in class alluxio.thrift.WorkerNetAddress
 
write(int) - Method in class alluxio.underfs.AtomicFileOutputStream
 
write(byte[]) - Method in class alluxio.underfs.AtomicFileOutputStream
 
write(byte[], int, int) - Method in class alluxio.underfs.AtomicFileOutputStream
 
write(int) - Method in class alluxio.underfs.cos.COSOutputStream
Writes the given bytes to this output stream.
write(byte[]) - Method in class alluxio.underfs.cos.COSOutputStream
Writes the given byte array to this output stream.
write(byte[], int, int) - Method in class alluxio.underfs.cos.COSOutputStream
Writes the given number of bytes from the given byte array starting at the given offset to this output stream.
write(int) - Method in class alluxio.underfs.gcs.GCSOutputStream
 
write(byte[]) - Method in class alluxio.underfs.gcs.GCSOutputStream
 
write(byte[], int, int) - Method in class alluxio.underfs.gcs.GCSOutputStream
 
write(int) - Method in class alluxio.underfs.hdfs.HdfsUnderFileOutputStream
 
write(byte[]) - Method in class alluxio.underfs.hdfs.HdfsUnderFileOutputStream
 
write(byte[], int, int) - Method in class alluxio.underfs.hdfs.HdfsUnderFileOutputStream
 
write(int) - Method in class alluxio.underfs.oss.OSSOutputStream
Writes the given bytes to this output stream.
write(byte[]) - Method in class alluxio.underfs.oss.OSSOutputStream
Writes the given byte array to this output stream.
write(byte[], int, int) - Method in class alluxio.underfs.oss.OSSOutputStream
Writes the given number of bytes from the given byte array starting at the given offset to this output stream.
write(int) - Method in class alluxio.underfs.s3a.S3AOutputStream
 
write(byte[]) - Method in class alluxio.underfs.s3a.S3AOutputStream
 
write(byte[], int, int) - Method in class alluxio.underfs.s3a.S3AOutputStream
 
write(int) - Method in class alluxio.underfs.swift.SwiftMockOutputStream
 
write(byte[], int, int) - Method in class alluxio.underfs.swift.SwiftMockOutputStream
 
write(byte[]) - Method in class alluxio.underfs.swift.SwiftMockOutputStream
 
write(int) - Method in class alluxio.underfs.swift.SwiftOutputStream
 
write(byte[], int, int) - Method in class alluxio.underfs.swift.SwiftOutputStream
 
write(byte[]) - Method in class alluxio.underfs.swift.SwiftOutputStream
 
write_args(TProtocol) - Method in class alluxio.thrift.AlluxioService.AsyncClient.getServiceVersion_call
 
write_args(TProtocol) - Method in class alluxio.thrift.BlockMasterClientService.AsyncClient.getBlockInfo_call
 
write_args(TProtocol) - Method in class alluxio.thrift.BlockMasterClientService.AsyncClient.getBlockMasterInfo_call
 
write_args(TProtocol) - Method in class alluxio.thrift.BlockMasterClientService.AsyncClient.getCapacityBytes_call
 
write_args(TProtocol) - Method in class alluxio.thrift.BlockMasterClientService.AsyncClient.getUsedBytes_call
 
write_args(TProtocol) - Method in class alluxio.thrift.BlockMasterClientService.AsyncClient.getWorkerInfoList_call
 
write_args(TProtocol) - Method in class alluxio.thrift.BlockMasterClientService.AsyncClient.getWorkerReport_call
 
write_args(TProtocol) - Method in class alluxio.thrift.BlockMasterWorkerService.AsyncClient.blockHeartbeat_call
 
write_args(TProtocol) - Method in class alluxio.thrift.BlockMasterWorkerService.AsyncClient.commitBlock_call
 
write_args(TProtocol) - Method in class alluxio.thrift.BlockMasterWorkerService.AsyncClient.getWorkerId_call
 
write_args(TProtocol) - Method in class alluxio.thrift.BlockMasterWorkerService.AsyncClient.registerWorker_call
 
write_args(TProtocol) - Method in class alluxio.thrift.BlockWorkerClientService.AsyncClient.accessBlock_call
 
write_args(TProtocol) - Method in class alluxio.thrift.BlockWorkerClientService.AsyncClient.cacheBlock_call
 
write_args(TProtocol) - Method in class alluxio.thrift.BlockWorkerClientService.AsyncClient.cancelBlock_call
 
write_args(TProtocol) - Method in class alluxio.thrift.BlockWorkerClientService.AsyncClient.lockBlock_call
 
write_args(TProtocol) - Method in class alluxio.thrift.BlockWorkerClientService.AsyncClient.promoteBlock_call
 
write_args(TProtocol) - Method in class alluxio.thrift.BlockWorkerClientService.AsyncClient.removeBlock_call
 
write_args(TProtocol) - Method in class alluxio.thrift.BlockWorkerClientService.AsyncClient.requestBlockLocation_call
 
write_args(TProtocol) - Method in class alluxio.thrift.BlockWorkerClientService.AsyncClient.requestSpace_call
 
write_args(TProtocol) - Method in class alluxio.thrift.BlockWorkerClientService.AsyncClient.sessionBlockHeartbeat_call
 
write_args(TProtocol) - Method in class alluxio.thrift.BlockWorkerClientService.AsyncClient.unlockBlock_call
 
write_args(TProtocol) - Method in class alluxio.thrift.FileSystemMasterClientService.AsyncClient.checkConsistency_call
 
write_args(TProtocol) - Method in class alluxio.thrift.FileSystemMasterClientService.AsyncClient.completeFile_call
 
write_args(TProtocol) - Method in class alluxio.thrift.FileSystemMasterClientService.AsyncClient.createDirectory_call
 
write_args(TProtocol) - Method in class alluxio.thrift.FileSystemMasterClientService.AsyncClient.createFile_call
 
write_args(TProtocol) - Method in class alluxio.thrift.FileSystemMasterClientService.AsyncClient.free_call
 
write_args(TProtocol) - Method in class alluxio.thrift.FileSystemMasterClientService.AsyncClient.getFilePath_call
 
write_args(TProtocol) - Method in class alluxio.thrift.FileSystemMasterClientService.AsyncClient.getMountTable_call
 
write_args(TProtocol) - Method in class alluxio.thrift.FileSystemMasterClientService.AsyncClient.getNewBlockIdForFile_call
 
write_args(TProtocol) - Method in class alluxio.thrift.FileSystemMasterClientService.AsyncClient.getStatus_call
 
write_args(TProtocol) - Method in class alluxio.thrift.FileSystemMasterClientService.AsyncClient.listStatus_call
 
write_args(TProtocol) - Method in class alluxio.thrift.FileSystemMasterClientService.AsyncClient.loadMetadata_call
 
write_args(TProtocol) - Method in class alluxio.thrift.FileSystemMasterClientService.AsyncClient.mount_call
 
write_args(TProtocol) - Method in class alluxio.thrift.FileSystemMasterClientService.AsyncClient.remove_call
 
write_args(TProtocol) - Method in class alluxio.thrift.FileSystemMasterClientService.AsyncClient.rename_call
 
write_args(TProtocol) - Method in class alluxio.thrift.FileSystemMasterClientService.AsyncClient.scheduleAsyncPersistence_call
 
write_args(TProtocol) - Method in class alluxio.thrift.FileSystemMasterClientService.AsyncClient.setAttribute_call
 
write_args(TProtocol) - Method in class alluxio.thrift.FileSystemMasterClientService.AsyncClient.unmount_call
 
write_args(TProtocol) - Method in class alluxio.thrift.FileSystemMasterClientService.AsyncClient.updateUfsMode_call
 
write_args(TProtocol) - Method in class alluxio.thrift.FileSystemMasterWorkerService.AsyncClient.fileSystemHeartbeat_call
 
write_args(TProtocol) - Method in class alluxio.thrift.FileSystemMasterWorkerService.AsyncClient.getFileInfo_call
 
write_args(TProtocol) - Method in class alluxio.thrift.FileSystemMasterWorkerService.AsyncClient.getPinnedFileIds_call
 
write_args(TProtocol) - Method in class alluxio.thrift.FileSystemMasterWorkerService.AsyncClient.getUfsInfo_call
 
write_args(TProtocol) - Method in class alluxio.thrift.FileSystemWorkerClientService.AsyncClient.cancelUfsFile_call
 
write_args(TProtocol) - Method in class alluxio.thrift.FileSystemWorkerClientService.AsyncClient.closeUfsFile_call
 
write_args(TProtocol) - Method in class alluxio.thrift.FileSystemWorkerClientService.AsyncClient.completeUfsFile_call
 
write_args(TProtocol) - Method in class alluxio.thrift.FileSystemWorkerClientService.AsyncClient.createUfsFile_call
 
write_args(TProtocol) - Method in class alluxio.thrift.FileSystemWorkerClientService.AsyncClient.openUfsFile_call
 
write_args(TProtocol) - Method in class alluxio.thrift.FileSystemWorkerClientService.AsyncClient.sessionFileSystemHeartbeat_call
 
write_args(TProtocol) - Method in class alluxio.thrift.KeyValueMasterClientService.AsyncClient.completePartition_call
 
write_args(TProtocol) - Method in class alluxio.thrift.KeyValueMasterClientService.AsyncClient.completeStore_call
 
write_args(TProtocol) - Method in class alluxio.thrift.KeyValueMasterClientService.AsyncClient.createStore_call
 
write_args(TProtocol) - Method in class alluxio.thrift.KeyValueMasterClientService.AsyncClient.deleteStore_call
 
write_args(TProtocol) - Method in class alluxio.thrift.KeyValueMasterClientService.AsyncClient.getPartitionInfo_call
 
write_args(TProtocol) - Method in class alluxio.thrift.KeyValueMasterClientService.AsyncClient.mergeStore_call
 
write_args(TProtocol) - Method in class alluxio.thrift.KeyValueMasterClientService.AsyncClient.renameStore_call
 
write_args(TProtocol) - Method in class alluxio.thrift.KeyValueWorkerClientService.AsyncClient.get_call
 
write_args(TProtocol) - Method in class alluxio.thrift.KeyValueWorkerClientService.AsyncClient.getNextKeys_call
 
write_args(TProtocol) - Method in class alluxio.thrift.KeyValueWorkerClientService.AsyncClient.getSize_call
 
write_args(TProtocol) - Method in class alluxio.thrift.LineageMasterClientService.AsyncClient.createLineage_call
 
write_args(TProtocol) - Method in class alluxio.thrift.LineageMasterClientService.AsyncClient.deleteLineage_call
 
write_args(TProtocol) - Method in class alluxio.thrift.LineageMasterClientService.AsyncClient.getLineageInfoList_call
 
write_args(TProtocol) - Method in class alluxio.thrift.LineageMasterClientService.AsyncClient.reinitializeFile_call
 
write_args(TProtocol) - Method in class alluxio.thrift.LineageMasterClientService.AsyncClient.reportLostFile_call
 
write_args(TProtocol) - Method in class alluxio.thrift.MetaMasterClientService.AsyncClient.backup_call
 
write_args(TProtocol) - Method in class alluxio.thrift.MetaMasterClientService.AsyncClient.getConfigReport_call
 
write_args(TProtocol) - Method in class alluxio.thrift.MetaMasterClientService.AsyncClient.getConfiguration_call
 
write_args(TProtocol) - Method in class alluxio.thrift.MetaMasterClientService.AsyncClient.getMasterInfo_call
 
write_args(TProtocol) - Method in class alluxio.thrift.MetaMasterClientService.AsyncClient.getMetrics_call
 
write_args(TProtocol) - Method in class alluxio.thrift.MetaMasterMasterService.AsyncClient.getMasterId_call
 
write_args(TProtocol) - Method in class alluxio.thrift.MetaMasterMasterService.AsyncClient.masterHeartbeat_call
 
write_args(TProtocol) - Method in class alluxio.thrift.MetaMasterMasterService.AsyncClient.registerMaster_call
 
write_args(TProtocol) - Method in class alluxio.thrift.MetricsMasterClientService.AsyncClient.metricsHeartbeat_call
 
writeBuf(BlockWriteRequestContext, Channel, ByteBuf, long) - Method in class alluxio.worker.netty.BlockWriteHandler.BlockPacketWriter
 
writeBuf(UfsFileWriteRequestContext, Channel, ByteBuf, long) - Method in class alluxio.worker.netty.UfsFileWriteHandler.UfsFilePacketWriter
 
writeBufferToFile(String, byte[]) - Static method in class alluxio.util.io.BufferUtils
Writes buffer to the given file path.
writeByte(byte[], int, byte) - Static method in class alluxio.util.io.ByteIOUtils
Writes a single byte value (1 byte) to the output byte array at the given offset.
writeByte(ByteBuffer, int, byte) - Static method in class alluxio.util.io.ByteIOUtils
Writes a single byte value (1 byte) to the output byte buffer at the given offset.
writeByte(OutputStream, byte) - Static method in class alluxio.util.io.ByteIOUtils
Writes a single byte value (1 byte) to the output stream.
writeCSVFile(Collection<? extends PropertyKey>, String) - Static method in class alluxio.cli.ConfigurationDocGenerator
Writes property key to csv files.
writeInt(byte[], int, int) - Static method in class alluxio.util.io.ByteIOUtils
Writes a specific integer value (4 bytes) to the output byte array at the given offset.
writeInt(ByteBuffer, int, int) - Static method in class alluxio.util.io.ByteIOUtils
Writes a specific integer value (4 bytes) to the output byte buffer at the given offset.
writeInt(OutputStream, int) - Static method in class alluxio.util.io.ByteIOUtils
Writes a specific integer value (4 bytes) to the output stream.
writeLock() - Method in class alluxio.worker.block.ClientRWLock
 
writeLong(byte[], int, long) - Static method in class alluxio.util.io.ByteIOUtils
Writes a specific long value (8 bytes) to the output byte array at the given offset.
writeLong(OutputStream, long) - Static method in class alluxio.util.io.ByteIOUtils
Writes a specific long value (8 bytes) to the output stream.
writePacket(ByteBuf) - Method in class alluxio.client.block.stream.LocalFilePacketWriter
 
writePacket(ByteBuf) - Method in class alluxio.client.block.stream.NettyPacketWriter
 
writePacket(ByteBuf) - Method in interface alluxio.client.block.stream.PacketWriter
Writes a packet.
writePartition() - Method in class alluxio.examples.Performance.AlluxioWriterWorker
Writes a partition.
writeReplace() - Method in class alluxio.proto.dataserver.Protocol.AsyncCacheRequest
 
writeReplace() - Method in class alluxio.proto.dataserver.Protocol.CreateUfsFileOptions
 
writeReplace() - Method in class alluxio.proto.dataserver.Protocol.Heartbeat
 
writeReplace() - Method in class alluxio.proto.dataserver.Protocol.LocalBlockCloseRequest
 
writeReplace() - Method in class alluxio.proto.dataserver.Protocol.LocalBlockCompleteRequest
 
writeReplace() - Method in class alluxio.proto.dataserver.Protocol.LocalBlockCreateRequest
 
writeReplace() - Method in class alluxio.proto.dataserver.Protocol.LocalBlockCreateResponse
 
writeReplace() - Method in class alluxio.proto.dataserver.Protocol.LocalBlockOpenRequest
 
writeReplace() - Method in class alluxio.proto.dataserver.Protocol.LocalBlockOpenResponse
 
writeReplace() - Method in class alluxio.proto.dataserver.Protocol.OpenUfsBlockOptions
 
writeReplace() - Method in class alluxio.proto.dataserver.Protocol.ReadRequest
 
writeReplace() - Method in class alluxio.proto.dataserver.Protocol.ReadResponse
 
writeReplace() - Method in class alluxio.proto.dataserver.Protocol.Response
 
writeReplace() - Method in class alluxio.proto.dataserver.Protocol.WriteRequest
 
writeReplace() - Method in class alluxio.proto.journal.Block.BlockContainerIdGeneratorEntry
 
writeReplace() - Method in class alluxio.proto.journal.Block.BlockInfoEntry
 
writeReplace() - Method in class alluxio.proto.journal.Block.DeleteBlockEntry
 
writeReplace() - Method in class alluxio.proto.journal.File.AddMountPointEntry
 
writeReplace() - Method in class alluxio.proto.journal.File.AsyncPersistRequestEntry
 
writeReplace() - Method in class alluxio.proto.journal.File.CompleteFileEntry
 
writeReplace() - Method in class alluxio.proto.journal.File.DeleteFileEntry
 
writeReplace() - Method in class alluxio.proto.journal.File.DeleteMountPointEntry
 
writeReplace() - Method in class alluxio.proto.journal.File.InodeDirectoryEntry
 
writeReplace() - Method in class alluxio.proto.journal.File.InodeDirectoryIdGeneratorEntry
 
writeReplace() - Method in class alluxio.proto.journal.File.InodeFileEntry
 
writeReplace() - Method in class alluxio.proto.journal.File.InodeLastModificationTimeEntry
 
writeReplace() - Method in class alluxio.proto.journal.File.PersistDirectoryEntry
 
writeReplace() - Method in class alluxio.proto.journal.File.PersistFileEntry
 
writeReplace() - Method in class alluxio.proto.journal.File.ReinitializeFileEntry
 
writeReplace() - Method in class alluxio.proto.journal.File.RenameEntry
 
writeReplace() - Method in class alluxio.proto.journal.File.SetAttributeEntry
 
writeReplace() - Method in class alluxio.proto.journal.File.StringPairEntry
 
writeReplace() - Method in class alluxio.proto.journal.File.UpdateUfsModeEntry
 
writeReplace() - Method in class alluxio.proto.journal.Journal.JournalEntry
 
writeReplace() - Method in class alluxio.proto.journal.KeyValue.CompletePartitionEntry
 
writeReplace() - Method in class alluxio.proto.journal.KeyValue.CompleteStoreEntry
 
writeReplace() - Method in class alluxio.proto.journal.KeyValue.CreateStoreEntry
 
writeReplace() - Method in class alluxio.proto.journal.KeyValue.DeleteStoreEntry
 
writeReplace() - Method in class alluxio.proto.journal.KeyValue.MergeStoreEntry
 
writeReplace() - Method in class alluxio.proto.journal.KeyValue.RenameStoreEntry
 
writeReplace() - Method in class alluxio.proto.journal.Lineage.DeleteLineageEntry
 
writeReplace() - Method in class alluxio.proto.journal.Lineage.LineageEntry
 
writeReplace() - Method in class alluxio.proto.journal.Lineage.LineageIdGeneratorEntry
 
WriteRequestContext<T extends alluxio.worker.netty.WriteRequest> - Class in alluxio.worker.netty
Represents the context of a write request received from netty channel.
WriteRequestContext(T) - Constructor for class alluxio.worker.netty.WriteRequestContext
 
writeShort(byte[], int, short) - Static method in class alluxio.util.io.ByteIOUtils
Writes a specific short value (2 bytes) to the output byte buffer at the given offset.
writeShort(OutputStream, short) - Static method in class alluxio.util.io.ByteIOUtils
Writes a specific short value (2 bytes) to the output stream.
writeTo(CodedOutputStream) - Method in class alluxio.proto.dataserver.Protocol.AsyncCacheRequest
 
writeTo(CodedOutputStream) - Method in class alluxio.proto.dataserver.Protocol.CreateUfsFileOptions
 
writeTo(CodedOutputStream) - Method in class alluxio.proto.dataserver.Protocol.Heartbeat
 
writeTo(CodedOutputStream) - Method in class alluxio.proto.dataserver.Protocol.LocalBlockCloseRequest
 
writeTo(CodedOutputStream) - Method in class alluxio.proto.dataserver.Protocol.LocalBlockCompleteRequest
 
writeTo(CodedOutputStream) - Method in class alluxio.proto.dataserver.Protocol.LocalBlockCreateRequest
 
writeTo(CodedOutputStream) - Method in class alluxio.proto.dataserver.Protocol.LocalBlockCreateResponse
 
writeTo(CodedOutputStream) - Method in class alluxio.proto.dataserver.Protocol.LocalBlockOpenRequest
 
writeTo(CodedOutputStream) - Method in class alluxio.proto.dataserver.Protocol.LocalBlockOpenResponse
 
writeTo(CodedOutputStream) - Method in class alluxio.proto.dataserver.Protocol.OpenUfsBlockOptions
 
writeTo(CodedOutputStream) - Method in class alluxio.proto.dataserver.Protocol.ReadRequest
 
writeTo(CodedOutputStream) - Method in class alluxio.proto.dataserver.Protocol.ReadResponse
 
writeTo(CodedOutputStream) - Method in class alluxio.proto.dataserver.Protocol.Response
 
writeTo(CodedOutputStream) - Method in class alluxio.proto.dataserver.Protocol.WriteRequest
 
writeTo(CodedOutputStream) - Method in class alluxio.proto.journal.Block.BlockContainerIdGeneratorEntry
 
writeTo(CodedOutputStream) - Method in class alluxio.proto.journal.Block.BlockInfoEntry
 
writeTo(CodedOutputStream) - Method in class alluxio.proto.journal.Block.DeleteBlockEntry
 
writeTo(CodedOutputStream) - Method in class alluxio.proto.journal.File.AddMountPointEntry
 
writeTo(CodedOutputStream) - Method in class alluxio.proto.journal.File.AsyncPersistRequestEntry
 
writeTo(CodedOutputStream) - Method in class alluxio.proto.journal.File.CompleteFileEntry
 
writeTo(CodedOutputStream) - Method in class alluxio.proto.journal.File.DeleteFileEntry
 
writeTo(CodedOutputStream) - Method in class alluxio.proto.journal.File.DeleteMountPointEntry
 
writeTo(CodedOutputStream) - Method in class alluxio.proto.journal.File.InodeDirectoryEntry
 
writeTo(CodedOutputStream) - Method in class alluxio.proto.journal.File.InodeDirectoryIdGeneratorEntry
 
writeTo(CodedOutputStream) - Method in class alluxio.proto.journal.File.InodeFileEntry
 
writeTo(CodedOutputStream) - Method in class alluxio.proto.journal.File.InodeLastModificationTimeEntry
 
writeTo(CodedOutputStream) - Method in class alluxio.proto.journal.File.PersistDirectoryEntry
 
writeTo(CodedOutputStream) - Method in class alluxio.proto.journal.File.PersistFileEntry
 
writeTo(CodedOutputStream) - Method in class alluxio.proto.journal.File.ReinitializeFileEntry
 
writeTo(CodedOutputStream) - Method in class alluxio.proto.journal.File.RenameEntry
 
writeTo(CodedOutputStream) - Method in class alluxio.proto.journal.File.SetAttributeEntry
 
writeTo(CodedOutputStream) - Method in class alluxio.proto.journal.File.StringPairEntry
 
writeTo(CodedOutputStream) - Method in class alluxio.proto.journal.File.UpdateUfsModeEntry
 
writeTo(CodedOutputStream) - Method in class alluxio.proto.journal.Journal.JournalEntry
 
writeTo(CodedOutputStream) - Method in class alluxio.proto.journal.KeyValue.CompletePartitionEntry
 
writeTo(CodedOutputStream) - Method in class alluxio.proto.journal.KeyValue.CompleteStoreEntry
 
writeTo(CodedOutputStream) - Method in class alluxio.proto.journal.KeyValue.CreateStoreEntry
 
writeTo(CodedOutputStream) - Method in class alluxio.proto.journal.KeyValue.DeleteStoreEntry
 
writeTo(CodedOutputStream) - Method in class alluxio.proto.journal.KeyValue.MergeStoreEntry
 
writeTo(CodedOutputStream) - Method in class alluxio.proto.journal.KeyValue.RenameStoreEntry
 
writeTo(CodedOutputStream) - Method in class alluxio.proto.journal.Lineage.DeleteLineageEntry
 
writeTo(CodedOutputStream) - Method in class alluxio.proto.journal.Lineage.LineageEntry
 
writeTo(CodedOutputStream) - Method in class alluxio.proto.journal.Lineage.LineageIdGeneratorEntry
 
WriteType - Enum in alluxio.client
Write types for creating a file in Alluxio.
writeYMLFile(Collection<? extends PropertyKey>, String) - Static method in class alluxio.cli.ConfigurationDocGenerator
Writes description of property key to yml files.

Z

ZkMasterConnectDetails(String, String) - Constructor for class alluxio.master.ZkMasterInquireClient.ZkMasterConnectDetails
 
ZkMasterInquireClient - Class in alluxio.master
Utility to get leader from zookeeper.
ZkMasterInquireClient.ZkMasterConnectDetails - Class in alluxio.master
Details used to connect to the leader Alluxio master via Zookeeper.
ZOOKEEPER_ADDRESS - Static variable in class alluxio.PropertyKey.Name
 
ZOOKEEPER_ADDRESS - Static variable in class alluxio.PropertyKey
 
ZOOKEEPER_AUTH_ENABLED - Static variable in class alluxio.PropertyKey.Name
 
ZOOKEEPER_AUTH_ENABLED - Static variable in class alluxio.PropertyKey
 
ZOOKEEPER_CONNECTION_POLICY_SESSION - Static variable in class alluxio.multi.process.PortCoordination
 
ZOOKEEPER_CONNECTION_POLICY_STANDARD - Static variable in class alluxio.multi.process.PortCoordination
 
ZOOKEEPER_CONNECTION_TIMEOUT - Static variable in class alluxio.PropertyKey.Name
 
ZOOKEEPER_CONNECTION_TIMEOUT - Static variable in class alluxio.PropertyKey
 
ZOOKEEPER_ELECTION_PATH - Static variable in class alluxio.PropertyKey.Name
 
ZOOKEEPER_ELECTION_PATH - Static variable in class alluxio.PropertyKey
 
ZOOKEEPER_ENABLED - Static variable in class alluxio.PropertyKey.Name
 
ZOOKEEPER_ENABLED - Static variable in class alluxio.PropertyKey
 
ZOOKEEPER_FAILURE - Static variable in class alluxio.multi.process.PortCoordination
 
ZOOKEEPER_LEADER_CONNECTION_ERROR_POLICY - Static variable in class alluxio.PropertyKey.Name
 
ZOOKEEPER_LEADER_CONNECTION_ERROR_POLICY - Static variable in class alluxio.PropertyKey
 
ZOOKEEPER_LEADER_INQUIRY_RETRY_COUNT - Static variable in class alluxio.PropertyKey.Name
 
ZOOKEEPER_LEADER_INQUIRY_RETRY_COUNT - Static variable in class alluxio.PropertyKey
 
ZOOKEEPER_LEADER_PATH - Static variable in class alluxio.PropertyKey.Name
 
ZOOKEEPER_LEADER_PATH - Static variable in class alluxio.PropertyKey
 
ZOOKEEPER_SESSION_TIMEOUT - Static variable in class alluxio.PropertyKey.Name
 
ZOOKEEPER_SESSION_TIMEOUT - Static variable in class alluxio.PropertyKey
 
A B C D E F G H I J K L M N O P Q R S T U V W Z 
Skip navigation links

Copyright © 2023. All Rights Reserved.