public interface GiraphConstants
Modifier and Type | Field and Description |
---|---|
static FloatConfOption |
ADDITIONAL_EDGE_REQUEST_SIZE
Additional size (expressed as a ratio) of each per-partition buffer on
top of the average size for edges.
|
static FloatConfOption |
ADDITIONAL_MSG_REQUEST_SIZE
How much bigger than the average per partition size to make initial per
partition buffers.
|
static FloatConfOption |
ADDITIONAL_VERTEX_REQUEST_SIZE
Additional size (expressed as a ratio) of each per-partition buffer on
top of the average size for vertices.
|
static ClassConfOption<AggregatorWriter> |
AGGREGATOR_WRITER_CLASS
AggregatorWriter class - optional
|
static IntConfOption |
ASYNC_MESSAGE_STORE_THREADS_COUNT
Number of threads to use in async message store, 0 means
we should not use async message processing
|
static BooleanConfOption |
AUTHENTICATE
Whether to use SASL with DIGEST and Hadoop Job Tokens to authenticate
and authorize Netty BSP Clients to Servers.
|
static String |
BASE_ZNODE_KEY
Base ZNode for Giraph's state in the ZooKeeper cluster.
|
static IntConfOption |
CHANNELS_PER_SERVER
Number of channels used per server
|
static StrConfOption |
CHECKPOINT_COMPRESSION_CODEC
Compression algorithm to be used for checkpointing.
|
static StrConfOption |
CHECKPOINT_DIRECTORY
This directory has/stores the available checkpoint files in HDFS.
|
static IntConfOption |
CHECKPOINT_FREQUENCY
How often to checkpoint (i.e.
|
static ClassConfOption<CheckpointSupportedChecker> |
CHECKPOINT_SUPPORTED_CHECKER
Defines if and when checkpointing is supported by this job.
|
static BooleanConfOption |
CLEANUP_CHECKPOINTS_AFTER_SUCCESS
Delete checkpoints after a successful job run?
|
static IntConfOption |
CLIENT_RECEIVE_BUFFER_SIZE
Client receive buffer size
|
static IntConfOption |
CLIENT_SEND_BUFFER_SIZE
Client send buffer size
|
static ClassConfOption<Computation> |
COMPUTATION_CLASS
Computation class - required
|
static ClassConfOption<ComputationFactory> |
COMPUTATION_FACTORY_CLASS
Computation factory class - optional
|
static EnumConfOption<Language> |
COMPUTATION_LANGUAGE
Which language computation is implemented in
|
static BooleanConfOption |
CREATE_EDGE_SOURCE_VERTICES
This option can be used to specify if a source vertex present in edge
input but not in vertex input can be created
|
static ClassConfOption<CreateSourceVertexCallback> |
CREATE_EDGE_SOURCE_VERTICES_CALLBACK
Defines a call back that can be used to make decisions on
whether the vertex should be created or not in the runtime.
|
static int |
DEFAULT_ZOOKEEPER_MAX_CLIENT_CNXNS
Default ZooKeeper maximum client connections.
|
static int |
DEFAULT_ZOOKEEPER_SNAP_COUNT
Default ZooKeeper snap count.
|
static int |
DEFAULT_ZOOKEEPER_TICK_TIME
Default ZooKeeper tick time.
|
static BooleanConfOption |
DISABLE_GIRAPH_CLASS_RESOLVER
Whether to disable GiraphClassResolver which is an efficient
implementation of kryo class resolver.
|
static StrConfOption |
DNS_INTERFACE
Interface to use for hostname resolution
|
static StrConfOption |
DNS_NAMESERVER
Server for hostname resolution
|
static BooleanConfOption |
DO_OUTPUT_DURING_COMPUTATION
If you use this option, instead of having saving vertices in the end of
application, saveVertex will be called right after each vertex.compute()
is called.
|
static ClassConfOption<EdgeInputFilter> |
EDGE_INPUT_FILTER_CLASS
EdgeInputFilter class
|
static ClassConfOption<EdgeInputFormat> |
EDGE_INPUT_FORMAT_CLASS
EdgeInputFormat class
|
static ClassConfOption<EdgeOutputFormat> |
EDGE_OUTPUT_FORMAT_CLASS
EdgeOutputFormat class
|
static StrConfOption |
EDGE_OUTPUT_FORMAT_SUBDIR
EdgeOutputFormat sub-directory
|
static ClassConfOption<EdgeStoreFactory> |
EDGE_STORE_FACTORY_CLASS
Edge Store Factory
|
static ClassConfOption |
EDGE_TRANSLATION_CLASS
Class used to conduct expensive edge translation during vertex input
|
static ClassConfOption<org.apache.hadoop.io.Writable> |
EDGE_VALUE_CLASS
Edge value class
|
static ClassConfOption<EdgeValueFactory> |
EDGE_VALUE_FACTORY_CLASS
Edge value factory class - optional
|
static IntConfOption |
EVENT_WAIT_MSECS
Millseconds to wait for an event before continuing
|
static BooleanConfOption |
FAIL_FIRST_IPC_PORT_BIND_ATTEMPT
Fail first IPC port binding attempt, simulate binding failure
on real grid testing
|
static BooleanConfOption |
FAIL_ON_EMPTY_INPUT
Whether to fail the job or just warn when input is empty
|
static ClassConfOption<GcObserver> |
GC_OBSERVER_CLASSES
Classes for GC Observer - optional
|
static BooleanConfOption |
GIRAPH_TEXT_OUTPUT_FORMAT_REVERSE
Reverse values in the output
|
static StrConfOption |
GIRAPH_TEXT_OUTPUT_FORMAT_SEPARATOR
GiraphTextOuputFormat Separator
|
static String |
GIRAPH_YARN_CONF_FILE
Name of the XML file that will export our Configuration to YARN workers
|
static StrConfOption |
GIRAPH_YARN_LIBJARS
conf key for comma-separated list of jars to export to YARN workers
|
static int |
GIRAPH_YARN_PRIORITY
Default priority level in YARN for our task containers
|
static IntConfOption |
GIRAPH_YARN_TASK_HEAP_MB
Name of Giraph property for user-configurable heap memory per worker
|
static int |
GIRAPH_YARN_TASK_HEAP_MB_DEFAULT
Giraph default heap size for all tasks when running on YARN profile
|
static ClassConfOption<GraphPartitionerFactory> |
GRAPH_PARTITIONER_FACTORY_CLASS
Graph partitioner factory class - optional
|
static PerGraphTypeEnumConfOption<Language> |
GRAPH_TYPE_LANGUAGES
Language user's graph types are implemented in
|
static PerGraphTypeBooleanConfOption |
GRAPH_TYPES_NEEDS_WRAPPERS
Whether user graph types need wrappers
|
static ClassConfOption<org.apache.hadoop.mapreduce.OutputFormat> |
HADOOP_OUTPUT_FORMAT_CLASS
Output format class for hadoop to use (for committing)
|
static ClassConfOption<HaltApplicationUtils.HaltInstructionsWriter> |
HALT_INSTRUCTIONS_WRITER_CLASS
Which class to use to write instructions on how to halt the application
|
static IntConfOption |
HDFS_FILE_CREATION_RETRIES
Number of retries for creating the HDFS files
|
static IntConfOption |
HDFS_FILE_CREATION_RETRY_WAIT_MS
Number of milliseconds to wait before retrying HDFS file creation
|
static LongConfOption |
INPUT_SPLIT_MAX_EDGES
To limit outlier vertex input splits from producing too many vertices or
to help with testing, the number of edges loaded from an input split
can be limited.
|
static LongConfOption |
INPUT_SPLIT_MAX_VERTICES
To limit outlier vertex input splits from producing too many vertices or
to help with testing, the number of vertices loaded from an input split
can be limited.
|
static FloatConfOption |
INPUT_SPLIT_SAMPLE_PERCENT
Input split sample percent - Used only for sampling and testing, rather
than an actual job.
|
static ClassConfOption<OutEdges> |
INPUT_VERTEX_EDGES_CLASS
Vertex edges class to be used during edge input only - optional
|
static ClassConfOption<OutEdgesFactory> |
INPUT_VERTEX_EDGES_FACTORY_CLASS
OutEdges for input factory class - optional
|
static IntConfOption |
IPC_INITIAL_PORT
Initial port to start using for the IPC communication
|
static BooleanConfOption |
IS_PURE_YARN_JOB
Is this a pure YARN job (i.e.
|
static BooleanConfOption |
JMAP_ENABLE
Configuration key to enable jmap printing
|
static BooleanConfOption |
JMAP_LIVE_ONLY
Configuration key for printing live objects only
This option will trigger Full GC for every jmap dump
and so can significantly hinder performance.
|
static StrConfOption |
JMAP_PATH
Path where jmap exists
|
static IntConfOption |
JMAP_PRINT_LINES
Configuration key for how many lines to print
|
static IntConfOption |
JMAP_SLEEP_MILLIS
Configuration key for msec to sleep between calls
|
static ClassConfOption<GiraphJobObserver> |
JOB_OBSERVER_CLASS
Observer class to watch over job status - optional
|
static ClassConfOption<JobProgressTrackerClient> |
JOB_PROGRESS_TRACKER_CLIENT_CLASS
Class to use as the job progress client
|
static ClassConfOption<JobProgressTrackerService> |
JOB_PROGRESS_TRACKER_SERVICE_CLASS
Class to use to track job progress on client
|
static ClassConfOption<GiraphJobRetryChecker> |
JOB_RETRY_CHECKER_CLASS
Observer class to watch over job status - optional
|
static BooleanConfOption |
KEEP_ZOOKEEPER_DATA
Keep the zookeeper output for debugging? Default is to remove it.
|
static IntConfOption |
LB_MAPPINGSTORE_LOWER
Lower value of LongByteMappingStore
|
static IntConfOption |
LB_MAPPINGSTORE_UPPER
Upper value of LongByteMappingStore
|
static BooleanConfOption |
LOCAL_TEST_MODE
Indicates whether this job is run in an internal unit test
|
static StrConfOption |
LOG_LEVEL
Override the Hadoop log level and set the desired log level.
|
static BooleanConfOption |
LOG_THREAD_LAYOUT
Use thread level debugging?
|
static ClassConfOption<MapperObserver> |
MAPPER_OBSERVER_CLASSES
Classes for Mapper Observer - optional
|
static ClassConfOption<MappingInputFormat> |
MAPPING_INPUT_FORMAT_CLASS
MappingInputFormat class
|
static ClassConfOption<MappingStore> |
MAPPING_STORE_CLASS
Mapping related information
|
static ClassConfOption<MappingStoreOps> |
MAPPING_STORE_OPS_CLASS
Class to use for performing read operations on mapping store
|
static ClassConfOption<MasterCompute> |
MASTER_COMPUTE_CLASS
Class for Master - optional
|
static ClassConfOption<MasterObserver> |
MASTER_OBSERVER_CLASSES
Classes for Master Observer - optional
|
static LongConfOption |
MAX_ALLOWED_JOB_TIME_MS
Maximum allowed time for job to run after getting all resources before it
will be killed, in milliseconds (-1 if it has no limit)
|
static IntConfOption |
MAX_COUNTER_WAIT_MSECS
Maximum milliseconds to wait before giving up waiting for the workers to
write the counters to the Zookeeper after a superstep
|
static IntConfOption |
MAX_EDGE_REQUEST_SIZE
Maximum size of edges (in bytes) per peer before flush
|
static IntConfOption |
MAX_IPC_PORT_BIND_ATTEMPTS
Maximum bind attempts for different IPC ports
|
static IntConfOption |
MAX_MASTER_SUPERSTEP_WAIT_MSECS
Maximum milliseconds to wait before giving up trying to get the minimum
number of workers before a superstep (int).
|
static IntConfOption |
MAX_MSG_REQUEST_SIZE
Maximum size of messages (in bytes) per peer before flush
|
static IntConfOption |
MAX_MUTATIONS_PER_REQUEST
Maximum number of mutations per partition before flush
|
static IntConfOption |
MAX_NUMBER_OF_SUPERSTEPS
The application will halt after this many supersteps is completed.
|
static IntConfOption |
MAX_PARTITIONS_IN_MEMORY
Maximum number of partitions to hold in memory for each worker.
|
static IntConfOption |
MAX_REQUEST_MILLISECONDS
Milliseconds for a request to complete (or else resend)
|
static IntConfOption |
MAX_RESOLVE_ADDRESS_ATTEMPTS
Max resolve address attempts
|
static IntConfOption |
MAX_TASK_ATTEMPTS
Maximum number of attempts a master/worker will retry before killing
the job.
|
static IntConfOption |
MAX_VERTEX_REQUEST_SIZE
Maximum size of vertices (in bytes) per peer before flush
|
static String |
MAX_WORKERS
Maximum number of simultaneous worker tasks started by this job (int).
|
static ClassConfOption<MessageCombiner> |
MESSAGE_COMBINER_CLASS
Message combiner class - optional
|
static EnumConfOption<MessageEncodeAndStoreType> |
MESSAGE_ENCODE_AND_STORE_TYPE
This option will tell which message encode & store enum to use when
combining is not enabled
|
static ClassConfOption<MessageStoreFactory> |
MESSAGE_STORE_FACTORY_CLASS
Message Store Factory
|
static StrConfOption |
METRICS_DIRECTORY
Directory in HDFS to write master metrics to, instead of stderr
|
static BooleanConfOption |
METRICS_ENABLE
Enable the Metrics system
|
static IntConfOption |
MIN_FREE_MBS_ON_HEAP
Option used by ReactiveJMapHistoDumper to check for an imminent
OOM in worker or master process
|
static IntConfOption |
MIN_PARTITIONS_PER_COMPUTE_THREAD
Minimum number of partitions to have per compute thread
|
static FloatConfOption |
MIN_PERCENT_RESPONDED
Minimum percent of the maximum number of workers that have responded
in order to continue progressing.
|
static String |
MIN_WORKERS
Minimum number of simultaneous workers before this job can run (int)
|
static String |
MSG_NUM_FLUSH_THREADS
Number of flush threads per peer
|
static StrConfOption |
NETTY_CLIENT_EXECUTION_AFTER_HANDLER
Where to place the netty client execution handle?
|
static IntConfOption |
NETTY_CLIENT_EXECUTION_THREADS
Netty client execution threads (execution handler)
|
static IntConfOption |
NETTY_CLIENT_THREADS
Netty client threads
|
static BooleanConfOption |
NETTY_CLIENT_USE_EXECUTION_HANDLER
Use the execution handler in netty on the client?
|
static StrConfOption |
NETTY_COMPRESSION_ALGORITHM
Netty - set which compression to use
|
static IntConfOption |
NETTY_MAX_CONNECTION_FAILURES
Netty max connection failures
|
static IntConfOption |
NETTY_REQUEST_ENCODER_BUFFER_SIZE
How big to make the encoder buffer?
|
static StrConfOption |
NETTY_SERVER_EXECUTION_AFTER_HANDLER
Where to place the netty server execution handle?
|
static IntConfOption |
NETTY_SERVER_EXECUTION_THREADS
Netty server execution threads (execution handler)
|
static IntConfOption |
NETTY_SERVER_THREADS
Netty server threads
|
static BooleanConfOption |
NETTY_SERVER_USE_EXECUTION_HANDLER
Use the execution handler in netty on the server?
|
static BooleanConfOption |
NETTY_SIMULATE_FIRST_REQUEST_CLOSED
Netty simulate a first request closed
|
static BooleanConfOption |
NETTY_SIMULATE_FIRST_RESPONSE_FAILED
Netty simulate a first response failed
|
static BooleanConfOption |
NETTY_USE_DIRECT_MEMORY
Use direct memory buffers in netty
|
static BooleanConfOption |
NETTY_USE_POOLED_ALLOCATOR
Use netty pooled memory buffer allocator
|
static IntConfOption |
NUM_CHECKPOINT_IO_THREADS
Number of threads for writing and reading checkpoints
|
static IntConfOption |
NUM_COMPUTE_THREADS
Number of threads for vertex computation
|
static IntConfOption |
NUM_INPUT_THREADS
Number of threads for input split loading
|
static IntConfOption |
NUM_OUT_OF_CORE_THREADS
Number of IO threads used in out-of-core mechanism.
|
static IntConfOption |
NUM_OUTPUT_THREADS
Number of threads for writing output in the end of the application
|
static int |
ONE_KB
1KB in bytes
|
static int |
ONE_MB
1MB in bytes
|
static ClassConfOption<OutOfCoreDataAccessor> |
OUT_OF_CORE_DATA_ACCESSOR
Data accessor resource/object
|
static ClassConfOption<OutOfCoreOracle> |
OUT_OF_CORE_ORACLE
Out-of-core oracle that is to be used for adaptive out-of-core engine.
|
static ClassConfOption<org.apache.hadoop.io.Writable> |
OUTGOING_MESSAGE_VALUE_CLASS
Outgoing message value class
|
static ClassConfOption<MessageValueFactory> |
OUTGOING_MESSAGE_VALUE_FACTORY_CLASS
Outgoing message value factory class - optional
|
static ClassConfOption<Partition> |
PARTITION_CLASS
Partition class - optional
|
static FloatConfOption |
PARTITION_COUNT_MULTIPLIER
Multiplier for the current workers squared
|
static IntConfOption |
PARTITION_LONG_TAIL_MIN_PRINT
Minimum stragglers of the superstep before printing them out
|
static String |
PARTITION_VERTEX_KEY_SPACE_SIZE
Vertex key space size for
WorkerGraphPartitionerImpl |
static StrConfOption |
PARTITIONS_DIRECTORY
Comma-separated list of directories in the local filesystem for
out-of-core partitions.
|
static BooleanConfOption |
PREFER_IP_ADDRESSES
For worker to worker communication we can use IPs or host names, by
default prefer IPs.
|
static BooleanConfOption |
REACTIVE_JMAP_ENABLE
Option can be used to enable reactively dumping jmap histo when
OOM is imminent
|
static FloatConfOption |
REQUEST_SIZE_WARNING_THRESHOLD
Warn if msg request size exceeds default size by this factor
|
static BooleanConfOption |
RESEND_TIMED_OUT_REQUESTS
Whether to resend request which timed out or fail the job if timeout
happens
|
static BooleanConfOption |
RESOLVER_CREATE_VERTEX_ON_MSGS
Option of whether to create vertexes that were not existent before but
received messages
|
static StrConfOption |
RESTART_JOB_ID
If application is restarted manually we need to specify job ID
to restart from.
|
static String |
RESTART_SUPERSTEP
An application can be restarted manually by selecting a superstep.
|
static IntConfOption |
SERVER_RECEIVE_BUFFER_SIZE
Server receive buffer size
|
static IntConfOption |
SERVER_SEND_BUFFER_SIZE
Server send buffer size
|
static BooleanConfOption |
SPLIT_MASTER_WORKER
Separate the workers and the master tasks.
|
static BooleanConfOption |
STATIC_GRAPH
The application will not mutate the graph topology (the edges).
|
static IntConfOption |
SUPERSTEP_COUNT
Number of supersteps job will run for
|
static IntConfOption |
TCP_BACKLOG
TCP backlog (defaults to number of workers)
|
static BooleanConfOption |
TRACK_JOB_PROGRESS_ON_CLIENT
Whether to track job progress on client or not
|
static ClassConfOption<TypesHolder> |
TYPES_HOLDER_CLASS
TypesHolder, used if Computation not set - optional
|
static BooleanConfOption |
USE_BIG_DATA_IO_FOR_MESSAGES
Use BigDataIO for messages? If there are super-vertices in the
graph which receive a lot of messages (total serialized size of messages
goes beyond the maximum size of a byte array), setting this option to true
will remove that limit.
|
static BooleanConfOption |
USE_INPUT_SPLIT_LOCALITY
To minimize network usage when reading input splits,
each worker can prioritize splits that reside on its host.
|
static BooleanConfOption |
USE_MESSAGE_SIZE_ENCODING
Use message size encoding (typically better for complex objects,
not meant for primitive wrapped messages)
|
static BooleanConfOption |
USE_OUT_OF_CORE_GRAPH
Enable out-of-core graph.
|
static BooleanConfOption |
USE_SUPERSTEP_COUNTERS
Use superstep counters? (boolean)
|
static BooleanConfOption |
USE_UNSAFE_SERIALIZATION
Use unsafe serialization?
|
static IntConfOption |
USER_PARTITION_COUNT
Overrides default partition count calculation if not -1
|
static ClassConfOption<Vertex> |
VERTEX_CLASS
Vertex class
|
static ClassConfOption<OutEdges> |
VERTEX_EDGES_CLASS
Vertex edges class - optional
|
static ClassConfOption<OutEdgesFactory> |
VERTEX_EDGES_FACTORY_CLASS
OutEdges factory class - optional
|
static ClassConfOption<org.apache.hadoop.io.WritableComparable> |
VERTEX_ID_CLASS
Vertex index class
|
static ClassConfOption<VertexIdFactory> |
VERTEX_ID_FACTORY_CLASS
Vertex id factory class - optional
|
static ClassConfOption<VertexInputFilter> |
VERTEX_INPUT_FILTER_CLASS
VertexInputFilter class
|
static ClassConfOption<VertexInputFormat> |
VERTEX_INPUT_FORMAT_CLASS
VertexInputFormat class
|
static ClassConfOption<VertexOutputFormat> |
VERTEX_OUTPUT_FORMAT_CLASS
VertexOutputFormat class
|
static StrConfOption |
VERTEX_OUTPUT_FORMAT_SUBDIR
EdgeOutputFormat sub-directory
|
static BooleanConfOption |
VERTEX_OUTPUT_FORMAT_THREAD_SAFE
Vertex output format thread-safe - if your VertexOutputFormat allows
several vertexWriters to be created and written to in parallel,
you should set this to true.
|
static ClassConfOption<VertexResolver> |
VERTEX_RESOLVER_CLASS
Vertex resolver class - optional
|
static ClassConfOption<org.apache.hadoop.io.Writable> |
VERTEX_VALUE_CLASS
Vertex value class
|
static ClassConfOption<VertexValueCombiner> |
VERTEX_VALUE_COMBINER_CLASS
Vertex value combiner class - optional
|
static ClassConfOption<VertexValueFactory> |
VERTEX_VALUE_FACTORY_CLASS
Vertex value factory class - optional
|
static LongConfOption |
VERTICES_TO_UPDATE_PROGRESS
Minimum number of vertices to compute before adding to worker progress.
|
static LongConfOption |
WAIT_FOR_OTHER_WORKERS_TIMEOUT_MSEC
Timeout for "waitForever", when we need to wait for other workers
to complete their job.
|
static IntConfOption |
WAIT_TASK_DONE_TIMEOUT_MS
Maximum timeout (in milliseconds) for waiting for all tasks
to complete after the job is done.
|
static IntConfOption |
WAIT_TIME_BETWEEN_CONNECTION_RETRIES_MS
How long to wait before trying to reconnect failed connections
|
static LongConfOption |
WAIT_ZOOKEEPER_TIMEOUT_MSEC
Timeout for "waitForever", when we need to wait for zookeeper.
|
static IntConfOption |
WAITING_REQUEST_MSECS
Msecs to wait between waiting for all requests to finish
|
static ClassConfOption<WorkerContext> |
WORKER_CONTEXT_CLASS
Worker context class
|
static ClassConfOption<WorkerObserver> |
WORKER_OBSERVER_CLASSES
Classes for Worker Observer - optional
|
static String |
YOURKIT_OUTPUT_DIR
Directory to write YourKit snapshots to
|
static String |
YOURKIT_OUTPUT_DIR_DEFAULT
Default directory to write YourKit snapshots to
|
static String |
ZOOKEEPER_BASE_PATH_COUNTER_GROUP
This counter group will contain one counter whose name is the ZooKeeper
node path which contains all data about this job
|
static IntConfOption |
ZOOKEEPER_CONNECTION_ATTEMPTS
Number of ZooKeeper client connection attempts before giving up.
|
static String |
ZOOKEEPER_DIR
Local ZooKeeper directory to use
|
static BooleanConfOption |
ZOOKEEPER_FORCE_SYNC
ZooKeeper force sync
|
static String |
ZOOKEEPER_HALT_NODE_COUNTER_GROUP
This counter group will contain one counter whose name is the ZooKeeper
node path which should be created to trigger computation halt
|
static BooleanConfOption |
ZOOKEEPER_IS_EXTERNAL
Zookeeper List will always hold a value during the computation while
this option provides information regarding whether the zookeeper was
internally started or externally provided.
|
static StrConfOption |
ZOOKEEPER_LIST
ZooKeeper comma-separated list (if not set,
will start up ZooKeeper locally).
|
static StrConfOption |
ZOOKEEPER_MANAGER_DIRECTORY
If ZOOKEEPER_LIST is not set, then use this directory to manage
ZooKeeper
|
static IntConfOption |
ZOOKEEPER_MAX_SESSION_TIMEOUT
ZooKeeper maximum session timeout
|
static IntConfOption |
ZOOKEEPER_MIN_SESSION_TIMEOUT
ZooKeeper minimum session timeout
|
static IntConfOption |
ZOOKEEPER_OPS_MAX_ATTEMPTS
Max attempts for handling ZooKeeper connection loss
|
static IntConfOption |
ZOOKEEPER_OPS_RETRY_WAIT_MSECS
Msecs to wait before retrying a failed ZooKeeper op due to connection loss.
|
static int |
ZOOKEEPER_PURGE_INTERVAL
Zookeeper purge interval in hours
|
static IntConfOption |
ZOOKEEPER_SERVER_PORT
ZooKeeper port to use
|
static String |
ZOOKEEPER_SERVER_PORT_COUNTER_GROUP
This counter group will contain one counter whose name is the ZooKeeper
server:port which this job is using
|
static IntConfOption |
ZOOKEEPER_SERVERLIST_POLL_MSECS
Polling interval to check for the ZooKeeper server data
|
static IntConfOption |
ZOOKEEPER_SESSION_TIMEOUT
ZooKeeper session millisecond timeout
|
static BooleanConfOption |
ZOOKEEPER_SKIP_ACL
ZooKeeper skip ACLs
|
static int |
ZOOKEEPER_SNAP_RETAIN_COUNT
Number of snapshots to be retained after purge
|
static final int ONE_KB
static final int ONE_MB
static final ClassConfOption<MappingStore> MAPPING_STORE_CLASS
static final ClassConfOption<MappingStoreOps> MAPPING_STORE_OPS_CLASS
static final IntConfOption LB_MAPPINGSTORE_UPPER
static final IntConfOption LB_MAPPINGSTORE_LOWER
static final ClassConfOption EDGE_TRANSLATION_CLASS
static final ClassConfOption<Computation> COMPUTATION_CLASS
static final ClassConfOption<ComputationFactory> COMPUTATION_FACTORY_CLASS
static final ClassConfOption<TypesHolder> TYPES_HOLDER_CLASS
static final ClassConfOption<EdgeStoreFactory> EDGE_STORE_FACTORY_CLASS
static final ClassConfOption<MessageStoreFactory> MESSAGE_STORE_FACTORY_CLASS
static final PerGraphTypeEnumConfOption<Language> GRAPH_TYPE_LANGUAGES
static final PerGraphTypeBooleanConfOption GRAPH_TYPES_NEEDS_WRAPPERS
static final ClassConfOption<VertexIdFactory> VERTEX_ID_FACTORY_CLASS
static final ClassConfOption<VertexValueFactory> VERTEX_VALUE_FACTORY_CLASS
static final ClassConfOption<EdgeValueFactory> EDGE_VALUE_FACTORY_CLASS
static final ClassConfOption<MessageValueFactory> OUTGOING_MESSAGE_VALUE_FACTORY_CLASS
static final ClassConfOption<OutEdges> VERTEX_EDGES_CLASS
static final ClassConfOption<OutEdges> INPUT_VERTEX_EDGES_CLASS
static final ClassConfOption<OutEdgesFactory> VERTEX_EDGES_FACTORY_CLASS
static final ClassConfOption<OutEdgesFactory> INPUT_VERTEX_EDGES_FACTORY_CLASS
static final ClassConfOption<MasterCompute> MASTER_COMPUTE_CLASS
static final ClassConfOption<MasterObserver> MASTER_OBSERVER_CLASSES
static final ClassConfOption<WorkerObserver> WORKER_OBSERVER_CLASSES
static final ClassConfOption<MapperObserver> MAPPER_OBSERVER_CLASSES
static final ClassConfOption<GcObserver> GC_OBSERVER_CLASSES
static final ClassConfOption<MessageCombiner> MESSAGE_COMBINER_CLASS
static final ClassConfOption<VertexResolver> VERTEX_RESOLVER_CLASS
static final ClassConfOption<VertexValueCombiner> VERTEX_VALUE_COMBINER_CLASS
static final EnumConfOption<Language> COMPUTATION_LANGUAGE
static final BooleanConfOption RESOLVER_CREATE_VERTEX_ON_MSGS
static final ClassConfOption<GraphPartitionerFactory> GRAPH_PARTITIONER_FACTORY_CLASS
static final ClassConfOption<GiraphJobObserver> JOB_OBSERVER_CLASS
static final ClassConfOption<GiraphJobRetryChecker> JOB_RETRY_CHECKER_CLASS
static final LongConfOption MAX_ALLOWED_JOB_TIME_MS
static final ClassConfOption<VertexInputFormat> VERTEX_INPUT_FORMAT_CLASS
static final ClassConfOption<EdgeInputFormat> EDGE_INPUT_FORMAT_CLASS
static final ClassConfOption<MappingInputFormat> MAPPING_INPUT_FORMAT_CLASS
static final ClassConfOption<EdgeInputFilter> EDGE_INPUT_FILTER_CLASS
static final ClassConfOption<VertexInputFilter> VERTEX_INPUT_FILTER_CLASS
static final ClassConfOption<Vertex> VERTEX_CLASS
static final ClassConfOption<VertexOutputFormat> VERTEX_OUTPUT_FORMAT_CLASS
static final StrConfOption VERTEX_OUTPUT_FORMAT_SUBDIR
static final ClassConfOption<EdgeOutputFormat> EDGE_OUTPUT_FORMAT_CLASS
static final StrConfOption EDGE_OUTPUT_FORMAT_SUBDIR
static final StrConfOption GIRAPH_TEXT_OUTPUT_FORMAT_SEPARATOR
static final BooleanConfOption GIRAPH_TEXT_OUTPUT_FORMAT_REVERSE
static final BooleanConfOption DO_OUTPUT_DURING_COMPUTATION
static final BooleanConfOption VERTEX_OUTPUT_FORMAT_THREAD_SAFE
static final IntConfOption NUM_OUTPUT_THREADS
static final StrConfOption GIRAPH_YARN_LIBJARS
static final String GIRAPH_YARN_CONF_FILE
static final int GIRAPH_YARN_TASK_HEAP_MB_DEFAULT
static final IntConfOption GIRAPH_YARN_TASK_HEAP_MB
static final int GIRAPH_YARN_PRIORITY
static final BooleanConfOption IS_PURE_YARN_JOB
static final ClassConfOption<org.apache.hadoop.io.WritableComparable> VERTEX_ID_CLASS
static final ClassConfOption<org.apache.hadoop.io.Writable> VERTEX_VALUE_CLASS
static final ClassConfOption<org.apache.hadoop.io.Writable> EDGE_VALUE_CLASS
static final ClassConfOption<org.apache.hadoop.io.Writable> OUTGOING_MESSAGE_VALUE_CLASS
static final ClassConfOption<WorkerContext> WORKER_CONTEXT_CLASS
static final ClassConfOption<AggregatorWriter> AGGREGATOR_WRITER_CLASS
static final ClassConfOption<Partition> PARTITION_CLASS
static final String MIN_WORKERS
static final String MAX_WORKERS
static final BooleanConfOption SPLIT_MASTER_WORKER
static final BooleanConfOption LOCAL_TEST_MODE
static final StrConfOption LOG_LEVEL
static final BooleanConfOption LOG_THREAD_LAYOUT
static final BooleanConfOption JMAP_ENABLE
static final IntConfOption JMAP_SLEEP_MILLIS
static final IntConfOption JMAP_PRINT_LINES
static final BooleanConfOption JMAP_LIVE_ONLY
static final IntConfOption MIN_FREE_MBS_ON_HEAP
static final BooleanConfOption REACTIVE_JMAP_ENABLE
static final FloatConfOption MIN_PERCENT_RESPONDED
static final BooleanConfOption METRICS_ENABLE
static final StrConfOption METRICS_DIRECTORY
static final StrConfOption ZOOKEEPER_LIST
static final BooleanConfOption ZOOKEEPER_IS_EXTERNAL
static final IntConfOption ZOOKEEPER_SESSION_TIMEOUT
static final IntConfOption ZOOKEEPER_SERVERLIST_POLL_MSECS
static final IntConfOption ZOOKEEPER_SERVER_PORT
static final String ZOOKEEPER_DIR
static final IntConfOption ZOOKEEPER_OPS_MAX_ATTEMPTS
static final IntConfOption ZOOKEEPER_OPS_RETRY_WAIT_MSECS
static final IntConfOption TCP_BACKLOG
static final BooleanConfOption NETTY_USE_POOLED_ALLOCATOR
static final BooleanConfOption NETTY_USE_DIRECT_MEMORY
static final IntConfOption NETTY_REQUEST_ENCODER_BUFFER_SIZE
static final IntConfOption NETTY_CLIENT_THREADS
static final IntConfOption NETTY_SERVER_THREADS
static final BooleanConfOption NETTY_CLIENT_USE_EXECUTION_HANDLER
static final IntConfOption NETTY_CLIENT_EXECUTION_THREADS
static final StrConfOption NETTY_CLIENT_EXECUTION_AFTER_HANDLER
static final BooleanConfOption NETTY_SERVER_USE_EXECUTION_HANDLER
static final IntConfOption NETTY_SERVER_EXECUTION_THREADS
static final StrConfOption NETTY_SERVER_EXECUTION_AFTER_HANDLER
static final BooleanConfOption NETTY_SIMULATE_FIRST_REQUEST_CLOSED
static final BooleanConfOption NETTY_SIMULATE_FIRST_RESPONSE_FAILED
static final StrConfOption NETTY_COMPRESSION_ALGORITHM
static final IntConfOption MAX_RESOLVE_ADDRESS_ATTEMPTS
static final IntConfOption WAITING_REQUEST_MSECS
static final IntConfOption EVENT_WAIT_MSECS
static final IntConfOption MAX_MASTER_SUPERSTEP_WAIT_MSECS
static final IntConfOption MAX_COUNTER_WAIT_MSECS
static final IntConfOption MAX_REQUEST_MILLISECONDS
static final BooleanConfOption RESEND_TIMED_OUT_REQUESTS
static final IntConfOption NETTY_MAX_CONNECTION_FAILURES
static final IntConfOption WAIT_TIME_BETWEEN_CONNECTION_RETRIES_MS
static final IntConfOption IPC_INITIAL_PORT
static final IntConfOption MAX_IPC_PORT_BIND_ATTEMPTS
static final BooleanConfOption FAIL_FIRST_IPC_PORT_BIND_ATTEMPT
static final IntConfOption CLIENT_SEND_BUFFER_SIZE
static final IntConfOption CLIENT_RECEIVE_BUFFER_SIZE
static final IntConfOption SERVER_SEND_BUFFER_SIZE
static final IntConfOption SERVER_RECEIVE_BUFFER_SIZE
static final IntConfOption MAX_MSG_REQUEST_SIZE
static final FloatConfOption ADDITIONAL_MSG_REQUEST_SIZE
static final FloatConfOption REQUEST_SIZE_WARNING_THRESHOLD
static final IntConfOption MAX_VERTEX_REQUEST_SIZE
static final FloatConfOption ADDITIONAL_VERTEX_REQUEST_SIZE
static final IntConfOption MAX_EDGE_REQUEST_SIZE
static final FloatConfOption ADDITIONAL_EDGE_REQUEST_SIZE
static final IntConfOption MAX_MUTATIONS_PER_REQUEST
static final BooleanConfOption USE_MESSAGE_SIZE_ENCODING
static final IntConfOption CHANNELS_PER_SERVER
static final String MSG_NUM_FLUSH_THREADS
static final IntConfOption NUM_COMPUTE_THREADS
static final IntConfOption NUM_INPUT_THREADS
static final IntConfOption PARTITION_LONG_TAIL_MIN_PRINT
static final BooleanConfOption USE_SUPERSTEP_COUNTERS
static final FloatConfOption INPUT_SPLIT_SAMPLE_PERCENT
static final LongConfOption INPUT_SPLIT_MAX_VERTICES
static final LongConfOption INPUT_SPLIT_MAX_EDGES
static final BooleanConfOption USE_INPUT_SPLIT_LOCALITY
static final FloatConfOption PARTITION_COUNT_MULTIPLIER
static final IntConfOption MIN_PARTITIONS_PER_COMPUTE_THREAD
static final IntConfOption USER_PARTITION_COUNT
static final String PARTITION_VERTEX_KEY_SPACE_SIZE
WorkerGraphPartitionerImpl
static final IntConfOption CHECKPOINT_FREQUENCY
static final BooleanConfOption CLEANUP_CHECKPOINTS_AFTER_SUCCESS
static final String RESTART_SUPERSTEP
static final StrConfOption RESTART_JOB_ID
static final String BASE_ZNODE_KEY
static final StrConfOption ZOOKEEPER_MANAGER_DIRECTORY
static final IntConfOption ZOOKEEPER_CONNECTION_ATTEMPTS
static final StrConfOption CHECKPOINT_DIRECTORY
static final StrConfOption PARTITIONS_DIRECTORY
static final IntConfOption NUM_OUT_OF_CORE_THREADS
static final BooleanConfOption USE_OUT_OF_CORE_GRAPH
static final ClassConfOption<OutOfCoreDataAccessor> OUT_OF_CORE_DATA_ACCESSOR
static final ClassConfOption<OutOfCoreOracle> OUT_OF_CORE_ORACLE
static final IntConfOption MAX_PARTITIONS_IN_MEMORY
static final String YOURKIT_OUTPUT_DIR
static final String YOURKIT_OUTPUT_DIR_DEFAULT
static final BooleanConfOption KEEP_ZOOKEEPER_DATA
static final int DEFAULT_ZOOKEEPER_SNAP_COUNT
static final int DEFAULT_ZOOKEEPER_TICK_TIME
static final int DEFAULT_ZOOKEEPER_MAX_CLIENT_CNXNS
static final int ZOOKEEPER_SNAP_RETAIN_COUNT
static final int ZOOKEEPER_PURGE_INTERVAL
static final IntConfOption ZOOKEEPER_MIN_SESSION_TIMEOUT
static final IntConfOption ZOOKEEPER_MAX_SESSION_TIMEOUT
static final BooleanConfOption ZOOKEEPER_FORCE_SYNC
static final BooleanConfOption ZOOKEEPER_SKIP_ACL
static final BooleanConfOption AUTHENTICATE
static final BooleanConfOption USE_UNSAFE_SERIALIZATION
static final BooleanConfOption USE_BIG_DATA_IO_FOR_MESSAGES
static final IntConfOption MAX_TASK_ATTEMPTS
static final StrConfOption DNS_INTERFACE
static final StrConfOption DNS_NAMESERVER
static final IntConfOption MAX_NUMBER_OF_SUPERSTEPS
static final BooleanConfOption STATIC_GRAPH
static final EnumConfOption<MessageEncodeAndStoreType> MESSAGE_ENCODE_AND_STORE_TYPE
static final BooleanConfOption CREATE_EDGE_SOURCE_VERTICES
static final ClassConfOption<CreateSourceVertexCallback> CREATE_EDGE_SOURCE_VERTICES_CALLBACK
static final String ZOOKEEPER_SERVER_PORT_COUNTER_GROUP
static final String ZOOKEEPER_HALT_NODE_COUNTER_GROUP
static final String ZOOKEEPER_BASE_PATH_COUNTER_GROUP
static final ClassConfOption<HaltApplicationUtils.HaltInstructionsWriter> HALT_INSTRUCTIONS_WRITER_CLASS
static final IntConfOption WAIT_TASK_DONE_TIMEOUT_MS
static final BooleanConfOption TRACK_JOB_PROGRESS_ON_CLIENT
static final ClassConfOption<JobProgressTrackerClient> JOB_PROGRESS_TRACKER_CLIENT_CLASS
static final ClassConfOption<JobProgressTrackerService> JOB_PROGRESS_TRACKER_SERVICE_CLASS
static final LongConfOption VERTICES_TO_UPDATE_PROGRESS
static final IntConfOption HDFS_FILE_CREATION_RETRIES
static final IntConfOption HDFS_FILE_CREATION_RETRY_WAIT_MS
static final IntConfOption NUM_CHECKPOINT_IO_THREADS
static final StrConfOption CHECKPOINT_COMPRESSION_CODEC
static final ClassConfOption<CheckpointSupportedChecker> CHECKPOINT_SUPPORTED_CHECKER
static final IntConfOption ASYNC_MESSAGE_STORE_THREADS_COUNT
static final ClassConfOption<org.apache.hadoop.mapreduce.OutputFormat> HADOOP_OUTPUT_FORMAT_CLASS
static final BooleanConfOption PREFER_IP_ADDRESSES
static final LongConfOption WAIT_ZOOKEEPER_TIMEOUT_MSEC
static final LongConfOption WAIT_FOR_OTHER_WORKERS_TIMEOUT_MSEC
static final IntConfOption SUPERSTEP_COUNT
static final BooleanConfOption DISABLE_GIRAPH_CLASS_RESOLVER
static final StrConfOption JMAP_PATH
static final BooleanConfOption FAIL_ON_EMPTY_INPUT
Copyright © 2011-2020 The Apache Software Foundation. All Rights Reserved.