Package | Description |
---|---|
alluxio.client.block | |
alluxio.client.block.policy | |
alluxio.client.block.stream | |
alluxio.client.block.util | |
alluxio.client.file | |
alluxio.grpc | |
alluxio.job | |
alluxio.job.plan.load | |
alluxio.job.util | |
alluxio.job.wire | |
alluxio.master | |
alluxio.master.block | |
alluxio.master.block.meta | |
alluxio.master.job | |
alluxio.stress.cli.client | |
alluxio.util | |
alluxio.util.network | |
alluxio.wire | |
alluxio.worker |
Worker process and utils for working with the worker remotely.
|
alluxio.worker.block | |
alluxio.worker.job | |
alluxio.worker.job.command | |
alluxio.worker.job.task |
Modifier and Type | Method and Description |
---|---|
WorkerNetAddress |
BlockWorkerInfo.getNetAddress() |
Modifier and Type | Method and Description |
---|---|
Pair<WorkerNetAddress,BlockInStream.BlockInStreamSource> |
AlluxioBlockStore.getDataSourceAndType(BlockInfo info,
URIStatus status,
BlockLocationPolicy policy,
Map<WorkerNetAddress,Long> failedWorkers)
Gets the data source and type of data source of a block.
|
Modifier and Type | Method and Description |
---|---|
BlockOutStream |
AlluxioBlockStore.getOutStream(long blockId,
long blockSize,
WorkerNetAddress address,
OutStreamOptions options)
Gets a stream to write data to a block.
|
Modifier and Type | Method and Description |
---|---|
Pair<WorkerNetAddress,BlockInStream.BlockInStreamSource> |
AlluxioBlockStore.getDataSourceAndType(BlockInfo info,
URIStatus status,
BlockLocationPolicy policy,
Map<WorkerNetAddress,Long> failedWorkers)
Gets the data source and type of data source of a block.
|
BlockInStream |
AlluxioBlockStore.getInStream(BlockInfo info,
InStreamOptions options,
Map<WorkerNetAddress,Long> failedWorkers)
|
BlockInStream |
AlluxioBlockStore.getInStream(long blockId,
InStreamOptions options,
Map<WorkerNetAddress,Long> failedWorkers)
Gets a stream to read the data of a block.
|
Constructor and Description |
---|
BlockWorkerInfo(WorkerNetAddress netAddress,
long capacityBytes,
long usedBytes)
Constructs the block worker information.
|
Modifier and Type | Method and Description |
---|---|
WorkerNetAddress |
LocalFirstPolicy.getWorker(GetWorkerOptions options) |
WorkerNetAddress |
LocalFirstAvoidEvictionPolicy.getWorker(GetWorkerOptions options) |
WorkerNetAddress |
RoundRobinPolicy.getWorker(GetWorkerOptions options)
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.
|
WorkerNetAddress |
SpecificHostPolicy.getWorker(GetWorkerOptions options)
Returns null if no active worker matches the hostname
provided in WORKER_HOSTNAME (alluxio.worker.hostname).
|
WorkerNetAddress |
DeterministicHashPolicy.getWorker(GetWorkerOptions options) |
WorkerNetAddress |
MostAvailableFirstPolicy.getWorker(GetWorkerOptions options)
The policy returns null if no worker is qualified.
|
WorkerNetAddress |
BlockLocationPolicy.getWorker(GetWorkerOptions options)
Gets the worker's network address for serving operations requested for the block.
|
Modifier and Type | Method and Description |
---|---|
WorkerNetAddress |
BlockOutStream.getAddress() |
WorkerNetAddress |
BlockInStream.getAddress() |
Modifier and Type | Method and Description |
---|---|
static BlockInStream |
BlockInStream.create(FileSystemContext context,
BlockInfo info,
WorkerNetAddress dataSource,
BlockInStream.BlockInStreamSource dataSourceType,
InStreamOptions options)
Creates a
BlockInStream . |
static DataWriter |
DataWriter.Factory.create(FileSystemContext context,
long blockId,
long blockSize,
WorkerNetAddress address,
OutStreamOptions options) |
static LocalFileDataWriter |
LocalFileDataWriter.create(FileSystemContext context,
WorkerNetAddress address,
long blockId,
long blockSize,
OutStreamOptions options)
Creates an instance of
LocalFileDataWriter . |
static UfsFallbackLocalFileDataWriter |
UfsFallbackLocalFileDataWriter.create(FileSystemContext context,
WorkerNetAddress address,
long blockId,
long blockSize,
OutStreamOptions options) |
static GrpcDataWriter |
GrpcDataWriter.create(FileSystemContext context,
WorkerNetAddress address,
long id,
long length,
RequestType type,
OutStreamOptions options) |
static UnderFileSystemFileOutStream |
UnderFileSystemFileOutStream.create(FileSystemContext context,
WorkerNetAddress address,
OutStreamOptions options)
Creates an instance of
UnderFileSystemFileOutStream that writes to a UFS file. |
static BufferCachingGrpcDataReader |
BufferCachingGrpcDataReader.create(FileSystemContext context,
WorkerNetAddress address,
ReadRequest readRequest)
Creates an instance of
BufferCachingGrpcDataReader for block reads. |
static BlockInStream |
BlockInStream.createRemoteBlockInStream(FileSystemContext context,
long blockId,
WorkerNetAddress address,
BlockInStream.BlockInStreamSource blockSource,
long blockSize,
Protocol.OpenUfsBlockOptions ufsOptions)
Creates a
BlockInStream to read from a specific remote server. |
Modifier and Type | Method and Description |
---|---|
static BlockOutStream |
BlockOutStream.createReplicatedBlockOutStream(FileSystemContext context,
long blockId,
long blockSize,
List<WorkerNetAddress> workerNetAddresses,
OutStreamOptions options)
Creates a new remote block output stream.
|
Constructor and Description |
---|
BlockOutStream(List<DataWriter> dataWriters,
long length,
List<WorkerNetAddress> workerNetAddresses)
Constructs a new
BlockOutStream with only one DataWriter . |
Modifier and Type | Method and Description |
---|---|
static Optional<Pair<WorkerNetAddress,Boolean>> |
BlockLocationUtils.nearest(TieredIdentity tieredIdentity,
List<WorkerNetAddress> addresses,
AlluxioConfiguration conf) |
Modifier and Type | Method and Description |
---|---|
static Optional<Pair<WorkerNetAddress,Boolean>> |
BlockLocationUtils.nearest(TieredIdentity tieredIdentity,
List<WorkerNetAddress> addresses,
AlluxioConfiguration conf) |
Modifier and Type | Method and Description |
---|---|
WorkerNetAddress |
FileSystemContext.getNodeLocalWorker() |
Modifier and Type | Method and Description |
---|---|
CloseableResource<BlockWorkerClient> |
FileSystemContext.acquireBlockWorkerClient(WorkerNetAddress workerNetAddress)
Acquires a block worker client from the client pools.
|
Modifier and Type | Method and Description |
---|---|
static WorkerNetAddress |
GrpcUtils.fromProto(WorkerNetAddress workerNetPAddress)
Converts a proto type to a wire type.
|
Modifier and Type | Method and Description |
---|---|
static WorkerNetAddress |
GrpcUtils.toProto(WorkerNetAddress workerNetAddress)
Converts wire type to proto type.
|
Modifier and Type | Method and Description |
---|---|
WorkerNetAddress |
MasterWorkerInfo.getWorkerAddress() |
Constructor and Description |
---|
MasterWorkerInfo(long id,
WorkerNetAddress address)
Creates a new instance of
MasterWorkerInfo . |
Modifier and Type | Method and Description |
---|---|
WorkerNetAddress |
LoadDefinition.LoadTask.getWorkerNetAddress() |
Constructor and Description |
---|
LoadTask(long blockId,
WorkerNetAddress workerNetAddress) |
Modifier and Type | Method and Description |
---|---|
static void |
JobUtils.loadBlock(URIStatus status,
FileSystemContext context,
long blockId,
WorkerNetAddress address)
Loads a block into the local worker.
|
Constructor and Description |
---|
TaskInfo(long jobId,
long taskId,
Status status,
WorkerNetAddress workerAddress,
Object args)
Constructs a new TaskInfo from jobId, taskId, Status, workerAddress, and arguments.
|
Modifier and Type | Method and Description |
---|---|
WorkerNetAddress |
LocalAlluxioCluster.getWorkerAddress() |
Modifier and Type | Method and Description |
---|---|
Set<WorkerNetAddress> |
DefaultBlockMaster.getWorkerAddresses() |
Set<WorkerNetAddress> |
BlockMaster.getWorkerAddresses() |
Modifier and Type | Method and Description |
---|---|
long |
DefaultBlockMaster.getWorkerId(WorkerNetAddress workerNetAddress) |
long |
BlockMaster.getWorkerId(WorkerNetAddress workerNetAddress)
Returns a worker id for the given worker, creating one if the worker is new.
|
Modifier and Type | Method and Description |
---|---|
WorkerNetAddress |
MasterWorkerInfo.getWorkerAddress()
StaticWorkerMeta is thread safe so the value can be read without locking. |
Constructor and Description |
---|
MasterWorkerInfo(long id,
WorkerNetAddress address)
Creates a new instance of
MasterWorkerInfo . |
StaticWorkerMeta(long id,
WorkerNetAddress address)
Constructor.
|
Modifier and Type | Method and Description |
---|---|
long |
JobMaster.registerWorker(WorkerNetAddress workerNetAddress)
Returns a worker id for the given worker.
|
Modifier and Type | Method and Description |
---|---|
WorkerNetAddress |
ClientIOWritePolicy.getWorker(GetWorkerOptions options) |
Modifier and Type | Method and Description |
---|---|
static boolean |
CommonUtils.isLocalHost(WorkerNetAddress address,
AlluxioConfiguration conf) |
Modifier and Type | Method and Description |
---|---|
static SocketAddress |
NetworkAddressUtils.getDataPortSocketAddress(WorkerNetAddress netAddress,
AlluxioConfiguration conf)
Extracts dataPort socket address from Alluxio representation of network address.
|
static String |
NetworkAddressUtils.getFqdnHost(WorkerNetAddress addr)
Gets FQDN(Full Qualified Domain Name) from Alluxio representation of network address.
|
static InetSocketAddress |
NetworkAddressUtils.getRpcPortSocketAddress(WorkerNetAddress netAddress)
Extracts rpcPort InetSocketAddress from Alluxio representation of network address.
|
static boolean |
NettyUtils.isDomainSocketAccessible(WorkerNetAddress workerNetAddress,
AlluxioConfiguration conf) |
static boolean |
NettyUtils.isDomainSocketSupported(WorkerNetAddress workerNetAddress) |
Modifier and Type | Method and Description |
---|---|
WorkerNetAddress |
WorkerInfo.getAddress() |
WorkerNetAddress |
BlockLocation.getWorkerAddress() |
WorkerNetAddress |
WorkerNetAddress.setContainerHost(String containerHost) |
WorkerNetAddress |
WorkerNetAddress.setDataPort(int dataPort) |
WorkerNetAddress |
WorkerNetAddress.setDomainSocketPath(String domainSocketPath) |
WorkerNetAddress |
WorkerNetAddress.setHost(String host) |
WorkerNetAddress |
WorkerNetAddress.setRpcPort(int rpcPort) |
WorkerNetAddress |
WorkerNetAddress.setTieredIdentity(TieredIdentity tieredIdentity) |
WorkerNetAddress |
WorkerNetAddress.setWebPort(int webPort) |
Modifier and Type | Method and Description |
---|---|
List<WorkerNetAddress> |
BlockLocationInfo.getLocations() |
Modifier and Type | Method and Description |
---|---|
WorkerInfo |
WorkerInfo.setAddress(WorkerNetAddress address) |
BlockLocation |
BlockLocation.setWorkerAddress(WorkerNetAddress workerAddress) |
Constructor and Description |
---|
BlockLocationInfo(FileBlockInfo blockInfo,
List<WorkerNetAddress> locations) |
Modifier and Type | Method and Description |
---|---|
WorkerNetAddress |
AlluxioJobWorkerProcess.getAddress() |
WorkerNetAddress |
JobWorkerProcess.getAddress() |
WorkerNetAddress |
AlluxioWorkerProcess.getAddress() |
WorkerNetAddress |
WorkerProcess.getAddress() |
Modifier and Type | Method and Description |
---|---|
static void |
JobWorkerIdRegistry.registerWorker(JobMasterClient jobMasterClient,
WorkerNetAddress workerAddress)
Registers with
JobMaster to get a new job worker id. |
void |
JobWorker.start(WorkerNetAddress address) |
void |
AbstractWorker.start(WorkerNetAddress address) |
Modifier and Type | Method and Description |
---|---|
long |
BlockMasterClient.getId(WorkerNetAddress address)
Returns a worker id for a workers net address.
|
void |
DefaultBlockWorker.start(WorkerNetAddress address)
Runs the block worker.
|
Constructor and Description |
---|
BlockMasterSync(BlockWorker blockWorker,
AtomicReference<Long> workerId,
WorkerNetAddress workerAddress,
BlockMasterClientPool masterClientPool)
Creates a new instance of
BlockMasterSync . |
Modifier and Type | Method and Description |
---|---|
long |
JobMasterClient.registerWorker(WorkerNetAddress address)
Returns a worker id for a workers net address.
|
long |
RetryHandlingJobMasterClient.registerWorker(WorkerNetAddress address) |
Constructor and Description |
---|
CommandHandlingExecutor(JobServerContext jobServerContext,
TaskExecutorManager taskExecutorManager,
JobMasterClient masterClient,
WorkerNetAddress workerNetAddress)
Creates a new instance of
CommandHandlingExecutor . |
Constructor and Description |
---|
TaskExecutorManager(int taskExecutorPoolSize,
WorkerNetAddress address)
Constructs a new instance of
TaskExecutorManager . |
Copyright © 2023. All Rights Reserved.