Guest User

cassandra yaml configuration

a guest
Dec 6th, 2013
192
0
Never
Not a member of Pastebin yet? Sign Up, it unlocks many cool features!
YAML 32.52 KB | None | 0 0
  1. # Cassandra storage config YAML
  2.  
  3. # NOTE:
  4. #   See http://wiki.apache.org/cassandra/StorageConfiguration for
  5. #   full explanations of configuration directives
  6. # /NOTE
  7.  
  8. # The name of the cluster. This is mainly used to prevent machines in
  9. # one logical cluster from joining another.
  10. cluster_name: TEST
  11.  
  12. # This defines the number of tokens randomly assigned to this node on the ring
  13. # The more tokens, relative to other nodes, the larger the proportion of data
  14. # that this node will store. You probably want all nodes to have the same number
  15. # of tokens assuming they have equal hardware capability.
  16. #
  17. # If you leave this unspecified, Cassandra will use the default of 1 token for legacy compatibility,
  18. # and will use the initial_token as described below.
  19. #
  20. # Specifying initial_token will override this setting.
  21. #
  22. # If you already have a cluster with 1 token per node, and wish to migrate to
  23. # multiple tokens per node, see http://wiki.apache.org/cassandra/Operations
  24. # num_tokens: 256
  25.  
  26. # If you haven't specified num_tokens, or have set it to the default of 1 then
  27. # you should always specify InitialToken when setting up a production
  28. # cluster for the first time, and often when adding capacity later.
  29. # The principle is that each node should be given an equal slice of
  30. # the token ring; see http://wiki.apache.org/cassandra/Operations
  31. # for more details.
  32. #
  33. # If blank, Cassandra will request a token bisecting the range of
  34. # the heaviest-loaded existing node.  If there is no load information
  35. # available, such as is the case with a new cluster, it will pick
  36. # a random token, which will lead to hot spots.
  37. initial_token: [initial_token]
  38.  
  39. # When set to true, populates a new node with a range of data when
  40. # it joins an established cluster based on the setting of
  41. # initial_token. If initial_token is not set, the newly added node
  42. # will insert itself into the ring by splitting the token range of
  43. # the most heavily loaded node. Leave set to false when initializing
  44. # a brand new cluster.
  45. auto_bootstrap: true
  46.  
  47. # See http://wiki.apache.org/cassandra/HintedHandoff
  48. hinted_handoff_enabled: true
  49. # this defines the maximum amount of time a dead host will have hints
  50. # generated.  After it has been dead this long, new hints for it will not be
  51. # created until it has been seen alive and gone down again.
  52. max_hint_window_in_ms: 3600000 # one hour
  53. # throttle in KBs per second, per delivery thread
  54. hinted_handoff_throttle_in_kb: 1024
  55. # Number of threads with which to deliver hints;
  56. # Consider increasing this number when you have multi-dc deployments, since
  57. # cross-dc handoff tends to be slower
  58. max_hints_delivery_threads: 5
  59.  
  60. # The following setting populates the page cache on memtable flush and compaction
  61. # WARNING: Enable this setting only when the whole node's data fits in memory.
  62. # Defaults to: false
  63. # populate_io_cache_on_flush: false
  64.  
  65. # Authentication backend, implementing IAuthenticator; used to identify users
  66. # Out of the box, Cassandra provides org.apache.cassandra.auth.{AllowAllAuthenticator,
  67. # PasswordAuthenticator}.
  68. #
  69. # - AllowAllAuthenticator performs no checks - set it to disable authentication.
  70. # - PasswordAuthenticator relies on username/password pairs to authenticate
  71. #   users. It keeps usernames and hashed passwords in system_auth.credentials table.
  72. #   Please increase system_auth keyspace replication factor if you use this authenticator.
  73. #authenticator: org.apache.cassandra.auth.AllowAllAuthenticator
  74. authenticator: org.apache.cassandra.auth.CustomAuthenticator
  75.  
  76. # Authorization backend, implementing IAuthorizer; used to limit access/provide permissions
  77. # Out of the box, Cassandra provides org.apache.cassandra.auth.{AllowAllAuthorizer,
  78. # CassandraAuthorizer}.
  79. #
  80. # - AllowAllAuthorizer allows any action to any user - set it to disable authorization.
  81. # - CassandraAuthorizer stores permissions in system_auth.permissions table. Please
  82. #   increase system_auth keyspace replication factor if you use this authorizer.
  83. #authorizer: org.apache.cassandra.auth.AllowAllAuthorizer
  84. authorizer: org.apache.cassandra.auth.CustomAuthorizer
  85.  
  86. # Validity period for permissions cache (fetching permissions can be an
  87. # expensive operation depending on the authorizer, CassandraAuthorizer is
  88. # one example). Defaults to 2000, set to 0 to disable.
  89. # Will be disabled automatically for AllowAllAuthorizer.
  90. # permissions_validity_in_ms: 2000
  91. permissions_validity_in_ms: 0
  92.  
  93. # The partitioner is responsible for distributing rows (by key) across
  94. # nodes in the cluster.  Any IPartitioner may be used, including your
  95. # own as long as it is on the classpath.  Out of the box, Cassandra
  96. # provides org.apache.cassandra.dht.{Murmur3Partitioner, RandomPartitioner
  97. # ByteOrderedPartitioner, OrderPreservingPartitioner (deprecated)}.
  98. #
  99. # - RandomPartitioner distributes rows across the cluster evenly by md5.
  100. #   This is the default prior to 1.2 and is retained for compatibility.
  101. # - Murmur3Partitioner is similar to RandomPartioner but uses Murmur3_128
  102. #   Hash Function instead of md5.  When in doubt, this is the best option.
  103. # - ByteOrderedPartitioner orders rows lexically by key bytes.  BOP allows
  104. #   scanning rows in key order, but the ordering can generate hot spots
  105. #   for sequential insertion workloads.
  106. # - OrderPreservingPartitioner is an obsolete form of BOP, that stores
  107. # - keys in a less-efficient format and only works with keys that are
  108. #   UTF8-encoded Strings.
  109. # - CollatingOPP collates according to EN,US rules rather than lexical byte
  110. #   ordering.  Use this as an example if you need custom collation.
  111. #
  112. # See http://wiki.apache.org/cassandra/Operations for more on
  113. # partitioners and token selection.
  114. # partitioner: org.apache.cassandra.dht.Murmur3Partitioner
  115. partitioner: org.apache.cassandra.dht.RandomPartitioner
  116.  
  117. # Directories where Cassandra should store data on disk.  Cassandra
  118. # will spread data evenly across them, subject to the granularity of
  119. # the configured compaction strategy.
  120. data_file_directories:
  121.    - /var/lib/cassandra/data
  122.  
  123. # commit log
  124. commitlog_directory: [commitlog_directory]
  125.  
  126. # policy for data disk failures:
  127. # stop: shut down gossip and Thrift, leaving the node effectively dead, but
  128. #       can still be inspected via JMX.
  129. # best_effort: stop using the failed disk and respond to requests based on
  130. #              remaining available sstables.  This means you WILL see obsolete
  131. #              data at CL.ONE!
  132. # ignore: ignore fatal errors and let requests fail, as in pre-1.2 Cassandra
  133. disk_failure_policy: stop
  134.  
  135. # Maximum size of the key cache in memory.
  136. #
  137. # Each key cache hit saves 1 seek and each row cache hit saves 2 seeks at the
  138. # minimum, sometimes more. The key cache is fairly tiny for the amount of
  139. # time it saves, so it's worthwhile to use it at large numbers.
  140. # The row cache saves even more time, but must contain the entire row,
  141. # so it is extremely space-intensive. It's best to only use the
  142. # row cache if you have hot rows or static rows.
  143. #
  144. # NOTE: if you reduce the size, you may not get you hottest keys loaded on startup.
  145. #
  146. # Default value is empty to make it "auto" (min(5% of Heap (in MB), 100MB)). Set to 0 to disable key cache.
  147. key_cache_size_in_mb:
  148. # Duration in seconds after which Cassandra should
  149. # save the key cache. Caches are saved to saved_caches_directory as
  150. # specified in this configuration file.
  151. #
  152. # Saved caches greatly improve cold-start speeds, and is relatively cheap in
  153. # terms of I/O for the key cache. Row cache saving is much more expensive and
  154. # has limited use.
  155. #
  156. # Default is 14400 or 4 hours.
  157. key_cache_save_period: 14400
  158.  
  159. # Number of keys from the key cache to save
  160. # Disabled by default, meaning all keys are going to be saved
  161. # key_cache_keys_to_save: 100
  162.  
  163. # Maximum size of the row cache in memory.
  164. # NOTE: if you reduce the size, you may not get you hottest keys loaded on startup.
  165. #
  166. # Default value is 0, to disable row caching.
  167. row_cache_size_in_mb: 0
  168.  
  169. # Duration in seconds after which Cassandra should
  170. # safe the row cache. Caches are saved to saved_caches_directory as specified
  171. # in this configuration file.
  172. #
  173. # Saved caches greatly improve cold-start speeds, and is relatively cheap in
  174. # terms of I/O for the key cache. Row cache saving is much more expensive and
  175. # has limited use.
  176. #
  177. # Default is 0 to disable saving the row cache.
  178. row_cache_save_period: 0
  179.  
  180. # Number of keys from the row cache to save
  181. # Disabled by default, meaning all keys are going to be saved
  182. # row_cache_keys_to_save: 100
  183.  
  184. # The provider for the row cache to use.
  185. #
  186. # Supported values are: ConcurrentLinkedHashCacheProvider, SerializingCacheProvider
  187. #
  188. # SerializingCacheProvider serialises the contents of the row and stores
  189. # it in native memory, i.e., off the JVM Heap. Serialized rows take
  190. # significantly less memory than "live" rows in the JVM, so you can cache
  191. # more rows in a given memory footprint.  And storing the cache off-heap
  192. # means you can use smaller heap sizes, reducing the impact of GC pauses.
  193. # Note however that when a row is requested from the row cache, it must be
  194. # deserialized into the heap for use.
  195. #
  196. # It is also valid to specify the fully-qualified class name to a class
  197. # that implements org.apache.cassandra.cache.IRowCacheProvider.
  198. #
  199. # Defaults to SerializingCacheProvider
  200. row_cache_provider: SerializingCacheProvider
  201.  
  202. # saved caches
  203. saved_caches_directory: [saved_caches_directory]
  204.  
  205. # commitlog_sync may be either "periodic" or "batch."
  206. # When in batch mode, Cassandra won't ack writes until the commit log
  207. # has been fsynced to disk.  It will wait up to
  208. # commitlog_sync_batch_window_in_ms milliseconds for other writes, before
  209. # performing the sync.
  210. #
  211. # commitlog_sync: batch
  212. # commitlog_sync_batch_window_in_ms: 50
  213. #
  214. # the other option is "periodic" where writes may be acked immediately
  215. # and the CommitLog is simply synced every commitlog_sync_period_in_ms
  216. # milliseconds.
  217. commitlog_sync: periodic
  218. commitlog_sync_period_in_ms: 10000
  219.  
  220. # The size of the individual commitlog file segments.  A commitlog
  221. # segment may be archived, deleted, or recycled once all the data
  222. # in it (potentially from each columnfamily in the system) has been
  223. # flushed to sstables.  
  224. #
  225. # The default size is 32, which is almost always fine, but if you are
  226. # archiving commitlog segments (see commitlog_archiving.properties),
  227. # then you probably want a finer granularity of archiving; 8 or 16 MB
  228. # is reasonable.
  229. commitlog_segment_size_in_mb: 32
  230.  
  231. # any class that implements the SeedProvider interface and has a
  232. # constructor that takes a Map<String, String> of parameters will do.
  233. seed_provider:
  234.    # Addresses of hosts that are deemed contact points.
  235.     # Cassandra nodes use this list of hosts to find each other and learn
  236.     # the topology of the ring.  You must change this if you are running
  237.     # multiple nodes!
  238.     - class_name: org.apache.cassandra.locator.SimpleSeedProvider
  239.       parameters:
  240.          # seeds is actually a comma-delimited list of addresses.
  241.           # Ex: "<ip1>,<ip2>,<ip3>"
  242.           - seeds: <ip1>,<ip2>,<ip3>
  243. # emergency pressure valve: each time heap usage after a full (CMS)
  244. # garbage collection is above this fraction of the max, Cassandra will
  245. # flush the largest memtables.  
  246. #
  247. # Set to 1.0 to disable.  Setting this lower than
  248. # CMSInitiatingOccupancyFraction is not likely to be useful.
  249. #
  250. # RELYING ON THIS AS YOUR PRIMARY TUNING MECHANISM WILL WORK POORLY:
  251. # it is most effective under light to moderate load, or read-heavy
  252. # workloads; under truly massive write load, it will often be too
  253. # little, too late.
  254. flush_largest_memtables_at: 0.75
  255.  
  256. # emergency pressure valve #2: the first time heap usage after a full
  257. # (CMS) garbage collection is above this fraction of the max,
  258. # Cassandra will reduce cache maximum _capacity_ to the given fraction
  259. # of the current _size_.  Should usually be set substantially above
  260. # flush_largest_memtables_at, since that will have less long-term
  261. # impact on the system.  
  262. #
  263. # Set to 1.0 to disable.  Setting this lower than
  264. # CMSInitiatingOccupancyFraction is not likely to be useful.
  265. reduce_cache_sizes_at: 0.85
  266. reduce_cache_capacity_to: 0.6
  267.  
  268. # For workloads with more data than can fit in memory, Cassandra's
  269. # bottleneck will be reads that need to fetch data from
  270. # disk. "concurrent_reads" should be set to (16 * number_of_drives) in
  271. # order to allow the operations to enqueue low enough in the stack
  272. # that the OS and drives can reorder them.
  273. #
  274. # On the other hand, since writes are almost never IO bound, the ideal
  275. # number of "concurrent_writes" is dependent on the number of cores in
  276. # your system; (8 * number_of_cores) is a good rule of thumb.
  277. concurrent_reads: 32
  278. concurrent_writes: 160
  279.  
  280. # Total memory to use for memtables.  Cassandra will flush the largest
  281. # memtable when this much memory is used.
  282. # If omitted, Cassandra will set it to 1/3 of the heap.
  283. # memtable_total_space_in_mb: 2048
  284.  
  285. # Total space to use for commitlogs.  Since commitlog segments are
  286. # mmapped, and hence use up address space, the default size is 32
  287. # on 32-bit JVMs, and 1024 on 64-bit JVMs.
  288. #
  289. # If space gets above this value (it will round up to the next nearest
  290. # segment multiple), Cassandra will flush every dirty CF in the oldest
  291. # segment and remove it.  So a small total commitlog space will tend
  292. # to cause more flush activity on less-active columnfamilies.
  293. # commitlog_total_space_in_mb: 4096
  294.  
  295. # This sets the amount of memtable flush writer threads.  These will
  296. # be blocked by disk io, and each one will hold a memtable in memory
  297. # while blocked. If you have a large heap and many data directories,
  298. # you can increase this value for better flush performance.
  299. # By default this will be set to the amount of data directories defined.
  300. # workaround for https://issues.apache.org/jira/browse/CASSANDRA-6297
  301. #memtable_flush_writers: 1
  302.  
  303. # the number of full memtables to allow pending flush, that is,
  304. # waiting for a writer thread.  At a minimum, this should be set to
  305. # the maximum number of secondary indexes created on a single CF.
  306. memtable_flush_queue_size: 4
  307.  
  308. # Whether to, when doing sequential writing, fsync() at intervals in
  309. # order to force the operating system to flush the dirty
  310. # buffers. Enable this to avoid sudden dirty buffer flushing from
  311. # impacting read latencies. Almost always a good idea on SSDs; not
  312. # necessarily on platters.
  313. trickle_fsync: false
  314. trickle_fsync_interval_in_kb: 10240
  315.  
  316. # TCP port, for commands and data
  317. storage_port: [STORAGE PORT]
  318.  
  319. # SSL port, for encrypted communication.  Unused unless enabled in
  320. # encryption_options
  321. ssl_storage_port: [STORAGE PORT]
  322.  
  323. # Address to bind to and tell other Cassandra nodes to connect to. You
  324. # _must_ change this if you want multiple nodes to be able to
  325. # communicate!
  326. #
  327. # Leaving it blank leaves it up to InetAddress.getLocalHost(). This
  328. # will always do the Right Thing _if_ the node is properly configured
  329. # (hostname, name resolution, etc), and the Right Thing is to use the
  330. # address associated with the hostname (it might not be).
  331. #
  332. # Setting this to 0.0.0.0 is always wrong.
  333. listen_address: [LISTEN ADDRESS]
  334.  
  335. # Address to broadcast to other Cassandra nodes
  336. # Leaving this blank will set it to the same value as listen_address
  337. # broadcast_address: 1.2.3.4
  338.  
  339. # Internode authentication backend, implementing IInternodeAuthenticator;
  340. # used to allow/disallow connections from peer nodes.
  341. # internode_authenticator: org.apache.cassandra.auth.AllowAllInternodeAuthenticator
  342.  
  343. # Whether to start the native transport server.
  344. # Please note that the address on which the native transport is bound is the
  345. # same as the rpc_address. The port however is different and specified below.
  346. # start_native_transport: true
  347. # port for the CQL native transport to listen for clients on
  348. # native_transport_port: 9042
  349. # The minimum and maximum threads for handling requests when the native
  350. # transport is used. They are similar to rpc_min_threads and rpc_max_threads,
  351. # though the defaults differ slightly.
  352. # native_transport_min_threads: 16
  353. # native_transport_max_threads: 128
  354.  
  355. # Whether to start the thrift rpc server.
  356. start_rpc: true
  357.  
  358. # The address to bind the Thrift RPC service to -- clients connect
  359. # here. Unlike ListenAddress above, you _can_ specify 0.0.0.0 here if
  360. # you want Thrift to listen on all interfaces.
  361. #
  362. # Leaving this blank has the same effect it does for ListenAddress,
  363. # (i.e. it will be based on the configured hostname of the node).
  364. rpc_address: [RPC ADDRESS]
  365. # port for Thrift to listen for clients on
  366. rpc_port: [PORT]
  367.  
  368. # enable or disable keepalive on rpc connections
  369. rpc_keepalive: true
  370.  
  371. # Cassandra provides three out-of-the-box options for the RPC Server:
  372. #
  373. # sync  -> One thread per thrift connection. For a very large number of clients, memory
  374. #          will be your limiting factor. On a 64 bit JVM, 180KB is the minimum stack size
  375. #          per thread, and that will correspond to your use of virtual memory (but physical memory
  376. #          may be limited depending on use of stack space).
  377. #
  378. # hsha  -> Stands for "half synchronous, half asynchronous." All thrift clients are handled
  379. #          asynchronously using a small number of threads that does not vary with the amount
  380. #          of thrift clients (and thus scales well to many clients). The rpc requests are still
  381. #          synchronous (one thread per active request).
  382. #
  383. # The default is sync because on Windows hsha is about 30% slower.  On Linux,
  384. # sync/hsha performance is about the same, with hsha of course using less memory.
  385. #
  386. # Alternatively,  can provide your own RPC server by providing the fully-qualified class name
  387. # of an o.a.c.t.TServerFactory that can create an instance of it.
  388. rpc_server_type: sync
  389.  
  390. # Uncomment rpc_min|max_thread to set request pool size limits.
  391. #
  392. # Regardless of your choice of RPC server (see above), the number of maximum requests in the
  393. # RPC thread pool dictates how many concurrent requests are possible (but if you are using the sync
  394. # RPC server, it also dictates the number of clients that can be connected at all).
  395. #
  396. # The default is unlimited and thus provides no protection against clients overwhelming the server. You are
  397. # encouraged to set a maximum that makes sense for you in production, but do keep in mind that
  398. # rpc_max_threads represents the maximum number of client requests this server may execute concurrently.
  399. #
  400. # rpc_min_threads: 16
  401. # rpc_max_threads: 2048
  402.  
  403. # uncomment to set socket buffer sizes on rpc connections
  404. # rpc_send_buff_size_in_bytes:
  405. # rpc_recv_buff_size_in_bytes:
  406.  
  407. # Uncomment to set socket buffer size for internode communication
  408. # Note that when setting this, the buffer size is limited by net.core.wmem_max
  409. # and when not setting it it is defined by net.ipv4.tcp_wmem
  410. # See:
  411. # /proc/sys/net/core/wmem_max
  412. # /proc/sys/net/core/rmem_max
  413. # /proc/sys/net/ipv4/tcp_wmem
  414. # /proc/sys/net/ipv4/tcp_wmem
  415. # and: man tcp
  416. # internode_send_buff_size_in_bytes:
  417. # internode_recv_buff_size_in_bytes:
  418.  
  419. # Frame size for thrift (maximum field length).
  420. thrift_framed_transport_size_in_mb: 15
  421.  
  422. # The max length of a thrift message, including all fields and
  423. # internal thrift overhead.
  424. thrift_max_message_length_in_mb: 16
  425.  
  426. # Set to true to have Cassandra create a hard link to each sstable
  427. # flushed or streamed locally in a backups/ subdirectory of the
  428. # keyspace data.  Removing these links is the operator's
  429. # responsibility.
  430. incremental_backups: false
  431.  
  432. # Whether or not to take a snapshot before each compaction.  Be
  433. # careful using this option, since Cassandra won't clean up the
  434. # snapshots for you.  Mostly useful if you're paranoid when there
  435. # is a data format change.
  436. snapshot_before_compaction: false
  437.  
  438. # Whether or not a snapshot is taken of the data before keyspace truncation
  439. # or dropping of column families. The STRONGLY advised default of true
  440. # should be used to provide data safety. If you set this flag to false, you will
  441. # lose data on truncation or drop.
  442. auto_snapshot: true
  443.  
  444. # Log a debug message if more than this many tombstones are scanned
  445. # in a single-partition query.  Set the threshold on SliceQueryFilter
  446. # to debug to enable.
  447. tombstone_debug_threshold: 10000
  448.  
  449. # Add column indexes to a row after its contents reach this size.
  450. # Increase if your column values are large, or if you have a very large
  451. # number of columns.  The competing causes are, Cassandra has to
  452. # deserialize this much of the row to read a single column, so you want
  453. # it to be small - at least if you do many partial-row reads - but all
  454. # the index data is read for each access, so you don't want to generate
  455. # that wastefully either.
  456. column_index_size_in_kb: 64
  457.  
  458. # Size limit for rows being compacted in memory.  Larger rows will spill
  459. # over to disk and use a slower two-pass compaction process.  A message
  460. # will be logged specifying the row key.
  461. in_memory_compaction_limit_in_mb: 64
  462.  
  463. # Number of simultaneous compactions to allow, NOT including
  464. # validation "compactions" for anti-entropy repair.  Simultaneous
  465. # compactions can help preserve read performance in a mixed read/write
  466. # workload, by mitigating the tendency of small sstables to accumulate
  467. # during a single long running compactions. The default is usually
  468. # fine and if you experience problems with compaction running too
  469. # slowly or too fast, you should look at
  470. # compaction_throughput_mb_per_sec first.
  471. #
  472. # concurrent_compactors defaults to the number of cores.
  473. # Uncomment to make compaction mono-threaded, the pre-0.8 default.
  474. # concurrent_compactors: 1
  475.  
  476. # Multi-threaded compaction. When enabled, each compaction will use
  477. # up to one thread per core, plus one thread per sstable being merged.
  478. # This is usually only useful for SSD-based hardware: otherwise,
  479. # your concern is usually to get compaction to do LESS i/o (see:
  480. # compaction_throughput_mb_per_sec), not more.
  481. #multithreaded_compaction: true
  482.  
  483. # Throttles compaction to the given total throughput across the entire
  484. # system. The faster you insert data, the faster you need to compact in
  485. # order to keep the sstable count down, but in general, setting this to
  486. # 16 to 32 times the rate you are inserting data is more than sufficient.
  487. # Setting this to 0 disables throttling. Note that this account for all types
  488. # of compaction, including validation compaction.
  489. compaction_throughput_mb_per_sec: 16
  490.  
  491. # Track cached row keys during compaction, and re-cache their new
  492. # positions in the compacted sstable.  Disable if you use really large
  493. # key caches.
  494. compaction_preheat_key_cache: true
  495.  
  496. # Throttles all outbound streaming file transfers on this node to the
  497. # given total throughput in Mbps. This is necessary because Cassandra does
  498. # mostly sequential IO when streaming data during bootstrap or repair, which
  499. # can lead to saturating the network connection and degrading rpc performance.
  500. # When unset, the default is 200 Mbps or 25 MB/s.
  501. # stream_throughput_outbound_megabits_per_sec: 200
  502.  
  503. # How long the coordinator should wait for read operations to complete
  504. read_request_timeout_in_ms: 10000
  505. # How long the coordinator should wait for seq or index scans to complete
  506. range_request_timeout_in_ms: 10000
  507. # How long the coordinator should wait for writes to complete
  508. write_request_timeout_in_ms: 10000
  509.  
  510. # How long the coordinator should wait for truncates to complete
  511. # (This can be much longer, because unless auto_snapshot is disabled
  512. # we need to flush first so we can snapshot before removing the data.)
  513. truncate_request_timeout_in_ms: 60000
  514. # The default timeout for other, miscellaneous operations
  515.  
  516. request_timeout_in_ms: 10000
  517.  
  518. # Enable operation timeout information exchange between nodes to accurately
  519. # measure request timeouts, If disabled cassandra will assuming the request
  520. # was forwarded to the replica instantly by the coordinator
  521. #
  522. # Warning: before enabling this property make sure to ntp is installed
  523. # and the times are synchronized between the nodes.
  524. # cross_node_timeout: false
  525.  
  526. # Enable socket timeout for streaming operation.
  527. # When a timeout occurs during streaming, streaming is retried from the start
  528. # of the current file. This _can_ involve re-streaming an important amount of
  529. # data, so you should avoid setting the value too low.
  530. # Default value is 0, which never timeout streams.
  531. # streaming_socket_timeout_in_ms: 0
  532.  
  533. # phi value that must be reached for a host to be marked down.
  534. # most users should never need to adjust this.
  535. # phi_convict_threshold: 8
  536. # R6.1 increasing so that nodes are not falsely marked down
  537. phi_convict_threshold: 12
  538.  
  539. # endpoint_snitch -- Set this to a class that implements
  540. # IEndpointSnitch.  The snitch has two functions:
  541. # - it teaches Cassandra enough about your network topology to route
  542. #   requests efficiently
  543. # - it allows Cassandra to spread replicas around your cluster to avoid
  544. #   correlated failures. It does this by grouping machines into
  545. #   "datacenters" and "racks."  Cassandra will do its best not to have
  546. #   more than one replica on the same "rack" (which may not actually
  547. #   be a physical location)
  548. #
  549. # IF YOU CHANGE THE SNITCH AFTER DATA IS INSERTED INTO THE CLUSTER,
  550. # YOU MUST RUN A FULL REPAIR, SINCE THE SNITCH AFFECTS WHERE REPLICAS
  551. # ARE PLACED.
  552. #
  553. # Out of the box, Cassandra provides
  554. #  - SimpleSnitch:
  555. #    Treats Strategy order as proximity. This improves cache locality
  556. #    when disabling read repair, which can further improve throughput.
  557. #    Only appropriate for single-datacenter deployments.
  558. #  - PropertyFileSnitch:
  559. #    Proximity is determined by rack and data center, which are
  560. #    explicitly configured in cassandra-topology.properties.
  561. #  - GossipingPropertyFileSnitch
  562. #    The rack and datacenter for the local node are defined in
  563. #    cassandra-rackdc.properties and propagated to other nodes via gossip.  If
  564. #    cassandra-topology.properties exists, it is used as a fallback, allowing
  565. #    migration from the PropertyFileSnitch.
  566. #  - RackInferringSnitch:
  567. #    Proximity is determined by rack and data center, which are
  568. #    assumed to correspond to the 3rd and 2nd octet of each node's
  569. #    IP address, respectively.  Unless this happens to match your
  570. #    deployment conventions (as it did Facebook's), this is best used
  571. #    as an example of writing a custom Snitch class.
  572. #  - Ec2Snitch:
  573. #    Appropriate for EC2 deployments in a single Region. Loads Region
  574. #    and Availability Zone information from the EC2 API. The Region is
  575. #    treated as the datacenter, and the Availability Zone as the rack.
  576. #    Only private IPs are used, so this will not work across multiple
  577. #    Regions.
  578. #  - Ec2MultiRegionSnitch:
  579. #    Uses public IPs as broadcast_address to allow cross-region
  580. #    connectivity.  (Thus, you should set seed addresses to the public
  581. #    IP as well.) You will need to open the storage_port or
  582. #    ssl_storage_port on the public IP firewall.  (For intra-Region
  583. #    traffic, Cassandra will switch to the private IP after
  584. #    establishing a connection.)
  585. #
  586. # You can use a custom Snitch by setting this to the full class name
  587. # of the snitch, which will be assumed to be on your classpath.
  588. endpoint_snitch: GossipingPropertyFileSnitch
  589.  
  590. # controls how often to perform the more expensive part of host score
  591. # calculation
  592. dynamic_snitch_update_interval_in_ms: 100
  593. # controls how often to reset all host scores, allowing a bad host to
  594. # possibly recover
  595. dynamic_snitch_reset_interval_in_ms: 600000
  596. # if set greater than zero and read_repair_chance is < 1.0, this will allow
  597. # 'pinning' of replicas to hosts in order to increase cache capacity.
  598. # The badness threshold will control how much worse the pinned host has to be
  599. # before the dynamic snitch will prefer other replicas over it.  This is
  600. # expressed as a double which represents a percentage.  Thus, a value of
  601. # 0.2 means Cassandra would continue to prefer the static snitch values
  602. # until the pinned host was 20% worse than the fastest.
  603. dynamic_snitch_badness_threshold: 0.1
  604.  
  605. # request_scheduler -- Set this to a class that implements
  606. # RequestScheduler, which will schedule incoming client requests
  607. # according to the specific policy. This is useful for multi-tenancy
  608. # with a single Cassandra cluster.
  609. # NOTE: This is specifically for requests from the client and does
  610. # not affect inter node communication.
  611. # org.apache.cassandra.scheduler.NoScheduler - No scheduling takes place
  612. # org.apache.cassandra.scheduler.RoundRobinScheduler - Round robin of
  613. # client requests to a node with a separate queue for each
  614. # request_scheduler_id. The scheduler is further customized by
  615. # request_scheduler_options as described below.
  616. request_scheduler: org.apache.cassandra.scheduler.NoScheduler
  617.  
  618. # Scheduler Options vary based on the type of scheduler
  619. # NoScheduler - Has no options
  620. # RoundRobin
  621. #  - throttle_limit -- The throttle_limit is the number of in-flight
  622. #                      requests per client.  Requests beyond
  623. #                      that limit are queued up until
  624. #                      running requests can complete.
  625. #                      The value of 80 here is twice the number of
  626. #                      concurrent_reads + concurrent_writes.
  627. #  - default_weight -- default_weight is optional and allows for
  628. #                      overriding the default which is 1.
  629. #  - weights -- Weights are optional and will default to 1 or the
  630. #               overridden default_weight. The weight translates into how
  631. #               many requests are handled during each turn of the
  632. #               RoundRobin, based on the scheduler id.
  633. #
  634. # request_scheduler_options:
  635. #    throttle_limit: 80
  636. #    default_weight: 5
  637. #    weights:
  638. #      Keyspace1: 1
  639. #      Keyspace2: 5
  640.  
  641. # request_scheduler_id -- An identifier based on which to perform
  642. # the request scheduling. Currently the only valid option is keyspace.
  643. # request_scheduler_id: keyspace
  644.  
  645. # index_interval controls the sampling of entries from the primrary
  646. # row index in terms of space versus time.  The larger the interval,
  647. # the smaller and less effective the sampling will be.  In technicial
  648. # terms, the interval coresponds to the number of index entries that
  649. # are skipped between taking each sample.  All the sampled entries
  650. # must fit in memory.  Generally, a value between 128 and 512 here
  651. # coupled with a large key cache size on CFs results in the best trade
  652. # offs.  This value is not often changed, however if you have many
  653. # very small rows (many to an OS page), then increasing this will
  654. # often lower memory usage without a impact on performance.
  655.  
  656. index_interval: 512
  657.  
  658. # Enable or disable inter-node encryption
  659. # Default settings are TLS v1, RSA 1024-bit keys (it is imperative that
  660. # users generate their own keys) TLS_RSA_WITH_AES_128_CBC_SHA as the cipher
  661. # suite for authentication, key exchange and encryption of the actual data transfers.
  662. # NOTE: No custom encryption options are enabled at the moment
  663. # The available internode options are : all, none, dc, rack
  664. #
  665. # If set to dc cassandra will encrypt the traffic between the DCs
  666. # If set to rack cassandra will encrypt the traffic between the racks
  667. #
  668. # The passwords used in these options must match the passwords used when generating
  669. # the keystore and truststore.  For instructions on generating these files, see:
  670. # http://download.oracle.com/javase/6/docs/technotes/guides/security/jsse/JSSERefGuide.html#CreateKeystore
  671. #
  672. server_encryption_options:
  673.     internode_encryption: true
  674.     keystore: [KEYSTORE]
  675.     keystore_password: [KEYSTORE PASSWORD]
  676.     truststore: [TRUSTSTORE]
  677.     truststore_password: [TRUSTSTORE PASSWORD]
  678.     # More advanced defaults below:
  679.     # protocol: TLS
  680.     # algorithm: SunX509
  681.     # store_type: JKS
  682.     # cipher_suites: [TLS_RSA_WITH_AES_128_CBC_SHA,TLS_RSA_WITH_AES_256_CBC_SHA]
  683.     require_client_auth: true
  684.  
  685. # enable or disable client/server encryption.
  686. client_encryption_options:
  687.     enabled: true
  688.     keystore: [KEYSTORE]
  689.     keystore_password: [KEYSTORE PASSWORD]
  690.     require_client_auth: true
  691.     # Set trustore and truststore_password if require_client_auth is true
  692.     truststore: [TRUSTSTORE]
  693.     truststore_password: [PASSWORD]    
  694.     # More advanced defaults below:
  695.     # protocol: TLS
  696.     # algorithm: SunX509
  697.     # store_type: JKS
  698.     # cipher_suites: [TLS_RSA_WITH_AES_128_CBC_SHA,TLS_RSA_WITH_AES_256_CBC_SHA]
  699.  
  700. # internode_compression controls whether traffic between nodes is
  701. # compressed.
  702. # can be:  all  - all traffic is compressed
  703. #          dc   - traffic between different datacenters is compressed
  704. #          none - nothing is compressed.
  705. # internode_compression: all
  706.  
  707. internode_compression: none
  708.  
  709. # Enable or disable tcp_nodelay for inter-dc communication.
  710. # Disabling it will result in larger (but fewer) network packets being sent,
  711. # reducing overhead from the TCP protocol itself, at the cost of increasing
  712. # latency if you block for cross-datacenter responses.
  713. inter_dc_tcp_nodelay: true
Advertisement
Add Comment
Please, Sign In to add comment