| Package | Description | 
|---|---|
| org.apache.giraph.comm.flow_control | Package for flow-control policies. | 
| org.apache.giraph.conf | Package of Giraph configuration related things. | 
| org.apache.giraph.graph | Package of all the graph related objects, built on the
 org.apache.bsp package. | 
| org.apache.giraph.job | Package of all the classes involved in job launch. | 
| org.apache.giraph.ooc | Package of out-of-core related classes. | 
| org.apache.giraph.ooc.data | Package of classes related to data structures used for an out-of-core
 mechanism | 
| org.apache.giraph.ooc.persistence | Package of classes related to IO abstraction or persistence layer used for
 out-of-core mechanism | 
| org.apache.giraph.utils | Package of all generic utility classes. | 
| org.apache.giraph.worker | Package of all the worker related things | 
| Modifier and Type | Field and Description | 
|---|---|
| static IntConfOption | CreditBasedFlowControl. MAX_NUM_OF_OPEN_REQUESTS_PER_WORKERMaximum number of requests we can have per worker without confirmation
 (i.e. | 
| static IntConfOption | CreditBasedFlowControl. MAX_NUM_OF_UNSENT_REQUESTSAggregate number of in-memory unsent requests | 
| static IntConfOption | StaticFlowControl. MAX_NUMBER_OF_OPEN_REQUESTSMaximum number of requests without confirmation we should have | 
| static IntConfOption | CreditBasedFlowControl. UNSENT_CACHE_WAIT_INTERVALTime interval to wait on unsent requests cahce until we find a spot in it | 
| Modifier and Type | Field and Description | 
|---|---|
| static IntConfOption | GiraphConstants. ASYNC_MESSAGE_STORE_THREADS_COUNTNumber of threads to use in async message store, 0 means
 we should not use async message processing | 
| static IntConfOption | GiraphConstants. CHANNELS_PER_SERVERNumber of channels used per server | 
| static IntConfOption | GiraphConstants. CHECKPOINT_FREQUENCYHow often to checkpoint (i.e. | 
| static IntConfOption | GiraphConstants. CLIENT_RECEIVE_BUFFER_SIZEClient receive buffer size | 
| static IntConfOption | GiraphConstants. CLIENT_SEND_BUFFER_SIZEClient send buffer size | 
| static IntConfOption | GiraphConstants. EVENT_WAIT_MSECSMillseconds to wait for an event before continuing | 
| static IntConfOption | GiraphConstants. GIRAPH_YARN_TASK_HEAP_MBName of Giraph property for user-configurable heap memory per worker | 
| static IntConfOption | GiraphConstants. HDFS_FILE_CREATION_RETRIESNumber of retries for creating the HDFS files | 
| static IntConfOption | GiraphConstants. HDFS_FILE_CREATION_RETRY_WAIT_MSNumber of milliseconds to wait before retrying HDFS file creation | 
| static IntConfOption | GiraphConstants. IPC_INITIAL_PORTInitial port to start using for the IPC communication | 
| static IntConfOption | GiraphConstants. JMAP_PRINT_LINESConfiguration key for how many lines to print | 
| static IntConfOption | GiraphConstants. JMAP_SLEEP_MILLISConfiguration key for msec to sleep between calls | 
| static IntConfOption | GiraphConstants. LB_MAPPINGSTORE_LOWERLower value of LongByteMappingStore | 
| static IntConfOption | GiraphConstants. LB_MAPPINGSTORE_UPPERUpper value of LongByteMappingStore | 
| static IntConfOption | FacebookConfiguration. MAPPER_CORESHow many cores per mapper should we use | 
| static IntConfOption | FacebookConfiguration. MAPPER_MEMORYHow much memory per mapper should we use | 
| static IntConfOption | GiraphConstants. MAX_COUNTER_WAIT_MSECSMaximum milliseconds to wait before giving up waiting for the workers to
 write the counters to the Zookeeper after a superstep | 
| static IntConfOption | GiraphConstants. MAX_EDGE_REQUEST_SIZEMaximum size of edges (in bytes) per peer before flush | 
| static IntConfOption | GiraphConstants. MAX_IPC_PORT_BIND_ATTEMPTSMaximum bind attempts for different IPC ports | 
| static IntConfOption | GiraphConstants. MAX_MASTER_SUPERSTEP_WAIT_MSECSMaximum milliseconds to wait before giving up trying to get the minimum
 number of workers before a superstep (int). | 
| static IntConfOption | GiraphConstants. MAX_MSG_REQUEST_SIZEMaximum size of messages (in bytes) per peer before flush | 
| static IntConfOption | GiraphConstants. MAX_MUTATIONS_PER_REQUESTMaximum number of mutations per partition before flush | 
| static IntConfOption | GiraphConstants. MAX_NUMBER_OF_SUPERSTEPSThe application will halt after this many supersteps is completed. | 
| static IntConfOption | GiraphConstants. MAX_PARTITIONS_IN_MEMORYMaximum number of partitions to hold in memory for each worker. | 
| static IntConfOption | GiraphConstants. MAX_REQUEST_MILLISECONDSMilliseconds for a request to complete (or else resend) | 
| static IntConfOption | GiraphConstants. MAX_RESOLVE_ADDRESS_ATTEMPTSMax resolve address attempts | 
| static IntConfOption | GiraphConstants. MAX_TASK_ATTEMPTSMaximum number of attempts a master/worker will retry before killing
 the job. | 
| static IntConfOption | GiraphConstants. MAX_VERTEX_REQUEST_SIZEMaximum size of vertices (in bytes) per peer before flush | 
| static IntConfOption | GiraphConstants. MIN_FREE_MBS_ON_HEAPOption used by ReactiveJMapHistoDumper to check for an imminent
 OOM in worker or master process | 
| static IntConfOption | GiraphConstants. MIN_PARTITIONS_PER_COMPUTE_THREADMinimum number of partitions to have per compute thread | 
| static IntConfOption | GiraphConstants. NETTY_CLIENT_EXECUTION_THREADSNetty client execution threads (execution handler) | 
| static IntConfOption | GiraphConstants. NETTY_CLIENT_THREADSNetty client threads | 
| static IntConfOption | GiraphConstants. NETTY_MAX_CONNECTION_FAILURESNetty max connection failures | 
| static IntConfOption | GiraphConstants. NETTY_REQUEST_ENCODER_BUFFER_SIZEHow big to make the encoder buffer? | 
| static IntConfOption | GiraphConstants. NETTY_SERVER_EXECUTION_THREADSNetty server execution threads (execution handler) | 
| static IntConfOption | GiraphConstants. NETTY_SERVER_THREADSNetty server threads | 
| static IntConfOption | GiraphConstants. NUM_CHECKPOINT_IO_THREADSNumber of threads for writing and reading checkpoints | 
| static IntConfOption | GiraphConstants. NUM_COMPUTE_THREADSNumber of threads for vertex computation | 
| static IntConfOption | GiraphConstants. NUM_INPUT_THREADSNumber of threads for input split loading | 
| static IntConfOption | GiraphConstants. NUM_OUT_OF_CORE_THREADSNumber of IO threads used in out-of-core mechanism. | 
| static IntConfOption | GiraphConstants. NUM_OUTPUT_THREADSNumber of threads for writing output in the end of the application | 
| static IntConfOption | GiraphConstants. PARTITION_LONG_TAIL_MIN_PRINTMinimum stragglers of the superstep before printing them out | 
| static IntConfOption | GiraphConstants. SERVER_RECEIVE_BUFFER_SIZEServer receive buffer size | 
| static IntConfOption | GiraphConstants. SERVER_SEND_BUFFER_SIZEServer send buffer size | 
| static IntConfOption | GiraphConstants. SUPERSTEP_COUNTNumber of supersteps job will run for | 
| static IntConfOption | GiraphConstants. TCP_BACKLOGTCP backlog (defaults to number of workers) | 
| static IntConfOption | GiraphConstants. USER_PARTITION_COUNTOverrides default partition count calculation if not -1 | 
| static IntConfOption | GiraphConstants. WAIT_TASK_DONE_TIMEOUT_MSMaximum timeout (in milliseconds) for waiting for all tasks
 to complete after the job is done. | 
| static IntConfOption | GiraphConstants. WAIT_TIME_BETWEEN_CONNECTION_RETRIES_MSHow long to wait before trying to reconnect failed connections | 
| static IntConfOption | GiraphConstants. WAITING_REQUEST_MSECSMsecs to wait between waiting for all requests to finish | 
| static IntConfOption | GiraphConstants. ZOOKEEPER_CONNECTION_ATTEMPTSNumber of ZooKeeper client connection attempts before giving up. | 
| static IntConfOption | GiraphConstants. ZOOKEEPER_MAX_SESSION_TIMEOUTZooKeeper maximum session timeout | 
| static IntConfOption | GiraphConstants. ZOOKEEPER_MIN_SESSION_TIMEOUTZooKeeper minimum session timeout | 
| static IntConfOption | GiraphConstants. ZOOKEEPER_OPS_MAX_ATTEMPTSMax attempts for handling ZooKeeper connection loss | 
| static IntConfOption | GiraphConstants. ZOOKEEPER_OPS_RETRY_WAIT_MSECSMsecs to wait before retrying a failed ZooKeeper op due to connection loss. | 
| static IntConfOption | GiraphConstants. ZOOKEEPER_SERVER_PORTZooKeeper port to use | 
| static IntConfOption | GiraphConstants. ZOOKEEPER_SERVERLIST_POLL_MSECSPolling interval to check for the ZooKeeper server data | 
| static IntConfOption | GiraphConstants. ZOOKEEPER_SESSION_TIMEOUTZooKeeper session millisecond timeout | 
| Modifier and Type | Field and Description | 
|---|---|
| static IntConfOption | RetryableJobProgressTrackerClient. RETRYABLE_JOB_PROGRESS_CLIENT_NUM_RETRIESConf option for number of retries | 
| static IntConfOption | RetryableJobProgressTrackerClient. RETRYABLE_JOB_PROGRESS_CLIENT_RETRY_WAIT_MSConf option for wait time between retries | 
| Modifier and Type | Field and Description | 
|---|---|
| static IntConfOption | ClientThriftServer. CLIENT_THRIFT_SERVER_PORTThe client can run a Thrift server (e.g. | 
| static IntConfOption | DefaultJobProgressTrackerService. MAX_ALLOWED_TIME_WITHOUT_PROGRESS_MSMax time job is allowed to not make progress before getting killed | 
| Modifier and Type | Field and Description | 
|---|---|
| static IntConfOption | OutOfCoreIOStatistics. DISK_BANDWIDTH_ESTIMATEAn estimate of disk bandwidth. | 
| static IntConfOption | OutOfCoreIOStatistics. IO_COMMAND_HISTORY_SIZEHow many recent IO operations should we keep track of? Any report given out
 of this statistics collector is only based on most recent IO operations. | 
| static IntConfOption | OutOfCoreIOScheduler. OOC_WAIT_INTERVALIf an IO thread does not have any command to do, it waits for certain a
 period and check back again to see if there exist any command to perform. | 
| static IntConfOption | OutOfCoreIOStatistics. STATS_PRINT_FREQUENCYUse this option to control how frequently to print OOC statistics. | 
| Modifier and Type | Field and Description | 
|---|---|
| static IntConfOption | DiskBackedDataStore. MINIMUM_BUFFER_SIZE_TO_FLUSHMinimum size of a buffer (in bytes) to flush to disk. | 
| Modifier and Type | Field and Description | 
|---|---|
| static IntConfOption | LocalDiskDataAccessor. OOC_DISK_BUFFER_SIZESize of the buffer used for (de)serializing data when reading/writing
 from/to disk | 
| Modifier and Type | Field and Description | 
|---|---|
| static IntConfOption | ExtendedByteArrayOutputBuffer. CAPACITY_OF_DATAOUT_IN_BUFFERThis option sets the capacity of an
  ExtendedDataOutputinstance created inExtendedByteArrayOutputBuffer | 
| static IntConfOption | GcTracker. LAST_GCS_TO_KEEPHow many last gcs to keep | 
| Modifier and Type | Field and Description | 
|---|---|
| static IntConfOption | MemoryObserver. MIN_MS_BETWEEN_FULL_GCSMinimum milliseconds between two manual gc calls | 
Copyright © 2011-2020 The Apache Software Foundation. All Rights Reserved.